yakgrpc

package
v1.3.3 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: May 30, 2024 License: AGPL-3.0 Imports: 126 Imported by: 0

Documentation

Index

Constants

View Source
const (
	OneKB   = 1 * 1024
	EightKB = 8 * 1024
	OneMB   = 1 * 1024 * 1024 // 1 MB in bytes
	FiveMB  = 5 * 1024 * 1024 // 5 MB in bytes
)
View Source
const (
	MITMReplacerKeyRecords = "R1oHf8xca6CobwVg2_MITMReplacerKeyRecords"
	MITMFilterKeyRecords   = "uWokegBnCQdnxezJtMVo_MITMFilterKeyRecords"
)
View Source
const (
	SPACE_ENGINE_ZOOMEYE = "zoomeye"
	SPACE_ENGINE_FOFA    = "fofa"
	SPACE_ENGINE_SHODAN  = "shodan"
	SPACE_ENGINE_HUNTER  = "hunter"
	SPACE_ENGINE_QUAKE   = "quake"

	SPACE_ENGINE_STATUS_NORMAL          = "normal"
	SPACE_ENGINE_STATUS_ERROR           = "error"
	SPACE_ENGINE_STATUS_INVALID_ACCOUNT = "invalid_account"
	SPACE_ENGINE_STATUS_EMPTY_KEY       = "empty_key"
	SPACE_ENGINE_STATUS_INVALID_TYPE    = "invalid_type"
)
View Source
const (
	COMPLETION = "completion"
	HOVER      = "hover"
	SIGNATURE  = "signature"
	DEFINITION = "definition"
	REFERENCES = "reference"
)
View Source
const (
	KEY_ProgressManager     = "JznQXuFDSepeNWHbiLGEwONiaBxhvj_PROGRESS_MANAGER"
	KEY_SimpleDetectManager = "JznQXuFDSepeNWHbiLGEwONiaBxhvj_SIMPLE_DETECT_MANAGER"
)
View Source
const EXECUTEPACKET_CODE = `` /* 1081-byte string literal not displayed */
View Source
const (
	MAX_PHI_LEVEL = 5
)
View Source
const PORTSCAN_PLUGIN_TRIGGER_CODE = `` /* 1260-byte string literal not displayed */
View Source
const (
	YAK_ENGINE_DEFAULT_SCAN_PROXY = "YAK_ENGINE_DEFAULT_SCAN_PROXY"
)

Variables

View Source
var BatchPoCTemplate, _ = template.New("BatchPoCTemplate").Parse(`

isHttps = cli.Have("https", cli.setDefault({{ .https }}))
target = cli.String("target", cli.setDefault("{{ .target }}"))
concurrent = cli.Int("concurrent", cli.setDefault(10))

packet = ` + "`" + `{{ .packetTemplate }}` + "`" + `

debug = cli.Have("debug", cli.setDefault(true))

if debug {
    loglevel("debug")
}

batchPacket = func(target) {
    return httpool.Pool(
        packet, 
        # httpool.proxy("http://127.0.0.1:8083"),
        # httpool.proxy("http://127.0.0.1:7890"),
        httpool.rawMode(true),
        httpool.size(concurrent), 
        httpool.redirectTimes(5),
        httpool.perRequestTimeout(10),
        httpool.fuzz(true),
        httpool.fuzzParams({
            "target": target,
        }),
    )
}

if YAK_MAIN {
    res, err = batchPacket(target)
    if err != nil {
        log.error("send packet error: %s", err)
        return
    }

    for result = range res {

        if result.Error != nil {
            yakit.Error("Request[%v] Payload: %v Failed: %v", result.Url, result.Payloads, result.Error)
            continue
        }

        yakit.Info("[%v] Request Result Received! payloads: %v", result.Url, result.Payloads)

        reqBytes := result.RequestRaw
        rspBytes := result.ResponseRaw

        if debug {
            println(string(reqBytes))
            println("---------------------------------")
            println(string(rspBytes))
        }

        // 处理结果
        riskTarget = target
        if str.MatchAllOfRegexp(rspBytes, ` + "`" + `(?i)foundtextinRsp!` + "`" + `) || str.MatchAllOfSubString(rspBytes, "FoundTextInResponse") {
            urlIns, _ = str.ExtractURLFromHTTPRequestRaw(reqBytes, isHttps)
            if urlIns == nil {
                riskTarget = urlIns.String()
            }
            yakit.Info("Matched for %v", target)
            # Save to RiskTable
            risk.NewRisk(
                riskTarget, risk.severity("high"), risk.type("poc"),
                risk.title("English Title"),            ## English Title for Risk
                risk.titleVerbose("中文标题"),           ##  中文标题
                risk.details({
                    "target": riskTarget,
                    "request": reqBytes,
                    "response": rspBytes,
                }),
            )
        }
    }
}

/*
type palm/common/mutate.(_httpResult) struct {
  Fields(可用字段): 
      Url: string  
      Request: *http.Request  
      Error: error  
      RequestRaw: []uint8  
      ResponseRaw: []uint8  
      Response: *http.Response  
      DurationMs: int64  
      Timestamp: int64  
      Payloads: []string  
  StructMethods(结构方法/函数): 
  PtrStructMethods(指针结构方法/函数): 
}
*/


`)
View Source
var OrdinaryPoCTemplate, _ = template.New("OrdinaryPoCTemplate").Parse(`
isHttps = cli.Have("https", cli.setDefault({{ .https }}))
target = cli.String("target", cli.setDefault("{{ .target }}"))

packet = ` + "`" + `
{{ .packetTemplate }}` + "`" + `

debug = cli.Have("debug", cli.setDefault(true))

if debug {
    loglevel("debug")
}

sendPacket = func(target) {
    return poc.HTTP(
        packet, 
        poc.timeout(10),
        # poc.proxy("http://127.0.0.1:8083"),
        # poc.proxy("http://127.0.0.1:7890"),
        poc.redirectTimes(3),  # 重定向次数
        poc.https(isHttps),
        poc.params({
            "target": target,
        },
    ))
}

if YAK_MAIN {
    rspBytes, reqBytes, err = sendPacket(target)
    if err != nil {
        log.error("send packet error: %s", err)
        return
    }

    if debug {
        println(string(reqBytes))
        println("---------------------------------")
        println(string(rspBytes))
    }

    riskTarget = target
    if str.MatchAllOfRegexp(rspBytes, ` + "`" + `(?i)foundtextinRsp!` + "`" + `) || str.MatchAllOfSubString(rspBytes, "FoundTextInResponse") {
        urlIns, _ = str.ExtractURLFromHTTPRequestRaw(reqBytes, isHttps)
        if urlIns == nil {
            riskTarget = urlIns.String()
        }
        yakit.Info("Matched for %v", target)
        # Save to RiskTable
        risk.NewRisk(
            riskTarget, risk.severity("high"), risk.type("poc"),
            risk.title("English Title"),            ## English Title for Risk
            risk.titleVerbose("中文标题"),           ##  中文标题
            risk.details({
                "target": riskTarget,
                "request": reqBytes,
                "response": rspBytes,
            }),
        )
    }
}
















`)
View Source
var (
	OriginRiskStats *ypb.RiskTableStats
)
View Source
var YakitAllTables = schema.ProjectTables
View Source
var YakitProfileTables = schema.ProfileTables

Functions

func AddExecBatchTask added in v1.3.3

func AddExecBatchTask(runtimeId string, percent float64, yakScriptOnlineGroup, taskName string, req *ypb.ExecBatchYakScriptRequest)

func AddSimpleDetectTask added in v1.3.3

func AddSimpleDetectTask(runtimeId string, req *ypb.RecordPortScanRequest)

func AfterAndBeforeIsExit added in v1.2.2

func AfterAndBeforeIsExit(id int64) (before, after bool)

func BuildHttpRequestPacket added in v1.3.2

func BuildHttpRequestPacket(db *gorm.DB, baseBuilderParams *ypb.HTTPRequestBuilderParams, targetInput string) (chan *HTTPRequestBuilderRes, error)

func Chardet

func Chardet(raw []byte) string

func CheckDefault

func CheckDefault(ProjectName, Type string, FolderId, ChildFolderId int64) error

func CompareParameter added in v1.3.0

func CompareParameter(p1, p2 *ypb.YakScriptParam) bool

CompareParameter p1 and p2 all field if return true, p2 information is more than p1

func ConvertLowhttpResponseToFuzzerResponseBase added in v1.2.4

func ConvertLowhttpResponseToFuzzerResponseBase(r *lowhttp.LowhttpResponse) *ypb.FuzzerResponse

func ConvertYakScriptToExecRequest

func ConvertYakScriptToExecRequest(req *ypb.ExecRequest, script *schema.YakScript, batchMode bool) (*ypb.ExecRequest, []func(), error)

func DeleteBatchYakScriptRequestByRuntimeId added in v1.3.3

func DeleteBatchYakScriptRequestByRuntimeId(db *gorm.DB, runtimeId string) (*ypb.ExecBatchYakScriptRequest, error)

func DeleteSimpleDetectUnfinishedTaskByUid added in v1.3.3

func DeleteSimpleDetectUnfinishedTaskByUid(db *gorm.DB, runtimeId string) (*ypb.RecordPortScanRequest, error)

func FixPacket added in v1.3.3

func FixPacket(packet []byte, isReq bool) (fixed []byte, use bool)

func GRPCYakScriptToYakScript added in v1.2.9

func GRPCYakScriptToYakScript(script *ypb.SaveNewYakScriptRequest) map[string]interface{}

func GRPCYakScriptToYakitScript

func GRPCYakScriptToYakitScript(script *ypb.YakScript) *schema.YakScript

func GenerateYsoPayload added in v1.3.2

func GenerateYsoPayload(req *ypb.YsoOptionsRequerstWithVerbose) (string, func(opts ...yso.MarshalOptionFun) ([]byte, error), error)

GenerateYsoPayload a utils for generate yso payload, return value is: token(className),Gadget or Class Instance,payload toByte fun,error

func GetBatchYakScriptRequestByRuntimeId added in v1.3.3

func GetBatchYakScriptRequestByRuntimeId(db *gorm.DB, runtimeId string) (*ypb.ExecBatchYakScriptRequest, error)

func GetBuildinAvailableBruteTypeTree added in v1.3.2

func GetBuildinAvailableBruteTypeTree(typeMap []struct {
	Name string
	Data string
}) []*ypb.Tree

func GetSimpleDetectUnfinishedTaskByUid added in v1.3.3

func GetSimpleDetectUnfinishedTaskByUid(db *gorm.DB, runtimeId string) (*ypb.RecordPortScanRequest, error)

func GrpcRangeToSSARange added in v1.3.3

func GrpcRangeToSSARange(sourceCode string, r *ypb.Range) *ssa.Range

func IsContain

func IsContain(items []*ypb.MenuItemGroup, item string) bool

func IsContainNavigation added in v1.2.3

func IsContainNavigation(items []*ypb.NavigationList, item string) bool

func IsExtOption added in v1.3.2

func IsExtOption(key string) bool

func IsValueInSortedSlice added in v1.2.2

