Versions in this module Expand all Collapse all v0 v0.5.0 Jun 23, 2023 v0.4.0 Jun 22, 2023 v0.3.0 Jun 22, 2023 v0.2.0 Jun 22, 2023 Changes in this version + const BlockhashStoreJobType + const BootstrapJobType + const CronJobType + const DirectRequestJobType + const FluxMonitorJobType + const InputTaskKey + const KeeperJobType + const KeepersObservationSource + const KeypathSeparator + const OffchainReporting2JobType + const OffchainReportingJobType + const VRFJobType + const WebhookJobType + var ErrBadInput = errors.New("bad input for task") + var ErrCancelled = errors.New("task run cancelled (fail early)") + var ErrDivideByZero = errors.New("divide by zero") + var ErrDivisionOverlow = errors.New("division overflow") + var ErrIndexOutOfRange = errors.New("index out of range") + var ErrInputTaskErrored = errors.New("input task errored") + var ErrInvalidMultiplier = errors.New("Invalid multiplier") + var ErrKeypathNotFound = errors.New("keypath not found") + var ErrMultiplyOverlow = errors.New("multiply overflow") + var ErrOverflow = errors.New("overflow") + var ErrParameterEmpty = errors.New("parameter is empty") + var ErrTaskRunFailed = errors.New("task run failed") + var ErrTimeout = errors.New("timeout") + var ErrTooManyErrors = errors.New("too many errors") + var ErrVarsRoot = errors.New("cannot get/set the root of a pipeline.Vars") + var ErrVarsSetNested = errors.New("cannot set a nested key of a pipeline.Vars") + var ErrWrongInputCardinality = errors.New("wrong number of task inputs") + var ErrWrongKeypath = errors.New("wrong keypath format") + var PromPipelineRunErrors = promauto.NewCounterVec(prometheus.CounterOpts{ ... }, []string{ ... }) + var PromPipelineRunTotalTimeToCompletion = promauto.NewGaugeVec(prometheus.GaugeOpts{ ... }, []string{ ... }) + var PromPipelineTaskExecutionTime = promauto.NewGaugeVec(prometheus.GaugeOpts{ ... }, []string{ ... }) + var PromPipelineTasksTotalFinished = promauto.NewCounterVec(prometheus.CounterOpts{ ... }, []string{ ... }) + func CheckInputs(inputs []Result, minLen, maxLen, maxErrors int) ([]interface{}, error) + func NewORM(db *sqlx.DB, lggr logger.Logger, cfg ORMConfig) *orm + func NewRunner(orm ORM, btORM bridges.ORM, cfg Config, chainSet evm.ChainSet, ...) *runner + func ParseETHABIArgsString(theABI []byte, isLog bool) (args abi.Arguments, indexedArgs abi.Arguments, _ error) + func ResolveParam(out PipelineParamUnmarshaler, getters []GetterFunc) error + func SelectGasLimit(cfg config.ChainScopedConfig, jobType string, specGasLimit *uint32) uint32 + type AddressParam common.Address + func (a *AddressParam) UnmarshalPipelineParam(val interface{}) error + type AddressSliceParam []common.Address + func (s *AddressSliceParam) UnmarshalPipelineParam(val interface{}) error + type AnyTask struct + func (t *AnyTask) Run(_ context.Context, _ logger.Logger, _ Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *AnyTask) Type() TaskType + type Base64DecodeTask struct + Input string + func (t *Base64DecodeTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *Base64DecodeTask) Type() TaskType + type Base64EncodeTask struct + Input string + func (t *Base64EncodeTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *Base64EncodeTask) Type() TaskType + type BaseTask struct + FailEarly bool + Index int32 + MaxBackoff time.Duration + MinBackoff time.Duration + Retries null.Uint32 + Timeout *time.Duration + func NewBaseTask(id int, dotID string, inputs []TaskDependency, outputs []Task, index int32) BaseTask + func (t *BaseTask) Base() *BaseTask + func (t BaseTask) DotID() string + func (t BaseTask) ID() int + func (t BaseTask) Inputs() []TaskDependency + func (t BaseTask) OutputIndex() int32 + func (t BaseTask) Outputs() []Task + func (t BaseTask) TaskMaxBackoff() time.Duration + func (t BaseTask) TaskMinBackoff() time.Duration + func (t BaseTask) TaskRetries() uint32 + func (t BaseTask) TaskTimeout() (time.Duration, bool) + type BoolParam bool + func (b *BoolParam) UnmarshalPipelineParam(val interface{}) error + type BridgeTask struct + Async string + CacheTTL string + Headers string + IncludeInputAtKey string + Name string + RequestData string + func (t *BridgeTask) Run(ctx context.Context, lggr logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *BridgeTask) Type() TaskType + type BytesParam []byte + func (b *BytesParam) UnmarshalPipelineParam(val interface{}) error + type CBORParseTask struct + Data string + Mode string + func (t *CBORParseTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *CBORParseTask) Type() TaskType + type ConditionalTask struct + Data string + func (t *ConditionalTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *ConditionalTask) Type() TaskType + type Config interface + BridgeCacheTTL func() time.Duration + BridgeResponseURL func() *url.URL + DatabaseURL func() url.URL + DefaultHTTPLimit func() int64 + DefaultHTTPTimeout func() models.Duration + JobPipelineMaxRunDuration func() time.Duration + JobPipelineReaperInterval func() time.Duration + JobPipelineReaperThreshold func() time.Duration + TriggerFallbackDBPollInterval func() time.Duration + type DecimalParam decimal.Decimal + func (d *DecimalParam) UnmarshalPipelineParam(val interface{}) error + func (d DecimalParam) Decimal() decimal.Decimal + type DecimalSliceParam []decimal.Decimal + func (s *DecimalSliceParam) UnmarshalPipelineParam(val interface{}) error + type DivideTask struct + Divisor string + Input string + Precision string + func (t *DivideTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *DivideTask) Type() TaskType + type ETHABIDecodeLogTask struct + ABI string + Data string + Topics string + func (t *ETHABIDecodeLogTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *ETHABIDecodeLogTask) Type() TaskType + type ETHABIDecodeTask struct + ABI string + Data string + func (t *ETHABIDecodeTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *ETHABIDecodeTask) Type() TaskType + type ETHABIEncodeTask struct + ABI string + Data string + func (t *ETHABIEncodeTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *ETHABIEncodeTask) Type() TaskType + type ETHABIEncodeTask2 struct + ABI string + Data string + func (t *ETHABIEncodeTask2) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (Result, RunInfo) + func (t *ETHABIEncodeTask2) Type() TaskType + type ETHCallTask struct + Contract string + Data string + EVMChainID string + ExtractRevertReason bool + From string + Gas string + GasFeeCap string + GasPrice string + GasTipCap string + GasUnlimited string + func (t *ETHCallTask) Run(ctx context.Context, lggr logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *ETHCallTask) Type() TaskType + type ETHGetBlockTask struct + EVMChainID string + func (t *ETHGetBlockTask) Run(ctx context.Context, lggr logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *ETHGetBlockTask) Type() TaskType + type ETHKeyStore interface + GetRoundRobinAddress func(chainID *big.Int, addrs ...common.Address) (common.Address, error) + type ETHTxTask struct + Data string + EVMChainID string + FailOnRevert string + From string + GasLimit string + MinConfirmations string + To string + TransmitChecker string + TxMeta string + func (t *ETHTxTask) Run(_ context.Context, lggr logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *ETHTxTask) Type() TaskType + type ErrRunPanicked struct + func (err ErrRunPanicked) Error() string + type EstimateGasLimitTask struct + Data string + EVMChainID string + From string + Input string + Multiplier string + To string + func (t *EstimateGasLimitTask) Run(ctx context.Context, lggr logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *EstimateGasLimitTask) Type() TaskType + type FailTask struct + Msg string + func (t *FailTask) Run(_ context.Context, _ logger.Logger, vars Vars, _ []Result) (Result, RunInfo) + func (t *FailTask) Type() TaskType + type FinalResult struct + AllErrors []error + FatalErrors []error + Values []interface{} + func (result FinalResult) HasErrors() bool + func (result FinalResult) HasFatalErrors() bool + func (result FinalResult) SingularResult() (Result, error) + type GasEstimator interface + EstimateGas func(ctx context.Context, call ethereum.CallMsg) (uint64, error) + type GetterFunc func() (interface{}, error) + func From(getters ...interface{}) []GetterFunc + func Input(inputs []Result, index int) GetterFunc + func Inputs(inputs []Result) GetterFunc + func JSONWithVarExprs(jsExpr string, vars Vars, allowErrors bool) GetterFunc + func NonemptyString(s string) GetterFunc + func ValidDurationInSeconds(s string) GetterFunc + func VarExpr(expr string, vars Vars) GetterFunc + type Graph struct + func NewGraph() *Graph + func (g *Graph) AddImplicitDependenciesAsEdges() + func (g *Graph) IsImplicitEdge(uid, vid int64) bool + func (g *Graph) NewEdge(from, to graph.Node) graph.Edge + func (g *Graph) NewNode() graph.Node + func (g *Graph) UnmarshalText(bs []byte) (err error) + type GraphEdge struct + func (e *GraphEdge) IsImplicit() bool + func (e *GraphEdge) SetIsImplicit(isImplicit bool) + type GraphNode struct + func (n *GraphNode) Attributes() []encoding.Attribute + func (n *GraphNode) DOTID() string + func (n *GraphNode) SetAttribute(attr encoding.Attribute) error + func (n *GraphNode) SetDOTID(id string) + func (n *GraphNode) String() string + type HTTPTask struct + AllowUnrestrictedNetworkAccess string + Headers string + Method string + RequestData string + URL string + func (t *HTTPTask) Run(ctx context.Context, lggr logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *HTTPTask) Type() TaskType + type HashSliceParam []common.Hash + func (s *HashSliceParam) UnmarshalPipelineParam(val interface{}) error + type HexDecodeTask struct + Input string + func (t *HexDecodeTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *HexDecodeTask) Type() TaskType + type HexEncodeTask struct + Input string + func (t *HexEncodeTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *HexEncodeTask) Type() TaskType + type JSONParseTask struct + Data string + Lax string + Path string + Separator string + func (t *JSONParseTask) Run(_ context.Context, l logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *JSONParseTask) Type() TaskType + type JSONPathParam []string + func NewJSONPathParam(sep string) JSONPathParam + func (p *JSONPathParam) UnmarshalPipelineParam(val interface{}) error + type JSONSerializable struct + Val interface{} + Valid bool + func (js *JSONSerializable) Empty() bool + func (js *JSONSerializable) Scan(value interface{}) error + func (js *JSONSerializable) UnmarshalJSON(bs []byte) error + func (js JSONSerializable) MarshalJSON() ([]byte, error) + func (js JSONSerializable) Value() (driver.Value, error) + type Keypath struct + Parts []string + func NewKeypathFromString(keypathStr string) (Keypath, error) + type LengthTask struct + Input string + func (t *LengthTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *LengthTask) Type() TaskType + type LessThanTask struct + Left string + Right string + func (t *LessThanTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *LessThanTask) Type() TaskType + type LookupTask struct + Key string + func (t *LookupTask) Run(ctx context.Context, lggr logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *LookupTask) Type() TaskType + type LowercaseTask struct + Input string + func (t *LowercaseTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *LowercaseTask) Type() TaskType + type MapParam map[string]interface + func (m *MapParam) UnmarshalPipelineParam(val interface{}) error + func (m MapParam) Map() map[string]interface{} + type MaybeBigIntParam struct + func NewMaybeBigIntParam(n *big.Int) MaybeBigIntParam + func (p *MaybeBigIntParam) UnmarshalPipelineParam(val interface{}) error + func (p MaybeBigIntParam) BigInt() *big.Int + type MaybeInt32Param struct + func NewMaybeInt32Param(n int32, isSet bool) MaybeInt32Param + func (p *MaybeInt32Param) UnmarshalPipelineParam(val interface{}) error + func (p MaybeInt32Param) Int32() (int32, bool) + type MaybeUint64Param struct + func NewMaybeUint64Param(n uint64, isSet bool) MaybeUint64Param + func (p *MaybeUint64Param) UnmarshalPipelineParam(val interface{}) error + func (p MaybeUint64Param) Uint64() (uint64, bool) + type MeanTask struct + AllowedFaults string + Precision string + Values string + func (t *MeanTask) Run(ctx context.Context, lggr logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *MeanTask) Type() TaskType + type MedianTask struct + AllowedFaults string + Values string + func (t *MedianTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *MedianTask) Type() TaskType + type MemoTask struct + Value string + func (t *MemoTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (Result, RunInfo) + func (t *MemoTask) Type() TaskType + type MergeTask struct + Left string + Right string + func (t *MergeTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *MergeTask) Type() TaskType + type Method struct + Inputs abi.Arguments + Name string + type ModeTask struct + AllowedFaults string + Values string + func (t *ModeTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *ModeTask) Type() TaskType + type MultiplyTask struct + Input string + Times string + func (t *MultiplyTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *MultiplyTask) Type() TaskType + type ORM interface + CreateRun func(run *Run, qopts ...pg.QOpt) (err error) + CreateSpec func(pipeline Pipeline, maxTaskTimeout models.Interval, qopts ...pg.QOpt) (int32, error) + DeleteRun func(id int64) error + DeleteRunsOlderThan func(context.Context, time.Duration) error + FindRun func(id int64) (Run, error) + GetAllRuns func() ([]Run, error) + GetQ func() pg.Q + GetUnfinishedRuns func(context.Context, time.Time, func(run Run) error) error + InsertFinishedRun func(run *Run, saveSuccessfulTaskRuns bool, qopts ...pg.QOpt) (err error) + InsertFinishedRuns func(run []*Run, saveSuccessfulTaskRuns bool, qopts ...pg.QOpt) (err error) + InsertRun func(run *Run, qopts ...pg.QOpt) error + StoreRun func(run *Run, qopts ...pg.QOpt) (restart bool, err error) + UpdateTaskRunResult func(taskID uuid.UUID, result Result) (run Run, start bool, err error) + type ORMConfig interface + JobPipelineMaxSuccessfulRuns func() uint64 + type ObjectParam struct + BoolValue BoolParam + DecimalValue DecimalParam + MapValue MapParam + SliceValue SliceParam + StringValue StringParam + Type ObjectType + func (o *ObjectParam) UnmarshalPipelineParam(val interface{}) error + func (o ObjectParam) Marshal() (string, error) + func (o ObjectParam) MarshalJSON() ([]byte, error) + func (o ObjectParam) String() string + type ObjectType int + const BoolType + const DecimalType + const MapType + const NilType + const SliceType + const StringType + type PanicTask struct + Msg string + func (t *PanicTask) Run(_ context.Context, _ logger.Logger, vars Vars, _ []Result) (result Result, runInfo RunInfo) + func (t *PanicTask) Type() TaskType + type Pipeline struct + Source string + Tasks []Task + func Parse(text string) (*Pipeline, error) + func (p *Pipeline) ByDotID(id string) Task + func (p *Pipeline) MinTimeout() (time.Duration, bool, error) + func (p *Pipeline) RequiresPreInsert() bool + func (p *Pipeline) UnmarshalText(bs []byte) (err error) + type PipelineParamUnmarshaler interface + UnmarshalPipelineParam func(val interface{}) error + type PossibleErrorResponses struct + Error string + ErrorMessage string + type Result struct + Error error + Value interface{} + func (result Result) ErrorDB() null.String + func (result Result) OutputDB() JSONSerializable + type ResumeRequest struct + Error null.String + Value json.RawMessage + func (rr ResumeRequest) ToResult() (Result, error) + type Run struct + AllErrors RunErrors + CreatedAt time.Time + FailSilently bool + FatalErrors RunErrors + FinishedAt null.Time + ID int64 + Inputs JSONSerializable + Meta JSONSerializable + Outputs JSONSerializable + Pending bool + PipelineSpec Spec + PipelineSpecID int32 + PipelineTaskRuns []TaskRun + State RunStatus + func NewRun(spec Spec, vars Vars) Run + func (r *Run) ByDotID(id string) *TaskRun + func (r *Run) SetID(value string) error + func (r *Run) Status() RunStatus + func (r *Run) StringAllErrors() []*string + func (r *Run) StringFatalErrors() []*string + func (r *Run) StringOutputs() ([]*string, error) + func (r Run) GetID() string + func (r Run) HasErrors() bool + func (r Run) HasFatalErrors() bool + type RunErrors []null.String + func (re *RunErrors) Scan(value interface{}) error + func (re RunErrors) HasError() bool + func (re RunErrors) ToError() error + func (re RunErrors) Value() (driver.Value, error) + type RunInfo struct + IsPending bool + IsRetryable bool + type RunStatus string + const RunStatusCompleted + const RunStatusErrored + const RunStatusRunning + const RunStatusSuspended + const RunStatusUnknown + func (s RunStatus) Completed() bool + func (s RunStatus) Errored() bool + func (s RunStatus) Finished() bool + type Runner interface + ExecuteAndInsertFinishedRun func(ctx context.Context, spec Spec, vars Vars, l logger.Logger, ...) (runID int64, finalResult FinalResult, err error) + ExecuteRun func(ctx context.Context, spec Spec, vars Vars, l logger.Logger) (run Run, trrs TaskRunResults, err error) + InsertFinishedRun func(run *Run, saveSuccessfulTaskRuns bool, qopts ...pg.QOpt) error + InsertFinishedRuns func(runs []*Run, saveSuccessfulTaskRuns bool, qopts ...pg.QOpt) error + OnRunFinished func(func(*Run)) + ResumeRun func(taskID uuid.UUID, value interface{}, err error) error + Run func(ctx context.Context, run *Run, l logger.Logger, saveSuccessfulTaskRuns bool, ...) (incomplete bool, err error) + type SliceParam []interface + func (s *SliceParam) UnmarshalPipelineParam(val interface{}) error + func (s SliceParam) FilterErrors() (SliceParam, int) + type Spec struct + CreatedAt time.Time + DotDagSource string + ForwardingAllowed bool + GasLimit *uint32 + ID int32 + JobID int32 + JobName string + JobType string + MaxTaskDuration models.Interval + func (s Spec) Pipeline() (*Pipeline, error) + type StringParam string + func (s *StringParam) String() string + func (s *StringParam) UnmarshalPipelineParam(val interface{}) error + type StringSliceParam []string + func (s *StringSliceParam) UnmarshalPipelineParam(val interface{}) error + type SumTask struct + AllowedFaults string + Values string + func (t *SumTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *SumTask) Type() TaskType + type Task interface + Base func() *BaseTask + DotID func() string + ID func() int + Inputs func() []TaskDependency + OutputIndex func() int32 + Outputs func() []Task + Run func(ctx context.Context, lggr logger.Logger, vars Vars, inputs []Result) (Result, RunInfo) + TaskMaxBackoff func() time.Duration + TaskMinBackoff func() time.Duration + TaskRetries func() uint32 + TaskTimeout func() (time.Duration, bool) + Type func() TaskType + func UnmarshalTaskFromMap(taskType TaskType, taskMap interface{}, ID int, dotID string) (_ Task, err error) + type TaskDependency struct + InputTask Task + PropagateResult bool + type TaskRun struct + CreatedAt time.Time + DotID string + Error null.String + FinishedAt null.Time + ID uuid.UUID + Index int32 + Output JSONSerializable + PipelineRun Run + PipelineRunID int64 + Type TaskType + func (tr *TaskRun) IsPending() bool + func (tr *TaskRun) SetID(value string) error + func (tr TaskRun) GetDotID() string + func (tr TaskRun) GetID() string + func (tr TaskRun) Result() Result + type TaskRunResult struct + Attempts uint + CreatedAt time.Time + FinishedAt null.Time + ID uuid.UUID + Result Result + Task Task + TaskRun TaskRun + func (result *TaskRunResult) IsPending() bool + func (result *TaskRunResult) IsTerminal() bool + type TaskRunResults []TaskRunResult + func (trrs *TaskRunResults) GetNextTaskOf(task TaskRunResult) *TaskRunResult + func (trrs TaskRunResults) FinalResult(l logger.Logger) FinalResult + type TaskType string + const TaskTypeAny + const TaskTypeBase64Decode + const TaskTypeBase64Encode + const TaskTypeBridge + const TaskTypeCBORParse + const TaskTypeConditional + const TaskTypeDivide + const TaskTypeETHABIDecode + const TaskTypeETHABIDecodeLog + const TaskTypeETHABIEncode + const TaskTypeETHABIEncode2 + const TaskTypeETHCall + const TaskTypeETHGetBlock + const TaskTypeETHTx + const TaskTypeEstimateGasLimit + const TaskTypeFail + const TaskTypeHTTP + const TaskTypeHexDecode + const TaskTypeHexEncode + const TaskTypeJSONParse + const TaskTypeLength + const TaskTypeLessThan + const TaskTypeLookup + const TaskTypeLowercase + const TaskTypeMean + const TaskTypeMedian + const TaskTypeMemo + const TaskTypeMerge + const TaskTypeMode + const TaskTypeMultiply + const TaskTypePanic + const TaskTypeSum + const TaskTypeUppercase + const TaskTypeVRF + const TaskTypeVRFV2 + func (t TaskType) String() string + type URLParam url.URL + func (u *URLParam) String() string + func (u *URLParam) UnmarshalPipelineParam(val interface{}) error + type Uint64Param uint64 + func (u *Uint64Param) UnmarshalPipelineParam(val interface{}) error + type UppercaseTask struct + Input string + func (t *UppercaseTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *UppercaseTask) Type() TaskType + type VRFKeyStore interface + GenerateProof func(id string, seed *big.Int) (vrfkey.Proof, error) + type VRFTask struct + PublicKey string + RequestBlockHash string + RequestBlockNumber string + Topics string + func (t *VRFTask) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *VRFTask) Type() TaskType + type VRFTaskV2 struct + PublicKey string + RequestBlockHash string + RequestBlockNumber string + Topics string + func (t *VRFTaskV2) Run(_ context.Context, _ logger.Logger, vars Vars, inputs []Result) (result Result, runInfo RunInfo) + func (t *VRFTaskV2) Type() TaskType + type Vars struct + func NewVarsFrom(m map[string]interface{}) Vars + func (vars Vars) Copy() Vars + func (vars Vars) Get(keypathStr string) (interface{}, error) + func (vars Vars) Set(dotID string, value interface{}) error