func IsValueInSortedSlice(value string, slice []string) bool

func KVPairToParamItem added in v1.3.2

func KVPairToParamItem(params []*ypb.KVPair) []*ypb.ExecParamItem

func MarshalYakTemplateToYaml added in v1.2.7

func MarshalYakTemplateToYaml(y *httptpl.YakTemplate) (string, error)

func NewFakeStream added in v1.2.3

func NewFakeStream(ctx context.Context, handler func(result *ypb.ExecResult) error) *fakeStreamInstance

func NewFuzzerSequenceFlow added in v1.2.4

func NewFuzzerSequenceFlow(request *ypb.FuzzerRequest) *fuzzerSequenceFlow

func NewLocalClient added in v1.2.8

func NewLocalClient(locals ...bool) (ypb.YakClient, error)

func NewMITMReplacer

func NewMITMReplacer(initFunc ...func() []*ypb.MITMContentReplacer) *mitmReplacer

func NewRiskGRPCModel

func NewRiskGRPCModel(p *schema.Risk) *ypb.NewRisk

func OnCompletion added in v1.2.9

func OnCompletion(prog *ssaapi.Program, word string, containPoint bool, rng *ssa.Range, v *ssaapi.Value) (ret []*ypb.SuggestionDescription)

func OnFindDefinition added in v1.3.3

func OnFindDefinition(prog *ssaapi.Program, word string, containPoint bool, ssaRange *ssa.Range, v *ssaapi.Value) ([]memedit.RangeIf, error)

func OnFindReferences added in v1.3.3

func OnFindReferences(prog *ssaapi.Program, word string, containPoint bool, ssaRange *ssa.Range, v *ssaapi.Value) ([]memedit.RangeIf, error)

func OnHover added in v1.2.9

func OnHover(prog *ssaapi.Program, word string, containPoint bool, rng *ssa.Range, v *ssaapi.Value) (ret []*ypb.SuggestionDescription)

func OnSignature added in v1.2.9

func OnSignature(prog *ssaapi.Program, word string, containPoint bool, rng *ssa.Range, v *ssaapi.Value) (ret []*ypb.SuggestionDescription)

func ParamItemToKVPair added in v1.3.2

func ParamItemToKVPair(params []*ypb.ExecParamItem) []*ypb.KVPair

func ParseReassembledTraffic added in v1.3.0

func ParseReassembledTraffic(data []byte) ([]any, error)

func ParseTraffic added in v1.3.0

func ParseTraffic(data []byte, rule string) ([]any, error)

func Payload2Grpc added in v1.2.9

func Payload2Grpc(payload *schema.Payload) *ypb.Payload

func PortsServiceTypeGroup added in v1.2.2

func PortsServiceTypeGroup(data []*yakit.PortsTypeGroup) ypb.QueryPortsGroupResponse

func QueryYakScriptByNames

func QueryYakScriptByNames(db *gorm.DB, req []string) []*ypb.DownloadOnlinePluginByScriptName

func RangeIfToGrpcRange added in v1.3.3

func RangeIfToGrpcRange(rng memedit.RangeIf) *ypb.Range

func RegisterVulinboxAgent added in v1.2.3

func RegisterVulinboxAgent(addr string, agent *VulinboxAgentFacade)

func RemoveHybridTask added in v1.2.9

func RemoveHybridTask(id string)

func ReplaceString

func ReplaceString(s string) string

func SaveFromYakitLog

func SaveFromYakitLog(l *yaklib.YakitLog, db *gorm.DB)

func ScanHybridTargetWithPlugin added in v1.3.2

func ScanHybridTargetWithPlugin(
	runtimeId string, ctx context.Context, target *HybridScanTarget, plugin *schema.YakScript, proxy string, feedbackClient *yaklib.YakitClient, callerFilter *filter.StringFilter,
) error

func TargetGenerator added in v1.3.2

func TargetGenerator(ctx context.Context, db *gorm.DB, targetConfig *ypb.HybridScanInputTarget) (chan *HybridScanTarget, error)

func ToGrpcPort

func ToGrpcPort(r *schema.Port) *ypb.Port

func WatchDatabaseTableMeta added in v1.3.2

func WatchDatabaseTableMeta(db *gorm.DB, last int64, streamCtx context.Context, tableName string) (_ int64, changed bool)

Types

type DownloadStream added in v1.2.3

type DownloadStream interface {
	Send(result *ypb.ExecResult) error
	grpc.ServerStream
}

type FilterManager added in v1.3.1

type FilterManager struct {
	// contains filtered or unexported fields
}

func NewFilterManager added in v1.3.1

func NewFilterManager(filterEntries, filterTotal uint, capacity int) *FilterManager

func (*FilterManager) DequeueFilter added in v1.3.1

func (m *FilterManager) DequeueFilter() *filter.StringFilter

func (*FilterManager) EnqueueFilter added in v1.3.1

func (m *FilterManager) EnqueueFilter(f *filter.StringFilter)

type HTTPFlowShare added in v1.3.3

type HTTPFlowShare struct {
	*schema.HTTPFlow
	ExtractedList         []*schema.ExtractedData
	WebsocketFlowsList    []*schema.WebsocketFlow
	ProjectGeneralStorage []*schema.ProjectGeneralStorage
}

type HTTPRequestBuilderRes added in v1.3.2

type HTTPRequestBuilderRes struct {
	IsHttps bool
	Request []byte
	Url     string
}

type HybridScanRequestStream added in v1.2.9

type HybridScanRequestStream interface {
	Send(response *ypb.HybridScanResponse) error
	Recv() (*ypb.HybridScanRequest, error)
	Context() context.Context
}

type HybridScanStatusManager added in v1.2.9

type HybridScanStatusManager struct {
	// 任务的总量
	TargetTotal    int64
	PluginTotal    int64
	TotalTaskCount int64

	// 完成的任务
	TargetFinished int64
	TaskFinished   int64

	// dynamic
	ActiveTask    int64
	ActiveTarget  int64
	ActiveTaskMap *sync.Map

	TaskId string

	// Task 计数器,作为索引
	TaskCount int64

	// 任务状态
	Status string

	ManagerMutex *sync.Mutex
	// contains filtered or unexported fields
}

func (*HybridScanStatusManager) DoActiveTarget added in v1.2.9

func (h *HybridScanStatusManager) DoActiveTarget() int64

func (*HybridScanStatusManager) DoActiveTask added in v1.2.9

func (h *HybridScanStatusManager) DoActiveTask(task ...*schema.HybridScanTask) int64

DoActiveTask returns index of task

func (*HybridScanStatusManager) DoneTarget added in v1.2.9

func (h *HybridScanStatusManager) DoneTarget()

func (*HybridScanStatusManager) DoneTask added in v1.2.9

func (h *HybridScanStatusManager) DoneTask(index int64, task ...*schema.HybridScanTask)

func (*HybridScanStatusManager) Feedback added in v1.2.9

func (*HybridScanStatusManager) GetCurrentActiveTaskIndexes added in v1.2.9

func (h *HybridScanStatusManager) GetCurrentActiveTaskIndexes() []string

func (*HybridScanStatusManager) GetStatus added in v1.2.9

func (*HybridScanStatusManager) PushActiveTask added in v1.2.9

func (h *HybridScanStatusManager) PushActiveTask(index int64, t *HybridScanTarget, pluginName string, stream HybridScanRequestStream)

func (*HybridScanStatusManager) RemoveActiveTask added in v1.2.9

func (h *HybridScanStatusManager) RemoveActiveTask(index int64, t *HybridScanTarget, pluginName string, stream HybridScanRequestStream)

func (*HybridScanStatusManager) SetCurrentTaskIndex added in v1.2.9

func (h *HybridScanStatusManager) SetCurrentTaskIndex(i int64)

type HybridScanTarget added in v1.2.9

type HybridScanTarget struct {
	IsHttps  bool
	Request  []byte
	Response []byte
	Url      string
}

type HybridScanTaskManager added in v1.2.9

type HybridScanTaskManager struct {
	// contains filtered or unexported fields
}

func CreateHybridTask added in v1.2.9

func CreateHybridTask(id string, ctx context.Context) (*HybridScanTaskManager, error)

func GetHybridTask added in v1.2.9

func GetHybridTask(id string) (*HybridScanTaskManager, error)

func (*HybridScanTaskManager) Checkpoint added in v1.2.9

func (h *HybridScanTaskManager) Checkpoint(hs ...func())

func (*HybridScanTaskManager) Context added in v1.2.9

func (h *HybridScanTaskManager) Context() context.Context

func (*HybridScanTaskManager) IsPaused added in v1.2.9

func (h *HybridScanTaskManager) IsPaused() bool

func (*HybridScanTaskManager) IsStop added in v1.3.2

func (h *HybridScanTaskManager) IsStop() bool

func (*HybridScanTaskManager) Pause added in v1.2.9

func (h *HybridScanTaskManager) Pause()

func (*HybridScanTaskManager) PauseEffect added in v1.2.9

func (h *HybridScanTaskManager) PauseEffect()

func (*HybridScanTaskManager) Resume added in v1.2.9

func (h *HybridScanTaskManager) Resume()

func (*HybridScanTaskManager) Stop added in v1.2.9

func (h *HybridScanTaskManager) Stop()

func (*HybridScanTaskManager) TaskId added in v1.2.9

func (h *HybridScanTaskManager) TaskId() string

func (*HybridScanTaskManager) WaitCount added in v1.2.9

func (h *HybridScanTaskManager) WaitCount() int64

type JavaBytesCodeType

type JavaBytesCodeType string

type JavaClassGeneraterOption

type JavaClassGeneraterOption string
const (
	JavaClassGeneraterOption_ClassName     JavaClassGeneraterOption = "className"
	JavaClassGeneraterOption_IsObfuscation JavaClassGeneraterOption = "isObfuscation"
	JavaClassGeneraterOption_Version       JavaClassGeneraterOption = "version"
	JavaClassGeneraterOption_DirtyData     JavaClassGeneraterOption = "dirtyData"
	JavaClassGeneraterOption_twoByteChar   JavaClassGeneraterOption = "two byte char"
)

type JavaClassGeneraterOptionTypeVerbose

type JavaClassGeneraterOptionTypeVerbose string
const (
	String      JavaClassGeneraterOptionTypeVerbose = "String"
	Base64Bytes JavaClassGeneraterOptionTypeVerbose = "Base64Bytes"
	StringBool  JavaClassGeneraterOptionTypeVerbose = "StringBool"
	StringPort  JavaClassGeneraterOptionTypeVerbose = "StringPort"
)

type LanguageServerAnalyzerResult added in v1.3.3

type LanguageServerAnalyzerResult struct {
	Program      *ssaapi.Program
	Word         string
	ContainPoint bool
	Range        *ssa.Range
	Value        *ssaapi.Value
	Editor       *memedit.MemEditor
}

func LanguageServerAnalyzeProgram added in v1.3.3

func LanguageServerAnalyzeProgram(code string, inspectType, scriptType string, rng *ypb.Range) (*LanguageServerAnalyzerResult, error)

type MITMFilterManager

type MITMFilterManager struct {
	IncludeHostnames []string `json:"includeHostnames"`
	ExcludeHostnames []string `json:"excludeHostnames"`
	IncludeSuffix    []string `json:"includeSuffix"`
	ExcludeSuffix    []string `json:"excludeSuffix"`
	ExcludeMethods   []string `json:"excludeMethods"`
	ExcludeMIME      []string `json:"excludeMIME"`
	ExcludeUri       []string `json:"excludeUri"`
	IncludeUri       []string `json:"includeUri"`
	// contains filtered or unexported fields
}

func NewMITMFilterManager

func NewMITMFilterManager(db *gorm.DB) *MITMFilterManager

func (*MITMFilterManager) IsEmpty

func (m *MITMFilterManager) IsEmpty() bool

func (*MITMFilterManager) IsMIMEPassed added in v1.2.8

func (m *MITMFilterManager) IsMIMEPassed(ct string) bool

func (*MITMFilterManager) IsPassed added in v1.2.8

func (m *MITMFilterManager) IsPassed(method string, hostport, urlStr string, ext string, isHttps bool) bool

IsPassed return true if passed, false if filtered out

func (*MITMFilterManager) Recover

func (m *MITMFilterManager) Recover()

func (*MITMFilterManager) Save

func (m *MITMFilterManager) Save()

type MITMReplaceRule added in v1.3.1

type MITMReplaceRule struct {
	*ypb.MITMContentReplacer
	// contains filtered or unexported fields
}

func (*MITMReplaceRule) MatchAndReplacePacket added in v1.3.1

func (m *MITMReplaceRule) MatchAndReplacePacket(packet []byte, isReq bool) ([]*yakit.MatchResult, []byte, error)

MatchAndReplacePacket match and replace package, return matched result and replaced package

func (*MITMReplaceRule) MatchPacket added in v1.3.1

func (m *MITMReplaceRule) MatchPacket(packet []byte, isReq bool) (*yakit.PacketInfo, []*yakit.MatchResult, error)

type OpenPortServerStreamerHelperRWC

type OpenPortServerStreamerHelperRWC struct {
	io.ReadWriteCloser

	LocalAddr  string
	RemoveAddr string
	// contains filtered or unexported fields
}

OpenPortServerStreamerHelperRWC

func (*OpenPortServerStreamerHelperRWC) Close

func (s *OpenPortServerStreamerHelperRWC) Close() (err error)

func (*OpenPortServerStreamerHelperRWC) Read

func (c *OpenPortServerStreamerHelperRWC) Read(b []byte) (n int, _ error)

func (*OpenPortServerStreamerHelperRWC) Write

func (s *OpenPortServerStreamerHelperRWC) Write(b []byte) (int, error)

type PluginParamSelect added in v1.3.0

type PluginParamSelect struct {
	Double bool                    `json:"double"`
	Data   []PluginParamSelectData `json:"data"`
}

type PluginParamSelectData added in v1.3.0

type PluginParamSelectData struct {
	Label string `json:"label"`
	Value string `json:"value"`
}

type Rules added in v1.3.1

type Rules []*MITMReplaceRule

func NewRuleGroup added in v1.3.1

func NewRuleGroup(r ...*ypb.MITMContentReplacer) Rules

func (Rules) Len added in v1.3.1

func (a Rules) Len() int

func (Rules) Less added in v1.3.1

func (a Rules) Less(i, j int) bool

func (Rules) MITMContentReplacers added in v1.3.1

func (a Rules) MITMContentReplacers() []*ypb.MITMContentReplacer

func (Rules) Swap added in v1.3.1

func (a Rules) Swap(i, j int)

type Server

type Server struct {
	ypb.YakServer
	// contains filtered or unexported fields
}

func NewServer

func NewServer(opts ...ServerOpts) (*Server, error)

func NewServerWithLogCache added in v1.2.2

func NewServerWithLogCache(opts ...ServerOpts) (*Server, error)

func NewTestServer added in v1.3.3

func NewTestServer() (*Server, error)

func (*Server) AddMenus

func (s *Server) AddMenus(ctx context.Context, req *ypb.AddMenuRequest) (*ypb.Empty, error)

func (*Server) AddOneNavigation added in v1.2.3

func (s *Server) AddOneNavigation(ctx context.Context, req *ypb.AddOneNavigationRequest) (*ypb.Empty, error)

func (*Server) AddToMenu

func (s *Server) AddToMenu(ctx context.Context, req *ypb.AddToMenuRequest) (*ypb.Empty, error)

func (*Server) AddToNavigation added in v1.2.3

func (s *Server) AddToNavigation(ctx context.Context, req *ypb.AddToNavigationRequest) (*ypb.Empty, error)

func (*Server) ApplyClassToFacades

func (s *Server) ApplyClassToFacades(ctx context.Context, req *ypb.ApplyClassToFacadesParamsWithVerbose) (*ypb.Empty, error)

func (*Server) AttachCombinedOutput

func (s *Server) AttachCombinedOutput(req *ypb.AttachCombinedOutputRequest, server ypb.Yak_AttachCombinedOutputServer) error

func (*Server) AutoDecode

func (s *Server) AutoDecode(ctx context.Context, req *ypb.AutoDecodeRequest) (*ypb.AutoDecodeResponse, error)

func (*Server) AutoUpdateYakModule

func (s *Server) AutoUpdateYakModule(_ *ypb.Empty, stream ypb.Yak_AutoUpdateYakModuleServer) error

func (*Server) AvailableLocalAddr

func (s *Server) AvailableLocalAddr(ctx context.Context, empty *ypb.Empty) (*ypb.AvailableLocalAddrResponse, error)

func (*Server) BackUpOrCopyPayloads added in v1.2.9

func (s *Server) BackUpOrCopyPayloads(ctx context.Context, req *ypb.BackUpOrCopyPayloadsRequest) (*ypb.Empty, error)

func (*Server) BytesToBase64

func (s *Server) BytesToBase64(ctx context.Context, req *ypb.BytesToBase64Request) (*ypb.BytesToBase64Response, error)

func (*Server) CheckLicense

func (s *Server) CheckLicense(ctx context.Context, r *ypb.CheckLicenseRequest) (_ *ypb.Empty, unexpectedError error)

func (*Server) Codec

func (s *Server) Codec(ctx context.Context, req *ypb.CodecRequest) (*ypb.CodecResponse, error)

func (*Server) ConfigGlobalReverse

func (s *Server) ConfigGlobalReverse(req *ypb.ConfigGlobalReverseParams, stream ypb.Yak_ConfigGlobalReverseServer) error

func (*Server) ConnectVulinboxAgent added in v1.2.3

func (*Server) ConvertFuzzerResponseToHTTPFlow

func (s *Server) ConvertFuzzerResponseToHTTPFlow(ctx context.Context, in *ypb.FuzzerResponse) (*ypb.HTTPFlow, error)

func (*Server) ConvertPayloadGroupToDatabase added in v1.3.0

func (s *Server) ConvertPayloadGroupToDatabase(req *ypb.NameRequest, stream ypb.Yak_ConvertPayloadGroupToDatabaseServer) error

func (*Server) CreatePayloadFolder added in v1.2.9

func (s *Server) CreatePayloadFolder(ctx context.Context, req *ypb.NameRequest) (*ypb.Empty, error)

func (*Server) CreateWebShell added in v1.3.0

func (s *Server) CreateWebShell(ctx context.Context, req *ypb.WebShell) (*ypb.WebShell, error)

func (*Server) CreateWebsocketFuzzer

func (s *Server) CreateWebsocketFuzzer(stream ypb.Yak_CreateWebsocketFuzzerServer) error

func (*Server) CreateYaklangShell

func (s *Server) CreateYaklangShell(server ypb.Yak_CreateYaklangShellServer) error

func (*Server) DebugPlugin added in v1.2.2

func (s *Server) DebugPlugin(req *ypb.DebugPluginRequest, stream ypb.Yak_DebugPluginServer) error

func (*Server) DelKey

func (s *Server) DelKey(ctx context.Context, req *ypb.GetKeyRequest) (*ypb.Empty, error)

func (*Server) DeleteAllLocalPlugins

func (s *Server) DeleteAllLocalPlugins(ctx context.Context, req *ypb.Empty) (*ypb.Empty, error)

func (*Server) DeleteAllMenu

func (s *Server) DeleteAllMenu(ctx context.Context, req *ypb.QueryAllMenuItemRequest) (*ypb.Empty, error)

func (*Server) DeleteAllMenuItem

func (s *Server) DeleteAllMenuItem(ctx context.Context, req *ypb.Empty) (*ypb.Empty, error)

func (*Server) DeleteAllNavigation added in v1.2.3

func (s *Server) DeleteAllNavigation(ctx context.Context, req *ypb.GetAllNavigationRequest) (*ypb.Empty, error)

func (*Server) DeleteChaosMakerRuleByID

func (s *Server) DeleteChaosMakerRuleByID(ctx context.Context, req *ypb.DeleteChaosMakerRuleByIDRequest) (*ypb.Empty, error)

func (*Server) DeleteCodecFlow added in v1.3.3

func (s *Server) DeleteCodecFlow(ctx context.Context, req *ypb.DeleteCodecFlowRequest) (*ypb.Empty, error)

func (*Server) DeleteDomains

func (s *Server) DeleteDomains(ctx context.Context, req *ypb.DeleteDomainsRequest) (*ypb.Empty, error)

func (*Server) DeleteFuzzerLabel added in v1.2.3

func (s *Server) DeleteFuzzerLabel(ctx context.Context, req *ypb.DeleteFuzzerLabelRequest) (*ypb.Empty, error)

func (*Server) DeleteHTTPFlows

func (s *Server) DeleteHTTPFlows(ctx context.Context, r *ypb.DeleteHTTPFlowRequest) (*ypb.Empty, error)

func (*Server) DeleteHistoryHTTPFuzzerTask

func (s *Server) DeleteHistoryHTTPFuzzerTask(ctx context.Context, d *ypb.DeleteHistoryHTTPFuzzerTaskRequest) (*ypb.Empty, error)

func (*Server) DeleteHosts

func (s *Server) DeleteHosts(ctx context.Context, req *ypb.DeleteHostsRequest) (*ypb.Empty, error)

func (*Server) DeleteHybridScanTask added in v1.2.9

func (s *Server) DeleteHybridScanTask(ctx context.Context, request *ypb.DeleteHybridScanTaskRequest) (*ypb.Empty, error)

func (*Server) DeleteLocalPluginsByWhere

func (s *Server) DeleteLocalPluginsByWhere(ctx context.Context, req *ypb.DeleteLocalPluginsByWhereRequest) (*ypb.Empty, error)

func (*Server) DeleteMarkdownDocument

func (s *Server) DeleteMarkdownDocument(ctx context.Context, req *ypb.GetMarkdownDocumentRequest) (*ypb.Empty, error)

func (*Server) DeletePayload

func (s *Server) DeletePayload(ctx context.Context, req *ypb.DeletePayloadRequest) (*ypb.Empty, error)

func (*Server) DeletePayloadByFolder added in v1.2.9

func (s *Server) DeletePayloadByFolder(ctx context.Context, req *ypb.NameRequest) (*ypb.Empty, error)

func (*Server) DeletePayloadByGroup

func (s *Server) DeletePayloadByGroup(ctx context.Context, req *ypb.DeletePayloadByGroupRequest) (*ypb.Empty, error)

func (*Server) DeletePluginByUserID

func (s *Server) DeletePluginByUserID(ctx context.Context, req *ypb.DeletePluginByUserIDRequest) (*ypb.Empty, error)

func (*Server) DeletePorts

func (s *Server) DeletePorts(ctx context.Context, req *ypb.DeletePortsRequest) (*ypb.Empty, error)

func (*Server) DeleteProject

func (s *Server) DeleteProject(ctx context.Context, req *ypb.DeleteProjectRequest) (*ypb.Empty, error)

func (*Server) DeleteReport

func (s *Server) DeleteReport(ctx context.Context, d *ypb.DeleteReportRequest) (*ypb.Empty, error)

func (*Server) DeleteRisk

func (s *Server) DeleteRisk(ctx context.Context, req *ypb.DeleteRiskRequest) (*ypb.Empty, error)

func (*Server) DeleteScreenRecorders added in v1.2.2

func (s *Server) DeleteScreenRecorders(ctx context.Context, req *ypb.QueryScreenRecorderRequest) (*ypb.Empty, error)

func (*Server) DeleteSimpleDetectUnfinishedTask added in v1.3.3

func (s *Server) DeleteSimpleDetectUnfinishedTask(ctx context.Context, req *ypb.DeleteUnfinishedTaskRequest) (*ypb.Empty, error)

func (*Server) DeleteWebShell added in v1.3.0

func (s *Server) DeleteWebShell(ctx context.Context, req *ypb.DeleteWebShellRequest) (*ypb.Empty, error)

func (*Server) DeleteYakScript

func (s *Server) DeleteYakScript(ctx context.Context, req *ypb.DeleteYakScriptRequest) (*ypb.Empty, error)

func (*Server) DeleteYakScriptExec

func (s *Server) DeleteYakScriptExec(ctx context.Context, req *ypb.Empty) (*ypb.Empty, error)

func (*Server) DeleteYakScriptExecResult

func (s *Server) DeleteYakScriptExecResult(ctx context.Context, req *ypb.DeleteYakScriptExecResultRequest) (*ypb.Empty, error)

func (*Server) DeleteYakScriptGroup added in v1.3.1

func (s *Server) DeleteYakScriptGroup(ctx context.Context, req *ypb.DeleteYakScriptGroupRequest) (*ypb.Empty, error)

func (*Server) DiagnoseNetwork added in v1.2.4

func (s *Server) DiagnoseNetwork(req *ypb.DiagnoseNetworkRequest, server ypb.Yak_DiagnoseNetworkServer) error

func (*Server) DiagnoseNetworkDNS added in v1.2.4

func (s *Server) DiagnoseNetworkDNS(req *ypb.DiagnoseNetworkDNSRequest, server ypb.Yak_DiagnoseNetworkDNSServer) error

func (*Server) DisconnectVulinboxAgent added in v1.2.3

func (s *Server) DisconnectVulinboxAgent(ctx context.Context, req *ypb.DisconnectVulinboxAgentRequest) (*ypb.Empty, error)

func (*Server) DownloadMITMCert

func (s *Server) DownloadMITMCert(ctx context.Context, _ *ypb.Empty) (*ypb.MITMCert, error)

func (*Server) DownloadOnlinePluginBatch added in v1.2.9

func (s *Server) DownloadOnlinePluginBatch(ctx context.Context, req *ypb.DownloadOnlinePluginsRequest) (*ypb.Empty, error)

func (*Server) DownloadOnlinePluginById

func (s *Server) DownloadOnlinePluginById(ctx context.Context, req *ypb.DownloadOnlinePluginByIdRequest) (*ypb.Empty, error)

func (*Server) DownloadOnlinePluginByIds

func (s *Server) DownloadOnlinePluginByIds(ctx context.Context, req *ypb.DownloadOnlinePluginByIdsRequest) (*ypb.Empty, error)

func (*Server) DownloadOnlinePluginByPluginName added in v1.2.9

func (*Server) DownloadOnlinePlugins added in v1.2.9

func (s *Server) DownloadOnlinePlugins(req *ypb.DownloadOnlinePluginsRequest, stream ypb.Yak_DownloadOnlinePluginsServer) error

func (*Server) DownloadReport

func (s *Server) DownloadReport(ctx context.Context, req *ypb.DownloadReportRequest) (*ypb.Empty, error)

func (*Server) DownloadWithStream added in v1.2.3

func (s *Server) DownloadWithStream(proxy string, fileGetter func() (urlStr string, name string, err error), stream DownloadStream) error

func (*Server) DuplexConnection added in v1.2.8

func (s *Server) DuplexConnection(stream ypb.Yak_DuplexConnectionServer) error

func (*Server) Echo

func (s *Server) Echo(ctx context.Context, req *ypb.EchoRequest) (*ypb.EchoResposne, error)

func (*Server) EvaluateExpression added in v1.3.3

func (*Server) EvaluatePlugin added in v1.2.9

func (s *Server) EvaluatePlugin(ctx context.Context, pluginCode, pluginType string, host string, port int) (*ypb.SmokingEvaluatePluginResponse, error)

只在评分中使用

func (*Server) Exec

func (s *Server) Exec(req *ypb.ExecRequest, stream ypb.Yak_ExecServer) error

func (*Server) ExecBatchYakScript

func (s *Server) ExecBatchYakScript(req *ypb.ExecBatchYakScriptRequest, stream ypb.Yak_ExecBatchYakScriptServer) error

func (*Server) ExecPacketScan

func (s *Server) ExecPacketScan(req *ypb.ExecPacketScanRequest, stream ypb.Yak_ExecPacketScanServer) error

func (*Server) ExecWithContext

func (s *Server) ExecWithContext(ctx context.Context, req *ypb.ExecRequest, stream ypb.Yak_ExecServer) error

func (*Server) ExecYakScript

func (s *Server) ExecYakScript(req *ypb.ExecRequest, stream ypb.Yak_ExecYakScriptServer) error

func (*Server) ExecuteChaosMakerRule

func (s *Server) ExecuteChaosMakerRule(req *ypb.ExecuteChaosMakerRuleRequest, stream ypb.Yak_ExecuteChaosMakerRuleServer) error

func (*Server) ExecutePacketYakScript

func (s *Server) ExecutePacketYakScript(req *ypb.ExecutePacketYakScriptParams, stream ypb.Yak_ExecutePacketYakScriptServer) error

func (*Server) ExportAllPayload added in v1.3.0

func (s *Server) ExportAllPayload(req *ypb.GetAllPayloadRequest, stream ypb.Yak_ExportAllPayloadServer) error

导出payload到文件

func (*Server) ExportAllPayloadFromFile added in v1.3.0

func (s *Server) ExportAllPayloadFromFile(req *ypb.GetAllPayloadRequest, stream ypb.Yak_ExportAllPayloadFromFileServer) error

导出payload,从数据库中的文件导出到另外一个文件

func (*Server) ExportHTTPFlows added in v1.3.0

func (s *Server) ExportHTTPFlows(ctx context.Context, req *ypb.ExportHTTPFlowsRequest) (*ypb.QueryHTTPFlowResponse, error)

func (*Server) ExportHTTPFuzzerTaskToYaml added in v1.2.7

ExportHTTPFuzzerTaskToYaml fuzzerRequest -> yakTemplate -> yaml

func (*Server) ExportLocalYakScript added in v1.3.0

func (*Server) ExportLocalYakScriptStream added in v1.3.1

func (s *Server) ExportLocalYakScriptStream(req *ypb.ExportLocalYakScriptRequest, stream ypb.Yak_ExportLocalYakScriptStreamServer) error

func (*Server) ExportMITMReplacerRules

func (s *Server) ExportMITMReplacerRules(ctx context.Context, _ *ypb.Empty) (*ypb.ExportMITMReplacerRulesResponse, error)

func (*Server) ExportMenuItem

func (s *Server) ExportMenuItem(ctx context.Context, req *ypb.Empty) (*ypb.ExportMenuItemResult, error)

func (*Server) ExportProject

func (s *Server) ExportProject(req *ypb.ExportProjectRequest, stream ypb.Yak_ExportProjectServer) error

func (*Server) ExportYakPluginBatch

func (s *Server) ExportYakPluginBatch(script *schema.YakScript, dir, OutputPluginDir string) (string, error)

func (*Server) ExportYakScript

func (*Server) ExtractData

func (s *Server) ExtractData(server ypb.Yak_ExtractDataServer) error

func (*Server) ExtractDataToFile

func (s *Server) ExtractDataToFile(input ypb.Yak_ExtractDataToFileServer) error

func (*Server) ExtractHTTPResponse

func (s *Server) ExtractHTTPResponse(ctx context.Context, req *ypb.ExtractHTTPResponseParams) (*ypb.ExtractHTTPResponseResult, error)

func (*Server) ExtractUrl

func (s *Server) ExtractUrl(ctx context.Context, req *ypb.FuzzerRequest) (*ypb.ExtractedUrl, error)

func (*Server) FetchPortAssetFromSpaceEngine added in v1.2.9

func (*Server) FixUploadPacket

func (*Server) ForceUpdateAvailableYakScriptTags

func (s *Server) ForceUpdateAvailableYakScriptTags(ctx context.Context, req *ypb.Empty) (*ypb.Empty, error)

func (*Server) GenQualityInspectionReport added in v1.2.4

func (s *Server) GenQualityInspectionReport(req *ypb.GenQualityInspectionReportRequest, stream ypb.Yak_GenQualityInspectionReportServer) error

func (*Server) GenerateExtractRule

func (s *Server) GenerateExtractRule(
	ctx context.Context,
	req *ypb.GenerateExtractRuleRequest,
) (*ypb.GenerateExtractRuleResponse, error)

func (*Server) GenerateURL added in v1.2.9

func (s *Server) GenerateURL(ctx context.Context, req *ypb.GenerateURLRequest) (*ypb.GenerateURLResponse, error)

func (*Server) GenerateWebShell added in v1.3.3

func (s *Server) GenerateWebShell(context.Context, *ypb.ShellGenerate) (*ypb.WebShellResponse, error)

func (*Server) GenerateWebsiteTree

func (s *Server) GenerateWebsiteTree(ctx context.Context, req *ypb.GenerateWebsiteTreeRequest) (
	*ypb.GenerateWebsiteTreeResponse, error,
)

func (*Server) GenerateYsoBytes

func (s *Server) GenerateYsoBytes(ctx context.Context, req *ypb.YsoOptionsRequerstWithVerbose) (*ypb.YsoBytesResponse, error)

func (*Server) GenerateYsoCode

func (s *Server) GenerateYsoCode(ctx context.Context, req *ypb.YsoOptionsRequerstWithVerbose) (*ypb.YsoCodeResponse, error)

func (*Server) GetAllCodecFlow added in v1.3.3

func (s *Server) GetAllCodecFlow(ctx context.Context, req *ypb.Empty) (*ypb.GetCodecFlowResponse, error)

func (*Server) GetAllCodecMethods added in v1.3.1

func (s *Server) GetAllCodecMethods(ctx context.Context, in *ypb.Empty) (*ypb.CodecMethods, error)

func (*Server) GetAllMenuItem

func (s *Server) GetAllMenuItem(ctx context.Context, req *ypb.Empty) (*ypb.MenuByGroup, error)

func (*Server) GetAllNavigationItem added in v1.2.3

func (s *Server) GetAllNavigationItem(ctx context.Context, req *ypb.GetAllNavigationRequest) (*ypb.GetAllNavigationItemResponse, error)

func (*Server) GetAllPayload

func (s *Server) GetAllPayload(ctx context.Context, req *ypb.GetAllPayloadRequest) (*ypb.GetAllPayloadResponse, error)

! 已弃用 导出payload到文件

func (*Server) GetAllPayloadGroup

func (s *Server) GetAllPayloadGroup(ctx context.Context, _ *ypb.Empty) (*ypb.GetAllPayloadGroupResponse, error)

func (*Server) GetAllProcessEnvKey

func (s *Server) GetAllProcessEnvKey(ctx context.Context, req *ypb.Empty) (*ypb.GetProcessEnvKeyResult, error)

func (*Server) GetAllYsoClassOptions

func (s *Server) GetAllYsoClassOptions(ctx context.Context, req *ypb.YsoOptionsRequerstWithVerbose) (*ypb.YsoOptionsWithVerbose, error)

func (*Server) GetAllYsoGadgetOptions

func (s *Server) GetAllYsoGadgetOptions(ctx context.Context, _ *ypb.Empty) (*ypb.YsoOptionsWithVerbose, error)

func (*Server) GetAvailableBruteTypes

func (s *Server) GetAvailableBruteTypes(ctx context.Context, req *ypb.Empty) (*ypb.GetAvailableBruteTypesResponse, error)

func (*Server) GetAvailableYakScriptTags

func (s *Server) GetAvailableYakScriptTags(ctx context.Context, req *ypb.Empty) (*ypb.Fields, error)

func (*Server) GetBasicInfo added in v1.3.0

func (s *Server) GetBasicInfo(ctx context.Context, req *ypb.WebShellRequest) (*ypb.WebShellResponse, error)

func (*Server) GetCVE

func (s *Server) GetCVE(ctx context.Context, req *ypb.GetCVERequest) (*ypb.CVEDetailEx, error)

func (*Server) GetCurrentProject

func (s *Server) GetCurrentProject(ctx context.Context, _ *ypb.Empty) (*ypb.ProjectDescription, error)

func (*Server) GetCurrentRules

func (s *Server) GetCurrentRules(c context.Context, req *ypb.Empty) (*ypb.MITMContentReplacers, error)

func (*Server) GetCurrentYakBridgeLogServer

func (s *Server) GetCurrentYakBridgeLogServer(ctx context.Context, l *ypb.Empty) (*ypb.YakDNSLogBridgeAddr, error)

func (*Server) GetDefaultProject

func (s *Server) GetDefaultProject(ctx context.Context, req *ypb.Empty) (*ypb.ProjectDescription, error)

func (*Server) GetEngineDefaultProxy

func (s *Server) GetEngineDefaultProxy(ctx context.Context, e *ypb.Empty) (*ypb.DefaultProxyResult, error)

func (*Server) GetExecBatchYakScriptUnfinishedTask

func (s *Server) GetExecBatchYakScriptUnfinishedTask(ctx context.Context, req *ypb.Empty) (*ypb.GetExecBatchYakScriptUnfinishedTaskResponse, error)

func (*Server) GetGlobalNetworkConfig added in v1.2.4

func (s *Server) GetGlobalNetworkConfig(ctx context.Context, req *ypb.GetGlobalNetworkConfigRequest) (*ypb.GlobalNetworkConfig, error)

func (*Server) GetGlobalReverseServer

func (s *Server) GetGlobalReverseServer(ctx context.Context, req *ypb.Empty) (*ypb.GetGlobalReverseServerResponse, error)

func (*Server) GetHTTPFlowBare added in v1.2.6

func (s *Server) GetHTTPFlowBare(ctx context.Context, req *ypb.HTTPFlowBareRequest) (*ypb.HTTPFlowBareResponse, error)

func (*Server) GetHTTPFlowByHash

func (s *Server) GetHTTPFlowByHash(_ context.Context, r *ypb.GetHTTPFlowByHashRequest) (*ypb.HTTPFlow, error)

func (*Server) GetHTTPFlowById

func (s *Server) GetHTTPFlowById(_ context.Context, r *ypb.GetHTTPFlowByIdRequest) (*ypb.HTTPFlow, error)

func (*Server) GetHTTPFlowByIds added in v1.2.5

func (s *Server) GetHTTPFlowByIds(_ context.Context, r *ypb.GetHTTPFlowByIdsRequest) (*ypb.HTTPFlows, error)

func (*Server) GetHTTPPacketBody

func (s *Server) GetHTTPPacketBody(ctx context.Context, req *ypb.GetHTTPPacketBodyRequest) (*ypb.Bytes, error)

func (*Server) GetKey

func (s *Server) GetKey(ctx context.Context, req *ypb.GetKeyRequest) (*ypb.GetKeyResult, error)

func (*Server) GetLicense

func (s *Server) GetLicense(ctx context.Context, _ *ypb.Empty) (_ *ypb.GetLicenseResponse, unexpectedError error)

func (*Server) GetMITMFilter

func (s *Server) GetMITMFilter(ctx context.Context, req *ypb.Empty) (*ypb.SetMITMFilterRequest, error)

func (*Server) GetMachineID

func (s *Server) GetMachineID(ctx context.Context, _ *ypb.Empty) (*ypb.GetMachineIDResponse, error)

func (*Server) GetMarkdownDocument

func (*Server) GetMenuItemById

func (s *Server) GetMenuItemById(ctx context.Context, req *ypb.GetMenuItemByIdRequest) (*ypb.MenuItem, error)

func (*Server) GetOneScreenRecorders added in v1.2.2

func (s *Server) GetOneScreenRecorders(ctx context.Context, req *ypb.GetOneScreenRecorderRequest) (*ypb.ScreenRecorder, error)

func (*Server) GetOnlineProfile

func (s *Server) GetOnlineProfile(ctx context.Context, req *ypb.Empty) (*ypb.OnlineProfile, error)

func (*Server) GetPcapMetadata added in v1.2.8

func (s *Server) GetPcapMetadata(ctx context.Context, req *ypb.PcapMetadataRequest) (*ypb.PcapMetadata, error)

func (*Server) GetProfileDatabase

func (*Server) GetProfileDatabase() *gorm.DB

func (*Server) GetProjectDatabase

func (*Server) GetProjectDatabase() *gorm.DB

func (*Server) GetProjectKey added in v1.2.2

func (s *Server) GetProjectKey(ctx context.Context, req *ypb.GetKeyRequest) (*ypb.GetKeyResult, error)

func (*Server) GetProjects

func (s *Server) GetProjects(ctx context.Context, req *ypb.GetProjectsRequest) (*ypb.GetProjectsResponse, error)

func (*Server) GetRegisteredVulinboxAgent added in v1.2.3

func (s *Server) GetRegisteredVulinboxAgent(ctx context.Context, req *ypb.GetRegisteredAgentRequest) (*ypb.GetRegisteredAgentResponse, error)

func (*Server) GetRequestBodyByHTTPFlowID

func (s *Server) GetRequestBodyByHTTPFlowID(ctx context.Context, req *ypb.DownloadBodyByHTTPFlowIDRequest) (*ypb.Bytes, error)

func (*Server) GetResponseBodyByHTTPFlowID

func (s *Server) GetResponseBodyByHTTPFlowID(ctx context.Context, req *ypb.DownloadBodyByHTTPFlowIDRequest) (*ypb.Bytes, error)

func (*Server) GetSimpleDetectRecordRequestById added in v1.3.3

func (s *Server) GetSimpleDetectRecordRequestById(ctx context.Context, req *ypb.GetUnfinishedTaskDetailByIdRequest) (*ypb.RecordPortScanRequest, error)

func (*Server) GetSimpleDetectUnfinishedTask

func (s *Server) GetSimpleDetectUnfinishedTask(ctx context.Context, req *ypb.Empty) (*ypb.GetSimpleDetectUnfinishedTaskResponse, error)

func (*Server) GetSpaceEngineAccountStatus added in v1.3.1

func (s *Server) GetSpaceEngineAccountStatus(ctx context.Context, req *ypb.GetSpaceEngineAccountStatusRequest) (*ypb.SpaceEngineStatus, error)

func (*Server) GetSpaceEngineStatus added in v1.2.9

func (s *Server) GetSpaceEngineStatus(ctx context.Context, req *ypb.GetSpaceEngineStatusRequest) (*ypb.SpaceEngineStatus, error)

func (*Server) GetSystemDefaultDnsServers added in v1.2.3

func (s *Server) GetSystemDefaultDnsServers(ctx context.Context, req *ypb.Empty) (*ypb.DefaultDnsServerResponse, error)

func (*Server) GetSystemProxy

func (s *Server) GetSystemProxy(ctx context.Context, req *ypb.Empty) (*ypb.GetSystemProxyResult, error)

func (*Server) GetTemporaryProject added in v1.3.0

func (s *Server) GetTemporaryProject(ctx context.Context, req *ypb.Empty) (*ypb.ProjectDescription, error)

func (*Server) GetYakScriptById

func (s *Server) GetYakScriptById(ctx context.Context, req *ypb.GetYakScriptByIdRequest) (*ypb.YakScript, error)

func (*Server) GetYakScriptByName

func (s *Server) GetYakScriptByName(ctx context.Context, req *ypb.GetYakScriptByNameRequest) (*ypb.YakScript, error)

func (*Server) GetYakScriptByOnlineID

func (s *Server) GetYakScriptByOnlineID(ctx context.Context, req *ypb.GetYakScriptByOnlineIDRequest) (*ypb.YakScript, error)

func (*Server) GetYakScriptGroup added in v1.3.1

func (s *Server) GetYakScriptGroup(ctx context.Context, req *ypb.QueryYakScriptRequest) (*ypb.GetYakScriptGroupResponse, error)

func (*Server) GetYakScriptTags

func (s *Server) GetYakScriptTags(c context.Context, req *ypb.Empty) (*ypb.GetYakScriptTagsResponse, error)

func (*Server) GetYakScriptTagsAndType

func (s *Server) GetYakScriptTagsAndType(ctx context.Context, req *ypb.Empty) (*ypb.GetYakScriptTagsAndTypeResponse, error)

func (*Server) GetYakitCompletionRaw

func (s *Server) GetYakitCompletionRaw(ctx context.Context, _ *ypb.Empty) (*ypb.YakitCompletionRawResponse, error)

func (*Server) HTTPFlowsData added in v1.3.3

func (*Server) HTTPFlowsExtract added in v1.2.2

func (s *Server) HTTPFlowsExtract(ctx context.Context, req *ypb.HTTPFlowsExtractRequest) (*ypb.Empty, error)

func (*Server) HTTPFlowsFieldGroup

func (*Server) HTTPFlowsShare added in v1.2.2

func (*Server) HTTPFlowsToOnline added in v1.3.3

func (s *Server) HTTPFlowsToOnline(ctx context.Context, req *ypb.HTTPFlowsToOnlineRequest) (*ypb.Empty, error)

func (*Server) HTTPFuzzer

func (s *Server) HTTPFuzzer(req *ypb.FuzzerRequest, stream ypb.Yak_HTTPFuzzerServer) (finalError error)

func (*Server) HTTPFuzzerSequence added in v1.2.4

func (s *Server) HTTPFuzzerSequence(seqreq *ypb.FuzzerRequests, stream ypb.Yak_HTTPFuzzerSequenceServer) error

func (*Server) HTTPRequestAnalyzer

func (s *Server) HTTPRequestAnalyzer(ctx context.Context, req *ypb.HTTPRequestAnalysisMaterial) (*ypb.HTTPRequestAnalysis, error)

func (*Server) HTTPRequestBuilder added in v1.2.2

func (*Server) HTTPRequestMutate

func (s *Server) HTTPRequestMutate(ctx context.Context, req *ypb.HTTPRequestMutateParams) (*ypb.MutateResult, error)

func (*Server) HTTPResponseMutate

func (s *Server) HTTPResponseMutate(ctx context.Context, req *ypb.HTTPResponseMutateParams) (*ypb.MutateResult, error)

func (*Server) HybridScan added in v1.2.9

func (s *Server) HybridScan(stream ypb.Yak_HybridScanServer) error

func (*Server) IgnoreYakScript

func (s *Server) IgnoreYakScript(ctx context.Context, req *ypb.DeleteYakScriptRequest) (*ypb.Empty, error)

func (*Server) ImportChaosMakerRules

func (s *Server) ImportChaosMakerRules(ctx context.Context, req *ypb.ImportChaosMakerRulesRequest) (*ypb.Empty, error)

func (*Server) ImportHTTPFuzzerTaskFromYaml added in v1.2.7

ImportHTTPFuzzerTaskFromYaml yaml -> yakTemplate -> fuzzerRequest

func (*Server) ImportMITMReplacerRules

func (s *Server) ImportMITMReplacerRules(ctx context.Context, req *ypb.ImportMITMReplacerRulesRequest) (*ypb.Empty, error)

func (*Server) ImportMenuItem

func (s *Server) ImportMenuItem(ctx context.Context, req *ypb.ImportMenuItemRequest) (*ypb.Empty, error)

func (*Server) ImportProject

func (s *Server) ImportProject(req *ypb.ImportProjectRequest, stream ypb.Yak_ImportProjectServer) error

func (*Server) ImportYakScript added in v1.3.0

func (s *Server) ImportYakScript(req *ypb.ImportYakScriptRequest, stream ypb.Yak_ImportYakScriptServer) error

func (*Server) InstallScrecorder

func (s *Server) InstallScrecorder(req *ypb.InstallScrecorderRequest, stream ypb.Yak_InstallScrecorderServer) error

func (*Server) InstallVulinbox added in v1.2.3

func (s *Server) InstallVulinbox(req *ypb.InstallVulinboxRequest, stream ypb.Yak_InstallVulinboxServer) error

func (*Server) IsCVEDatabaseReady

func (*Server) IsMultipartFormDataRequest

func (s *Server) IsMultipartFormDataRequest(ctx context.Context, req *ypb.FixUploadPacketRequest) (*ypb.IsMultipartFormDataRequestResult, error)

func (*Server) IsPrivilegedForNetRaw

func (s *Server) IsPrivilegedForNetRaw(ctx context.Context, req *ypb.Empty) (*ypb.IsPrivilegedForNetRawResponse, error)

func (*Server) IsProjectNameValid

func (s *Server) IsProjectNameValid(ctx context.Context, req *ypb.IsProjectNameValidRequest) (*ypb.Empty, error)

func (*Server) IsScrecorderReady

func (*Server) IsVulinboxReady added in v1.2.3

func (*Server) LoadNucleiTemplates

func (s *Server) LoadNucleiTemplates(ctx context.Context, req *ypb.Empty) (*ypb.Empty, error)

func (*Server) MITM

func (s *Server) MITM(stream ypb.Yak_MITMServer) error

func (*Server) MatchHTTPResponse

func (s *Server) MatchHTTPResponse(ctx context.Context, req *ypb.MatchHTTPResponseParams) (*ypb.MatchHTTPResponseResult, error)

func (*Server) MigrateLegacyDatabase

func (s *Server) MigrateLegacyDatabase(ctx context.Context, req *ypb.Empty) (*ypb.Empty, error)

func (*Server) MigratePayloads added in v1.3.0

func (s *Server) MigratePayloads(req *ypb.Empty, stream ypb.Yak_MigratePayloadsServer) error

func (*Server) NewCodec added in v1.2.6

func (s *Server) NewCodec(ctx context.Context, req *ypb.CodecRequestFlow) (resp *ypb.CodecResponse, err error)

func (*Server) NewProject

func (s *Server) NewProject(ctx context.Context, req *ypb.NewProjectRequest) (*ypb.NewProjectResponse, error)

func (*Server) NewRiskRead

func (s *Server) NewRiskRead(ctx context.Context, req *ypb.NewRiskReadRequest) (*ypb.Empty, error)

func (*Server) OpenPort

func (s *Server) OpenPort(inputStream ypb.Yak_OpenPortServer) error

func (*Server) PacketPrettifyHelper added in v1.2.5

func (*Server) ParseTraffic added in v1.3.0

func (s *Server) ParseTraffic(ctx context.Context, req *ypb.ParseTrafficRequest) (*ypb.ParseTrafficResponse, error)

func (*Server) PcapX added in v1.2.8

func (s *Server) PcapX(stream ypb.Yak_PcapXServer) error

func (*Server) Ping added in v1.3.0

func (*Server) PluginGenerator added in v1.2.9

func (s *Server) PluginGenerator(l *list.List, ctx context.Context, plugin *ypb.HybridScanPluginConfig) (chan *schema.YakScript, error)

func (*Server) PluginListGenerator added in v1.3.2

func (s *Server) PluginListGenerator(plugin *ypb.HybridScanPluginConfig, ctx context.Context) (res []string)

func (*Server) PortScan

func (s *Server) PortScan(req *ypb.PortScanRequest, stream ypb.Yak_PortScanServer) error

func (*Server) PreRenderVariables added in v1.2.7

func (s *Server) PreRenderVariables(ctx context.Context, params []*ypb.FuzzerParamItem, https, gmtls, syncTagIndex bool) chan map[string]any

func (*Server) PromotePermissionForUserPcap

func (s *Server) PromotePermissionForUserPcap(ctx context.Context, req *ypb.Empty) (*ypb.Empty, error)

func (*Server) QueryAllMenuItem

func (s *Server) QueryAllMenuItem(ctx context.Context, req *ypb.QueryAllMenuItemRequest) (*ypb.MenuByGroup, error)

func (*Server) QueryAvailableReportFrom

func (s *Server) QueryAvailableReportFrom(ctx context.Context, _ *ypb.Empty) (*ypb.Fields, error)

func (*Server) QueryAvailableRiskLevel

func (s *Server) QueryAvailableRiskLevel(ctx context.Context, _ *ypb.Empty) (*ypb.Fields, error)

func (*Server) QueryAvailableRiskType

func (s *Server) QueryAvailableRiskType(ctx context.Context, req *ypb.Empty) (*ypb.Fields, error)

func (*Server) QueryCVE

func (s *Server) QueryCVE(ctx context.Context, req *ypb.QueryCVERequest) (*ypb.QueryCVEResponse, error)

func (*Server) QueryChaosMakerRule

func (*Server) QueryDNSLogByToken

func (*Server) QueryDNSLogTokenByScript added in v1.2.6

func (*Server) QueryDomains

func (s *Server) QueryDomains(ctx context.Context, req *ypb.QueryDomainsRequest) (*ypb.QueryDomainsResponse, error)

func (*Server) QueryExecHistory

func (s *Server) QueryExecHistory(ctx context.Context, req *ypb.ExecHistoryRequest) (*ypb.ExecHistoryRecordResponse, error)

func (*Server) QueryFuzzerLabel added in v1.2.3

func (s *Server) QueryFuzzerLabel(ctx context.Context, req *ypb.Empty) (*ypb.QueryFuzzerLabelResponse, error)

func (*Server) QueryGroupsByYakScriptId

func (s *Server) QueryGroupsByYakScriptId(ctx context.Context, req *ypb.QueryGroupsByYakScriptIdRequest) (*ypb.GroupNames, error)

func (*Server) QueryHTTPFlows

func (s *Server) QueryHTTPFlows(ctx context.Context, req *ypb.QueryHTTPFlowRequest) (*ypb.QueryHTTPFlowResponse, error)

func (*Server) QueryHTTPFlowsIds

似乎已弃用?没有调用

func (*Server) QueryHTTPFuzzerResponseByTaskId added in v1.3.3

func (*Server) QueryHistoryHTTPFuzzerTask

func (s *Server) QueryHistoryHTTPFuzzerTask(ctx context.Context, req *ypb.Empty) (*ypb.HistoryHTTPFuzzerTasks, error)

Deprecated

func (*Server) QueryHosts

func (s *Server) QueryHosts(ctx context.Context, req *ypb.QueryHostsRequest) (*ypb.QueryHostsResponse, error)

func (*Server) QueryHybridScanTask added in v1.2.9

func (s *Server) QueryHybridScanTask(ctx context.Context, request *ypb.QueryHybridScanTaskRequest) (*ypb.QueryHybridScanTaskResponse, error)

func (*Server) QueryICMPTrigger

func (*Server) QueryNavigationGroups added in v1.2.3

func (s *Server) QueryNavigationGroups(ctx context.Context, req *ypb.QueryNavigationGroupsRequest) (*ypb.GroupNames, error)

func (*Server) QueryNewRisk

func (s *Server) QueryNewRisk(ctx context.Context, req *ypb.QueryNewRiskRequest) (*ypb.QueryNewRiskResponse, error)

func (*Server) QueryPayload

func (s *Server) QueryPayload(ctx context.Context, req *ypb.QueryPayloadRequest) (*ypb.QueryPayloadResponse, error)

func (*Server) QueryPayloadFromFile added in v1.2.9

func (*Server) QueryPorts

func (s *Server) QueryPorts(ctx context.Context, req *ypb.QueryPortsRequest) (*ypb.QueryPortsResponse, error)

func (*Server) QueryPortsGroup added in v1.2.2

func (s *Server) QueryPortsGroup(ctx context.Context, req *ypb.Empty) (*ypb.QueryPortsGroupResponse, error)

func (*Server) QueryProjectDetail

func (s *Server) QueryProjectDetail(ctx context.Context, req *ypb.QueryProjectDetailRequest) (*ypb.ProjectDescription, error)

func (*Server) QueryReport

func (s *Server) QueryReport(ctx context.Context, d *ypb.QueryReportRequest) (*ypb.Report, error)

func (*Server) QueryReports

func (*Server) QueryRisk

func (s *Server) QueryRisk(ctx context.Context, req *ypb.QueryRiskRequest) (*ypb.Risk, error)

func (*Server) QueryRiskTableStats

func (s *Server) QueryRiskTableStats(ctx context.Context, e *ypb.Empty) (*ypb.RiskTableStats, error)

func (*Server) QueryRisks

func (s *Server) QueryRisks(ctx context.Context, req *ypb.QueryRisksRequest) (*ypb.QueryRisksResponse, error)

func (*Server) QueryScreenRecorders

func (*Server) QuerySimpleDetectUnfinishedTask added in v1.3.3

func (s *Server) QuerySimpleDetectUnfinishedTask(ctx context.Context, req *ypb.QueryUnfinishedTaskRequest) (*ypb.QueryUnfinishedTaskResponse, error)

func (*Server) QuerySupportedDnsLogPlatforms added in v1.2.6

func (s *Server) QuerySupportedDnsLogPlatforms(ctx context.Context, req *ypb.Empty) (*ypb.QuerySupportedDnsLogPlatformsResponse, error)

func (*Server) QueryTrafficPacket added in v1.2.8

func (*Server) QueryTrafficSession added in v1.2.8

func (*Server) QueryTrafficTCPReassembled added in v1.2.8

func (*Server) QueryWebShells added in v1.3.0

func (*Server) QueryWebsocketFlowByHTTPFlowWebsocketHash

func (s *Server) QueryWebsocketFlowByHTTPFlowWebsocketHash(ctx context.Context, req *ypb.QueryWebsocketFlowByHTTPFlowWebsocketHashRequest) (*ypb.WebsocketFlows, error)

func (*Server) QueryYakScript

func (*Server) QueryYakScriptByIsCore added in v1.2.4

func (*Server) QueryYakScriptByNames added in v1.2.3

func (*Server) QueryYakScriptByYakScriptName

func (s *Server) QueryYakScriptByYakScriptName(req *ypb.QueryYakScriptRequest, stream ypb.Yak_QueryYakScriptByYakScriptNameServer) error

func (*Server) QueryYakScriptGroup added in v1.3.1

func (*Server) QueryYakScriptLocalAll

func (s *Server) QueryYakScriptLocalAll(c context.Context, req *ypb.Empty) (*ypb.QueryYakScriptLocalAndUserResponse, error)

func (*Server) QueryYakScriptNameInExecResult

func (s *Server) QueryYakScriptNameInExecResult(ctx context.Context, req *ypb.Empty) (*ypb.YakScriptNames, error)

func (*Server) QueryYakScriptRiskDetailByCWE added in v1.2.9

func (*Server) QueryYakScriptTagsGroup added in v1.2.3

func (s *Server) QueryYakScriptTagsGroup(db *gorm.DB) []*ypb.Tags

func (*Server) RecoverSimpleDetectTask added in v1.3.3

func (s *Server) RecoverSimpleDetectTask(req *ypb.RecoverUnfinishedTaskRequest, stream ypb.Yak_RecoverSimpleDetectTaskServer) error

func (*Server) RedirectRequest

func (s *Server) RedirectRequest(ctx context.Context, req *ypb.RedirectRequestParams) (*ypb.FuzzerResponse, error)

func (*Server) RegisterFacadesHTTP

func (*Server) RemoveDuplicatePayloads added in v1.2.9

func (s *Server) RemoveDuplicatePayloads(req *ypb.NameRequest, stream ypb.Yak_RemoveDuplicatePayloadsServer) error

func (*Server) RemoveFromMenu

func (s *Server) RemoveFromMenu(ctx context.Context, req *ypb.RemoveFromMenuRequest) (*ypb.Empty, error)

func (*Server) RenamePayloadFolder added in v1.2.9

func (s *Server) RenamePayloadFolder(ctx context.Context, req *ypb.RenameRequest) (*ypb.Empty, error)

func (*Server) RenamePayloadGroup added in v1.2.9

func (s *Server) RenamePayloadGroup(ctx context.Context, req *ypb.RenameRequest) (*ypb.Empty, error)

func (*Server) RenameYakScriptGroup added in v1.3.1

func (s *Server) RenameYakScriptGroup(ctx context.Context, req *ypb.RenameYakScriptGroupRequest) (*ypb.Empty, error)

func (*Server) RenderHTTPFuzzerPacket added in v1.3.1

! 已弃用

func (*Server) RenderVariables

func (*Server) RenderVariablesWithTypedKV added in v1.2.7

func (s *Server) RenderVariablesWithTypedKV(ctx context.Context, kvs []*ypb.FuzzerParamItem) map[string]any

func (*Server) RequestYakURL added in v1.2.6

func (s *Server) RequestYakURL(ctx context.Context, req *ypb.RequestYakURLParams) (*ypb.RequestYakURLResponse, error)

func (*Server) RequireDNSLogDomain

func (s *Server) RequireDNSLogDomain(ctx context.Context, params *ypb.YakDNSLogBridgeAddr) (*ypb.DNSLogRootDomain, error)

func (*Server) RequireDNSLogDomainByScript added in v1.2.6

func (s *Server) RequireDNSLogDomainByScript(ctx context.Context, req *ypb.RequireDNSLogDomainByScriptRequest) (*ypb.DNSLogRootDomain, error)

func (*Server) RequireICMPRandomLength

func (s *Server) RequireICMPRandomLength(ctx context.Context, req *ypb.Empty) (*ypb.RequireICMPRandomLengthResponse, error)

func (*Server) RequireRandomPortToken

func (s *Server) RequireRandomPortToken(ctx context.Context, req *ypb.Empty) (*ypb.RandomPortInfo, error)

func (*Server) ResetAndInvalidUserData

func (s *Server) ResetAndInvalidUserData(ctx context.Context, req *ypb.ResetAndInvalidUserDataRequest) (*ypb.Empty, error)

func (*Server) ResetGlobalNetworkConfig added in v1.2.4

func (s *Server) ResetGlobalNetworkConfig(ctx context.Context, req *ypb.ResetGlobalNetworkConfigRequest) (*ypb.Empty, error)

func (*Server) ResetRiskTableStats

func (s *Server) ResetRiskTableStats(ctx context.Context, e *ypb.Empty) (*ypb.Empty, error)

func (*Server) ResetYakScriptGroup added in v1.3.1

func (s *Server) ResetYakScriptGroup(ctx context.Context, req *ypb.ResetYakScriptGroupRequest) (*ypb.Empty, error)

func (*Server) SaveCancelSimpleDetect

func (s *Server) SaveCancelSimpleDetect(ctx context.Context, req *ypb.RecordPortScanRequest) (*ypb.Empty, error)

func (*Server) SaveCodecFlow added in v1.3.3

func (s *Server) SaveCodecFlow(ctx context.Context, req *ypb.CustomizeCodecFlow) (*ypb.Empty, error)

func (*Server) SaveFuzzerLabel added in v1.2.3

func (s *Server) SaveFuzzerLabel(ctx context.Context, req *ypb.SaveFuzzerLabelRequest) (*ypb.Empty, error)

func (*Server) SaveMarkdownDocument

func (s *Server) SaveMarkdownDocument(ctx context.Context, req *ypb.SaveMarkdownDocumentRequest) (*ypb.Empty, error)

func (*Server) SaveNewYakScript added in v1.2.9

func (s *Server) SaveNewYakScript(ctx context.Context, script *ypb.SaveNewYakScriptRequest) (*ypb.YakScript, error)

func (*Server) SavePayloadStream

func (s *Server) SavePayloadStream(req *ypb.SavePayloadRequest, stream ypb.Yak_SavePayloadStreamServer) (ret error)

func (*Server) SavePayloadToFileStream added in v1.2.9

func (s *Server) SavePayloadToFileStream(req *ypb.SavePayloadRequest, stream ypb.Yak_SavePayloadToFileStreamServer) error

func (*Server) SaveSetTagForHTTPFlow

func (s *Server) SaveSetTagForHTTPFlow(id int64, hash string, tags []string) error

func (*Server) SaveYakScript

func (s *Server) SaveYakScript(ctx context.Context, script *ypb.YakScript) (*ypb.YakScript, error)

func (*Server) SaveYakScriptGroup added in v1.3.1

func (s *Server) SaveYakScriptGroup(ctx context.Context, req *ypb.SaveYakScriptGroupRequest) (*ypb.Empty, error)

func (*Server) SaveYakScriptToOnline added in v1.2.9

func (s *Server) SaveYakScriptToOnline(req *ypb.SaveYakScriptToOnlineRequest, stream ypb.Yak_SaveYakScriptToOnlineServer) error

func (*Server) SetCurrentProject

func (s *Server) SetCurrentProject(ctx context.Context, req *ypb.SetCurrentProjectRequest) (*ypb.Empty, error)

func (*Server) SetCurrentRules

func (s *Server) SetCurrentRules(c context.Context, req *ypb.MITMContentReplacers) (*ypb.Empty, error)

func (*Server) SetEngineDefaultProxy

func (s *Server) SetEngineDefaultProxy(ctx context.Context, d *ypb.DefaultProxyResult) (*ypb.Empty, error)

func (*Server) SetGlobalNetworkConfig added in v1.2.4

func (s *Server) SetGlobalNetworkConfig(ctx context.Context, req *ypb.GlobalNetworkConfig) (*ypb.Empty, error)

func (*Server) SetKey

func (s *Server) SetKey(ctx context.Context, req *ypb.SetKeyRequest) (*ypb.Empty, error)

func (*Server) SetMITMFilter

func (s *Server) SetMITMFilter(ctx context.Context, req *ypb.SetMITMFilterRequest) (*ypb.SetMITMFilterResponse, error)

func (*Server) SetOnlineProfile

func (s *Server) SetOnlineProfile(ctx context.Context, req *ypb.OnlineProfile) (*ypb.Empty, error)

func (*Server) SetProcessEnvKey

func (s *Server) SetProcessEnvKey(ctx context.Context, req *ypb.SetKeyRequest) (*ypb.Empty, error)

func (*Server) SetProjectKey added in v1.2.2

func (s *Server) SetProjectKey(ctx context.Context, req *ypb.SetKeyRequest) (*ypb.Empty, error)

func (*Server) SetSystemProxy

func (s *Server) SetSystemProxy(ctx context.Context, req *ypb.SetSystemProxyRequest) (*ypb.Empty, error)

func (*Server) SetTagForHTTPFlow

func (s *Server) SetTagForHTTPFlow(ctx context.Context, req *ypb.SetTagForHTTPFlowRequest) (*ypb.Empty, error)

func (*Server) SetYakBridgeLogServer

func (s *Server) SetYakBridgeLogServer(ctx context.Context, l *ypb.YakDNSLogBridgeAddr) (*ypb.Empty, error)

func (*Server) SimpleDetect

func (s *Server) SimpleDetect(req *ypb.RecordPortScanRequest, stream ypb.Yak_SimpleDetectServer) error

func (*Server) SimpleDetectCreatReport added in v1.3.3

func (s *Server) SimpleDetectCreatReport(req *ypb.CreatReportRequest, stream ypb.Yak_SimpleDetectCreatReportServer) error

func (*Server) SmokingEvaluatePlugin added in v1.2.3

func (*Server) SmokingEvaluatePluginBatch added in v1.2.9

func (s *Server) SmokingEvaluatePluginBatch(req *ypb.SmokingEvaluatePluginBatchRequest, stream ypb.Yak_SmokingEvaluatePluginBatchServer) error

SmokingEvaluatePluginBatch(*SmokingEvaluatePluginBatchRequest, Yak_SmokingEvaluatePluginBatchServer) error SmokingEvaluatePluginBatch

func (*Server) StartBrute

func (s *Server) StartBrute(params *ypb.StartBruteParams, stream ypb.Yak_StartBruteServer) error

func (*Server) StartFacades

func (s *Server) StartFacades(req *ypb.StartFacadesParams, stream ypb.Yak_StartFacadesServer) error

func (*Server) StartFacadesWithYsoObject

func (s *Server) StartFacadesWithYsoObject(req *ypb.StartFacadesWithYsoParams, stream ypb.Yak_StartFacadesWithYsoObjectServer) error

func (*Server) StartScrecorder

func (s *Server) StartScrecorder(req *ypb.StartScrecorderRequest, stream ypb.Yak_StartScrecorderServer) error

func (*Server) StartVulinbox added in v1.2.3

func (s *Server) StartVulinbox(req *ypb.StartVulinboxRequest, stream ypb.Yak_StartVulinboxServer) error

func (*Server) StaticAnalyzeError

func (*Server) StringFuzzer

func (s *Server) StringFuzzer(rootCtx context.Context, req *ypb.StringFuzzerRequest) (*ypb.StringFuzzerResponse, error)

func (*Server) ToGRPCNavigation added in v1.2.3

func (s *Server) ToGRPCNavigation(i *schema.NavigationBar) (*ypb.NavigationItem, error)

func (*Server) TraceRoute added in v1.3.1

func (s *Server) TraceRoute(req *ypb.TraceRouteRequest, server ypb.Yak_TraceRouteServer) error

func (*Server) UnIgnoreYakScript

func (s *Server) UnIgnoreYakScript(ctx context.Context, req *ypb.DeleteYakScriptRequest) (*ypb.Empty, error)

func (*Server) UpdateAllPayloadGroup added in v1.2.9

func (s *Server) UpdateAllPayloadGroup(ctx context.Context, req *ypb.UpdateAllPayloadGroupRequest) (*ypb.Empty, error)

func (*Server) UpdateCVEDatabase

func (s *Server) UpdateCVEDatabase(req *ypb.UpdateCVEDatabaseRequest, stream ypb.Yak_UpdateCVEDatabaseServer) error

func (*Server) UpdateFromGithub

func (s *Server) UpdateFromGithub(ctx context.Context, req *ypb.UpdateFromGithubRequest) (*ypb.Empty, error)

func (*Server) UpdateFromYakitResource

func (s *Server) UpdateFromYakitResource(ctx context.Context, req *ypb.UpdateFromYakitResourceRequest) (*ypb.Empty, error)

func (*Server) UpdatePayload

func (s *Server) UpdatePayload(ctx context.Context, req *ypb.UpdatePayloadRequest) (*ypb.Empty, error)

func (*Server) UpdatePayloadToFile added in v1.2.9

func (s *Server) UpdatePayloadToFile(ctx context.Context, req *ypb.UpdatePayloadToFileRequest) (*ypb.Empty, error)

func (*Server) UpdateScreenRecorders added in v1.2.2

func (s *Server) UpdateScreenRecorders(ctx context.Context, req *ypb.UpdateScreenRecorderRequest) (*ypb.Empty, error)

func (*Server) UpdateWebShell added in v1.3.0

func (s *Server) UpdateWebShell(ctx context.Context, req *ypb.WebShell) (*ypb.WebShell, error)

func (*Server) UploadRiskToOnline

func (s *Server) UploadRiskToOnline(ctx context.Context, req *ypb.UploadRiskToOnlineRequest) (*ypb.Empty, error)

func (*Server) UploadScreenRecorders added in v1.2.2

func (s *Server) UploadScreenRecorders(ctx context.Context, req *ypb.UploadScreenRecorderRequest) (*ypb.Empty, error)

func (*Server) ValidP12PassWord added in v1.2.8

func (*Server) VerifySystemCertificate added in v1.3.3

func (s *Server) VerifySystemCertificate(ctx context.Context, _ *ypb.Empty) (*ypb.VerifySystemCertificateResponse, error)

func (*Server) Version

func (s *Server) Version(ctx context.Context, _ *ypb.Empty) (*ypb.VersionResponse, error)

func (*Server) ViewPortScanCode

func (s *Server) ViewPortScanCode(ctx context.Context, req *ypb.Empty) (*ypb.SimpleScript, error)

func (*Server) YakScriptIsInMenu

func (s *Server) YakScriptIsInMenu(ctx context.Context, req *ypb.YakScriptIsInMenuRequest) (*ypb.Empty, error)

func (*Server) YakScriptRiskTypeList added in v1.2.9

func (s *Server) YakScriptRiskTypeList(context.Context, *ypb.Empty) (*ypb.YakScriptRiskTypeListResponse, error)

func (*Server) YakVersionAtLeast added in v1.3.0

func (s *Server) YakVersionAtLeast(ctx context.Context, req *ypb.YakVersionAtLeastRequest) (*ypb.GeneralResponse, error)

func (*Server) YaklangGetCliCodeFromDatabase added in v1.3.0

func (*Server) YaklangInspectInformation added in v1.2.9

func (*Server) YaklangLanguageFind added in v1.3.3

func (*Server) YaklangLanguageSuggestion added in v1.2.9

func (*Server) YsoDump

func (s *Server) YsoDump(ctx context.Context, req *ypb.YsoBytesObject) (*ypb.YsoDumpResponse, error)

type ServerConfig added in v1.3.3

type ServerConfig struct {
	// contains filtered or unexported fields
}

type ServerOpts added in v1.3.3

type ServerOpts func(config *ServerConfig)

func WithInitFacadeServer added in v1.3.3

func WithInitFacadeServer(init bool) ServerOpts

func WithReverseServerPort added in v1.3.3

func WithReverseServerPort(port int) ServerOpts

func WithStartCacheLog added in v1.3.3

func WithStartCacheLog() ServerOpts

type VAttachCombinedOutputServer

type VAttachCombinedOutputServer struct {
	// contains filtered or unexported fields
}

func NewVAttachCombinedOutputServer

func NewVAttachCombinedOutputServer(send func(msg *ypb.ExecResult) error) *VAttachCombinedOutputServer

func (*VAttachCombinedOutputServer) Cancel

func (v *VAttachCombinedOutputServer) Cancel()

func (*VAttachCombinedOutputServer) Context

func (*VAttachCombinedOutputServer) IsValid

func (v *VAttachCombinedOutputServer) IsValid() bool

func (*VAttachCombinedOutputServer) RecvMsg

func (v *VAttachCombinedOutputServer) RecvMsg(m interface{}) error

func (*VAttachCombinedOutputServer) Send

func (*VAttachCombinedOutputServer) SendHeader

func (*VAttachCombinedOutputServer) SendMsg

func (v *VAttachCombinedOutputServer) SendMsg(m interface{}) error

func (*VAttachCombinedOutputServer) SetHeader

func (*VAttachCombinedOutputServer) SetTrailer

func (v *VAttachCombinedOutputServer) SetTrailer(md grpcMetadata.MD)

type VulinboxAgentFacade added in v1.2.3

type VulinboxAgentFacade struct {
	// contains filtered or unexported fields
}

func GetVulinboxAgent added in v1.2.3

func GetVulinboxAgent(addr string) (*VulinboxAgentFacade, bool)

func (*VulinboxAgentFacade) AddPing added in v1.2.3

func (v *VulinboxAgentFacade) AddPing()

func (*VulinboxAgentFacade) AddRequestCount added in v1.2.3

func (v *VulinboxAgentFacade) AddRequestCount()

func (*VulinboxAgentFacade) Close added in v1.2.3

func (v *VulinboxAgentFacade) Close()

func (*VulinboxAgentFacade) IsClosed added in v1.2.3

func (v *VulinboxAgentFacade) IsClosed() bool

func (*VulinboxAgentFacade) Status added in v1.2.3

type YakExecServerWrapper

type YakExecServerWrapper struct {
	grpc.ServerStream
	// contains filtered or unexported fields
}

func NewYakExecServerWrapper

func NewYakExecServerWrapper(stream grpc.ServerStream, handle func(result *ypb.ExecResult) error) *YakExecServerWrapper

func (*YakExecServerWrapper) Send

func (y *YakExecServerWrapper) Send(result *ypb.ExecResult) error

type YakOutputStreamerHelperWC

type YakOutputStreamerHelperWC struct {
	io.WriteCloser
	// contains filtered or unexported fields
}

OpenPortServerStreamerHelperRWC

func (*YakOutputStreamerHelperWC) Close

func (s *YakOutputStreamerHelperWC) Close() (err error)

func (*YakOutputStreamerHelperWC) Write

func (s *YakOutputStreamerHelperWC) Write(b []byte) (int, error)

type YamlArrayBuilder added in v1.2.7

type YamlArrayBuilder struct {
	// contains filtered or unexported fields
}

func (*YamlArrayBuilder) Add added in v1.2.7

func (a *YamlArrayBuilder) Add(slice *YamlMapBuilder)

type YamlMapBuilder added in v1.2.7

type YamlMapBuilder struct {
	// contains filtered or unexported fields
}

func NewYamlMapBuilder added in v1.2.7

func NewYamlMapBuilder() *YamlMapBuilder

func (*YamlMapBuilder) AddComment added in v1.2.7

func (m *YamlMapBuilder) AddComment(comment string)

func (*YamlMapBuilder) AddEmptyLine added in v1.2.7

func (m *YamlMapBuilder) AddEmptyLine()

func (*YamlMapBuilder) FilterEmptyField added in v1.2.7

func (m *YamlMapBuilder) FilterEmptyField() *yaml.MapSlice

func (*YamlMapBuilder) ForceSet added in v1.2.7

func (m *YamlMapBuilder) ForceSet(k string, v any)

func (*YamlMapBuilder) MarshalToString added in v1.2.7

func (m *YamlMapBuilder) MarshalToString() (string, error)

func (*YamlMapBuilder) NewSubArrayBuilder added in v1.2.7

func (m *YamlMapBuilder) NewSubArrayBuilder(k string) *YamlArrayBuilder

func (*YamlMapBuilder) NewSubMapBuilder added in v1.2.7

func (m *YamlMapBuilder) NewSubMapBuilder(k string) *YamlMapBuilder

func (*YamlMapBuilder) Set added in v1.2.7

func (m *YamlMapBuilder) Set(k string, v any)

func (*YamlMapBuilder) SetDefaultField added in v1.2.7

func (a *YamlMapBuilder) SetDefaultField(fieldMap map[string]any)

Source Files

Directories

Path Synopsis

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL