models

package
v0.8.11 Latest Latest
Warning

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

Go to latest
Published: Jul 27, 2020 License: MIT Imports: 39 Imported by: 31

Documentation

Overview

Package models contain the key job components used by the Chainlink application.

Common

Common contains types and functions that are useful across the application. Particularly dealing with the URL field, dates, and time.

Eth

Eth creates transactions and tracks transaction attempts on the Ethereum blockchain.

JobSpec

A JobSpec is the largest unit of work that a Chainlink node can take on. It will have Initiators, which is how a JobRun is started from the job definition, and Tasks, which are the specific instructions for what work needs to be performed. The BridgeType is also located here, and is used to define the location (URL) of external adapters.

ORM

The ORM is the wrapper around the database. It gives a limited set of functions to allow for safe storing and withdrawing of information.

Run

A Run is the actual invocation of work being done on the Job and Task. This comprises of JobRuns and TaskRuns. A JobRun is like a workflow where the steps are the TaskRuns.

i.e. We have a Scheduler Initiator that creates a JobRun every monday based on a JobDefinition. And in turn, those JobRuns have TaskRuns based on the JobDefinition's TaskDefinitions.

Index

Constants

View Source
const (
	// RunStatusUnstarted is the default state of any run status.
	RunStatusUnstarted = RunStatus("unstarted")
	// RunStatusInProgress is used for when a run is actively being executed.
	RunStatusInProgress = RunStatus("in_progress")
	// RunStatusPendingIncomingConfirmations is used for when a run is awaiting for incoming block confirmations
	// e.g. waiting for the log event to be N blocks deep
	RunStatusPendingIncomingConfirmations = RunStatus("pending_incoming_confirmations")
	// RunStatusPendingConnection states that the run is waiting on a connection to the block chain.
	RunStatusPendingConnection = RunStatus("pending_connection")
	// RunStatusPendingBridge is used for when a run is waiting on the completion
	// of another event.
	RunStatusPendingBridge = RunStatus("pending_bridge")
	// RunStatusPendingSleep is used for when a run is waiting on a sleep function to finish.
	RunStatusPendingSleep = RunStatus("pending_sleep")
	// RunStatusPendingOutgoingConfirmations is used for when a run is waiting for outgoing block confirmations
	// e.g. we have sent a transaction using ethtx and are now waiting for it to be N blocks deep
	RunStatusPendingOutgoingConfirmations = RunStatus("pending_outgoing_confirmations")
	// RunStatusErrored is used for when a run has errored and will not complete.
	RunStatusErrored = RunStatus("errored")
	// RunStatusCompleted is used for when a run has successfully completed execution.
	RunStatusCompleted = RunStatus("completed")
	// RunStatusCancelled is used to indicate a run is no longer desired.
	RunStatusCancelled = RunStatus("cancelled")
)
View Source
const (
	EthTxUnstarted   = EthTxState("unstarted")
	EthTxInProgress  = EthTxState("in_progress")
	EthTxFatalError  = EthTxState("fatal_error")
	EthTxUnconfirmed = EthTxState("unconfirmed")
	EthTxConfirmed   = EthTxState("confirmed")

	EthTxAttemptInProgress = EthTxAttemptState("in_progress")
	EthTxAttemptBroadcast  = EthTxAttemptState("broadcast")
)
View Source
const (
	// InitiatorRunLog for tasks in a job to watch an ethereum address
	// and expect a JSON payload from a log event.
	InitiatorRunLog = "runlog"
	// InitiatorCron for tasks in a job to be ran on a schedule.
	InitiatorCron = "cron"
	// InitiatorEthLog for tasks in a job to use the Ethereum blockchain.
	InitiatorEthLog = "ethlog"
	// InitiatorRunAt for tasks in a job to be ran once.
	InitiatorRunAt = "runat"
	// InitiatorWeb for tasks in a job making a web request.
	InitiatorWeb = "web"
	// InitiatorServiceAgreementExecutionLog for tasks in a job to watch a
	// Solidity Coordinator contract and expect a payload from a log event.
	InitiatorServiceAgreementExecutionLog = "execagreement"
	// InitiatorExternal for tasks in a job to be trigger by an external party.
	InitiatorExternal = "external"
	// InitiatorFluxMonitor for tasks in a job to be run on price deviation
	// or request for a new round of prices.
	InitiatorFluxMonitor = "fluxmonitor"
	// InitiatorRandomnessLog for tasks from a VRF specific contract
	InitiatorRandomnessLog = "randomnesslog"
)

Types of Initiators (see Initiator struct just below.)

View Source
const (
	RequestLogTopicSignature = iota
	RequestLogTopicJobID
	RequestLogTopicRequester
	RequestLogTopicPayment
)

Descriptive indices of a RunLog's Topic array

View Source
const FunctionSelectorLength = 4

FunctionSelectorLength should always be a length of 4 as a byte.

View Source
const (
	MaxBcryptPasswordLength = 50
)

https://security.stackexchange.com/questions/39849/does-bcrypt-have-a-maximum-password-length

View Source
const (
	// SignatureLength is the length of the signature in bytes: v = 1, r = 32, s
	// = 32; v + r + s = 65
	SignatureLength = 65
)

Variables

View Source
var (
	// RunLogTopic20190207withoutIndexes was the new RunRequest filter topic as of 2019-01-28,
	// after renaming Solidity variables, moving data version, and removing the cast of requestId to uint256
	RunLogTopic20190207withoutIndexes = utils.MustHash("OracleRequest(bytes32,address,bytes32,uint256,address,bytes4,uint256,uint256,bytes)")
	// RandomnessRequestLogTopic is the signature for the event log
	// VRFCoordinator.RandomnessRequest.
	RandomnessRequestLogTopic = VRFRandomnessRequestLogTopic()
	// OracleFulfillmentFunctionID20190128withoutCast is the function selector for fulfilling Ethereum requests,
	// as updated on 2019-01-28, removing the cast to uint256 for the requestId.
	OracleFulfillmentFunctionID20190128withoutCast = utils.MustHash("fulfillOracleRequest(bytes32,uint256,address,bytes4,uint256,bytes32)").Hex()[:10]
)
View Source
var ChainlinkFulfilledTopic = utils.MustHash("ChainlinkFulfilled(bytes32)")

ChainlinkFulfilledTopic is the signature for the event emitted after calling ChainlinkClient.validateChainlinkCallback(requestId). See ../../evm-contracts/src/v0.6/ChainlinkClient.sol

View Source
var CronParser cron.Parser

CronParser is the global parser for crontabs. It accepts the standard 5 field cron syntax as well as an optional 6th field at the front to represent seconds.

View Source
var LogBasedChainlinkJobInitiators = []string{InitiatorRunLog, InitiatorEthLog, InitiatorRandomnessLog}

LogBasedChainlinkJobInitiators are initiators which kick off a user-specified chainlink job when an appropriate ethereum log is received. (InitiatorFluxMonitor kicks off work, but not a user-specified job.)

View Source
var TopicsForInitiatorsWhichRequireJobSpecIDTopic = map[string][]common.Hash{
	InitiatorRunLog:        {RunLogTopic20190207withoutIndexes},
	InitiatorRandomnessLog: {RandomnessRequestLogTopic},
}

topicsForInitiatorsWhichRequireJobSpecTopic are the log topics which kick off a user job with the given type of initiator. If chainlink has any jobs with these initiators, it subscribes on startup to logs which match both these topics and some representation of the job spec ID.

View Source
var WeiPerEth = new(big.Int).Exp(big.NewInt(10), big.NewInt(18), nil)

WeiPerEth is amount of Wei currency units in one Eth.

Functions

func AuthenticateBridgeType

func AuthenticateBridgeType(bt *BridgeType, token string) (bool, error)

AuthenticateBridgeType returns true if the passed token matches its IncomingToken, or returns false with an error.

func AuthenticateExternalInitiator

func AuthenticateExternalInitiator(eia *auth.Token, ea *ExternalInitiator) (bool, error)

AuthenticateExternalInitiator compares an auth against an initiator and returns true if the password hashes match

func AuthenticateUserByToken added in v0.8.2

func AuthenticateUserByToken(token *auth.Token, user *User) (bool, error)

AuthenticateUserByToken returns true on successful authentication of the user against the given Authentication Token.

func FilterQueryFactory

func FilterQueryFactory(i Initiator, from *big.Int) (q ethereum.FilterQuery, err error)

FilterQueryFactory returns the ethereum FilterQuery for this initiator.

func IDToHexTopic added in v0.6.6

func IDToHexTopic(id *ID) common.Hash

IDToHexTopic encodes the string representation of the ID

func IDToTopic added in v0.6.6

func IDToTopic(id *ID) common.Hash

IDToTopic encodes the bytes representation of the ID padded to fit into a bytes32

func JobSpecIDTopics added in v0.8.2

func JobSpecIDTopics(jsID *ID) []common.Hash

jobSpecIDTopics lists the ways jsID could be represented as a log topic. This allows log subscriptions to respond to all possible representations.

func NewBridgeType

NewBridgeType returns a bridge bridge type authentication (with plaintext password) and a bridge type (with hashed password, for persisting)

func NewDatabaseAccessError

func NewDatabaseAccessError(msg string) error

NewDatabaseAccessError returns a database access error.

func NewValidationError

func NewValidationError(msg string, values ...interface{}) error

NewValidationError returns a validation error.

func VRFCoordinatorABI added in v0.8.8

func VRFCoordinatorABI() abi.ABI

VRFCoordinatorABI returns the ABI for the VRFCoordinator contract

func VRFFulfillMethod added in v0.8.8

func VRFFulfillMethod() abi.Method

VRFFulfillMethod returns the golang abstraction of the fulfillRandomnessRequest method

func VRFFulfillSelector added in v0.8.8

func VRFFulfillSelector() string

VRFFulfillSelector returns the signature of the fulfillRandomnessRequest method on the VRFCoordinator contract

func VRFRandomnessRequestLogTopic added in v0.8.8

func VRFRandomnessRequestLogTopic() common.Hash

VRFRandomnessRequestLogTopic returns the signature of the RandomnessRequest log emitted by the VRFCoordinator contract

func ValidateBulkDeleteRunRequest

func ValidateBulkDeleteRunRequest(request *BulkDeleteRunRequest) error

ValidateBulkDeleteRunRequest returns a task from a request to make a task

Types

type AddressCollection

type AddressCollection []common.Address

AddressCollection is an array of common.Address serializable to and from a database.

func (*AddressCollection) Scan

func (r *AddressCollection) Scan(value interface{}) error

Scan parses the database value as a string.

func (AddressCollection) ToStrings

func (r AddressCollection) ToStrings() []string

ToStrings returns this address collection as an array of strings.

func (AddressCollection) Value

func (r AddressCollection) Value() (driver.Value, error)

Value returns the string value to be written to the database.

type AnyTime

type AnyTime struct {
	time.Time
	Valid bool
}

AnyTime holds a common field for time, and serializes it as a json number.

func NewAnyTime

func NewAnyTime(t time.Time) AnyTime

NewAnyTime creates a new Time.

func (AnyTime) MarshalJSON

func (t AnyTime) MarshalJSON() ([]byte, error)

MarshalJSON implements json.Marshaler. It will encode null if this time is null.

func (AnyTime) MarshalText

func (t AnyTime) MarshalText() ([]byte, error)

MarshalText returns null if not set, or the time.

func (*AnyTime) Scan

func (t *AnyTime) Scan(value interface{}) error

Scan reads the database value and returns an instance.

func (*AnyTime) UnmarshalJSON

func (t *AnyTime) UnmarshalJSON(b []byte) error

UnmarshalJSON parses the raw time stored in JSON-encoded data and stores it to the Time field.

func (*AnyTime) UnmarshalText

func (t *AnyTime) UnmarshalText(text []byte) error

UnmarshalText parses null or a valid time.

func (AnyTime) Value

func (t AnyTime) Value() (driver.Value, error)

Value returns this instance serialized for database storage.

type Block added in v0.8.8

type Block struct {
	Number       hexutil.Uint64 `json:"number"`
	Transactions []Transaction  `json:"transactions"`
}

Block represents a full block See: https://github.com/ethereum/go-ethereum/blob/0e6ea9199ca701ee4c96220e873884327c8d18ff/core/types/block.go#L147

type BridgeRunResult

type BridgeRunResult struct {
	Data            JSON        `json:"data"`
	Status          RunStatus   `json:"status"`
	ErrorMessage    null.String `json:"error"`
	ExternalPending bool        `json:"pending"`
	AccessToken     string      `json:"accessToken"`
}

BridgeRunResult handles the parsing of RunResults from external adapters.

func (BridgeRunResult) GetError added in v0.8.2

func (brr BridgeRunResult) GetError() error

GetError returns the error of a BridgeRunResult if it is present.

func (BridgeRunResult) HasError added in v0.8.2

func (brr BridgeRunResult) HasError() bool

HasError returns true if the status is errored or the error message is set

func (*BridgeRunResult) UnmarshalJSON

func (brr *BridgeRunResult) UnmarshalJSON(input []byte) error

UnmarshalJSON parses the given input and updates the BridgeRunResult in the external adapter format.

type BridgeType

type BridgeType struct {
	Name                   TaskType     `json:"name" gorm:"primary_key"`
	URL                    WebURL       `json:"url"`
	Confirmations          uint32       `json:"confirmations"`
	IncomingTokenHash      string       `json:"-"`
	Salt                   string       `json:"-"`
	OutgoingToken          string       `json:"outgoingToken"`
	MinimumContractPayment *assets.Link `json:"minimumContractPayment" gorm:"type:varchar(255)"`
	CreatedAt              time.Time    `json:"-"`
	UpdatedAt              time.Time    `json:"-"`
}

BridgeType is used for external adapters and has fields for the name of the adapter and its URL.

func (BridgeType) GetID

func (bt BridgeType) GetID() string

GetID returns the ID of this structure for jsonapi serialization.

func (BridgeType) GetName

func (bt BridgeType) GetName() string

GetName returns the pluralized "type" of this structure for jsonapi serialization.

func (*BridgeType) SetID

func (bt *BridgeType) SetID(value string) error

SetID is used to set the ID of this structure when deserializing from jsonapi documents.

type BridgeTypeAuthentication

type BridgeTypeAuthentication struct {
	Name                   TaskType     `json:"name"`
	URL                    WebURL       `json:"url"`
	Confirmations          uint32       `json:"confirmations"`
	IncomingToken          string       `json:"incomingToken"`
	OutgoingToken          string       `json:"outgoingToken"`
	MinimumContractPayment *assets.Link `json:"minimumContractPayment"`
}

BridgeTypeAuthentication is the record returned in response to a request to create a BridgeType

func (BridgeTypeAuthentication) GetID

func (bt BridgeTypeAuthentication) GetID() string

GetID returns the ID of this structure for jsonapi serialization.

func (BridgeTypeAuthentication) GetName

func (bt BridgeTypeAuthentication) GetName() string

GetName returns the pluralized "type" of this structure for jsonapi serialization.

func (*BridgeTypeAuthentication) SetID

func (bt *BridgeTypeAuthentication) SetID(value string) error

SetID is used to set the ID of this structure when deserializing from jsonapi documents.

type BridgeTypeRequest

type BridgeTypeRequest struct {
	Name                   TaskType     `json:"name"`
	URL                    WebURL       `json:"url"`
	Confirmations          uint32       `json:"confirmations"`
	MinimumContractPayment *assets.Link `json:"minimumContractPayment"`
}

BridgeTypeRequest is the incoming record used to create a BridgeType

func (BridgeTypeRequest) GetID

func (bt BridgeTypeRequest) GetID() string

GetID returns the ID of this structure for jsonapi serialization.

func (BridgeTypeRequest) GetName

func (bt BridgeTypeRequest) GetName() string

GetName returns the pluralized "type" of this structure for jsonapi serialization.

func (*BridgeTypeRequest) SetID

func (bt *BridgeTypeRequest) SetID(value string) error

SetID is used to set the ID of this structure when deserializing from jsonapi documents.

type BulkDeleteRunRequest

type BulkDeleteRunRequest struct {
	ID            uint                `gorm:"primary_key"`
	Status        RunStatusCollection `json:"status" gorm:"type:text"`
	UpdatedBefore time.Time           `json:"updatedBefore"`
}

BulkDeleteRunRequest describes the query for deletion of runs

type ChangeAuthTokenRequest added in v0.8.2

type ChangeAuthTokenRequest struct {
	Password string `json:"password"`
}

Changeauth.TokenRequest is sent when updating a User's authentication token.

type ChangePasswordRequest

type ChangePasswordRequest struct {
	OldPassword string `json:"oldPassword"`
	NewPassword string `json:"newPassword"`
}

ChangePasswordRequest sets a new password for the current Session's User.

type Configuration added in v0.6.6

type Configuration struct {
	ID        int64  `gorm:"primary_key"`
	Name      string `gorm:"not null;unique;index"`
	Value     string `gorm:"not null"`
	CreatedAt time.Time
	UpdatedAt time.Time
	DeletedAt *time.Time
}

Configuration stores key value pairs for overriding global configuration

type CreateKeyRequest

type CreateKeyRequest struct {
	CurrentPassword string `json:"current_password"`
}

CreateKeyRequest represents a request to add an ethereum key.

type Cron

type Cron string

Cron holds the string that will represent the spec of the cron-job.

func (Cron) String

func (c Cron) String() string

String returns the current Cron spec string.

func (*Cron) UnmarshalJSON

func (c *Cron) UnmarshalJSON(b []byte) error

UnmarshalJSON parses the raw spec stored in JSON-encoded data and stores it to the Cron string.

type DatabaseAccessError

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

DatabaseAccessError is an error that occurs during database access.

func (*DatabaseAccessError) Error

func (e *DatabaseAccessError) Error() string

type Duration added in v0.8.2

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

Duration is a non-negative time duration.

func MakeDuration added in v0.8.3

func MakeDuration(d time.Duration) (Duration, error)

func MustMakeDuration added in v0.8.3

func MustMakeDuration(d time.Duration) Duration

func (Duration) Before added in v0.8.3

func (d Duration) Before(t time.Time) time.Time

Before returns the time d units before time t

func (Duration) Duration added in v0.8.2

func (d Duration) Duration() time.Duration

Duration returns the value as the standard time.Duration value.

func (Duration) IsInstant added in v0.8.3

func (d Duration) IsInstant() bool

IsInstant is true if and only if d is of duration 0

func (Duration) MarshalJSON added in v0.8.2

func (d Duration) MarshalJSON() ([]byte, error)

MarshalJSON implements the json.Marshaler interface.

func (*Duration) Scan added in v0.8.3

func (d *Duration) Scan(v interface{}) (err error)

func (Duration) Shorter added in v0.8.3

func (d Duration) Shorter(od Duration) bool

Shorter returns true if and only if d is shorter than od.

func (Duration) String added in v0.8.2

func (d Duration) String() string

String returns a string representing the duration in the form "72h3m0.5s". Leading zero units are omitted. As a special case, durations less than one second format use a smaller unit (milli-, micro-, or nanoseconds) to ensure that the leading digit is non-zero. The zero duration formats as 0s.

func (*Duration) UnmarshalJSON added in v0.8.2

func (d *Duration) UnmarshalJSON(input []byte) error

UnmarshalJSON implements the json.Unmarshaler interface.

func (Duration) Value added in v0.8.3

func (d Duration) Value() (driver.Value, error)

type EIP55Address

type EIP55Address string

EIP55Address is a newtype for string which persists an ethereum address in its original string representation which includes a leading 0x, and EIP55 checksum which is represented by the case of digits A-F.

func NewEIP55Address

func NewEIP55Address(s string) (EIP55Address, error)

NewEIP55Address creates an EIP55Address from a string, an error is returned if:

1) There is no leading 0x 2) The length is wrong 3) There are any non hexadecimal characters 4) The checksum fails

func (EIP55Address) Address

func (a EIP55Address) Address() common.Address

Address returns EIP55Address as a go-ethereum Address type

func (EIP55Address) Big

func (a EIP55Address) Big() *big.Int

Big returns a big.Int representation

func (EIP55Address) Bytes

func (a EIP55Address) Bytes() []byte

Bytes returns the raw bytes

func (EIP55Address) Format

func (a EIP55Address) Format(s fmt.State, c rune)

Format implements fmt.Formatter

func (EIP55Address) Hash

func (a EIP55Address) Hash() common.Hash

Hash returns the Hash

func (EIP55Address) Hex added in v0.8.11

func (a EIP55Address) Hex() string

Hex is idential to String but makes the API similar to common.Address

func (*EIP55Address) Scan

func (a *EIP55Address) Scan(value interface{}) error

Scan reads the database value and returns an instance.

func (EIP55Address) String

func (a EIP55Address) String() string

String implements the stringer interface and is used also by the logger.

func (*EIP55Address) UnmarshalJSON

func (a *EIP55Address) UnmarshalJSON(input []byte) error

UnmarshalJSON parses a hash from a JSON string

func (*EIP55Address) UnmarshalText

func (a *EIP55Address) UnmarshalText(input []byte) error

UnmarshalText parses a hash from plain text

func (EIP55Address) Value

func (a EIP55Address) Value() (driver.Value, error)

Value returns this instance serialized for database storage.

type EIP55AddressCollection

type EIP55AddressCollection []EIP55Address

EIP55AddressCollection is an array of EIP55Addresses.

func (*EIP55AddressCollection) Scan

func (c *EIP55AddressCollection) Scan(value interface{}) error

Scan reads the database value and returns an instance.

func (EIP55AddressCollection) Value

Value returns this instance serialized for database storage.

type Encumbrance

type Encumbrance struct {
	// Corresponds to requestDigest in solidity ServiceAgreement struct
	ID int64 `json:"-" gorm:"primary_key;auto_increment"`
	// Price to request a report based on this agreement
	Payment *assets.Link `json:"payment,omitempty"`
	// Expiration is the amount of time an oracle has to answer a request
	Expiration uint64 `json:"expiration"`
	// Agreement is valid until this time
	EndAt AnyTime `json:"endAt"`
	// Addresses of oracles committed to this agreement
	Oracles EIP55AddressCollection `json:"oracles" gorm:"type:text"`
	// Address of aggregator contract
	Aggregator EIP55Address `json:"aggregator" gorm:"not null"`
	// selector for initialization method on aggregator contract
	AggInitiateJobSelector FunctionSelector `json:"aggInitiateJobSelector" gorm:"not null"`
	// selector for fulfillment (oracle reporting) method on aggregator contract
	AggFulfillSelector FunctionSelector `json:"aggFulfillSelector" gorm:"not null"`
	CreatedAt          time.Time        `json:"-"`
	UpdatedAt          time.Time        `json:"-"`
}

Encumbrance connects job specifications with on-chain encumbrances.

func (Encumbrance) ABI

func (e Encumbrance) ABI(digest common.Hash) ([]byte, error)

ABI packs the encumberance as a byte array using the same rules as the abi.encodePacked in Coordinator#getId.

Used only for constructing a stable hash which will be signed by all oracles, so it does not have to be easily parsed or unambiguous (e.g., re-ordering Oracles will result in different output.) It just has to be an injective function.

type EthLogEvent

type EthLogEvent struct {
	InitiatorLogEvent
}

EthLogEvent provides functionality specific to a log event emitted for an eth log initiator.

type EthReceipt added in v0.8.7

type EthReceipt struct {
	ID               int64
	TxHash           common.Hash
	BlockHash        common.Hash
	BlockNumber      int64
	TransactionIndex uint
	Receipt          []byte
	CreatedAt        time.Time
}

type EthTaskRunTx added in v0.8.7

type EthTaskRunTx struct {
	TaskRunID uuid.UUID
	EthTxID   int64
	EthTx     EthTx
}

type EthTx added in v0.8.7

type EthTx struct {
	ID             int64
	Nonce          *int64
	FromAddress    common.Address
	ToAddress      common.Address
	EncodedPayload []byte
	Value          assets.Eth
	GasLimit       uint64
	Error          *string
	BroadcastAt    *time.Time
	CreatedAt      time.Time
	State          EthTxState
	EthTxAttempts  []EthTxAttempt `gorm:"association_autoupdate:false;association_autocreate:false"`
}

func (EthTx) GetError added in v0.8.7

func (e EthTx) GetError() error

func (EthTx) GetID added in v0.8.8

func (e EthTx) GetID() string

GetID allows EthTx to be used as jsonapi.MarshalIdentifier

type EthTxAttempt added in v0.8.7

type EthTxAttempt struct {
	ID                      int64
	EthTxID                 int64
	EthTx                   EthTx
	GasPrice                utils.Big
	SignedRawTx             []byte
	Hash                    common.Hash
	CreatedAt               time.Time
	BroadcastBeforeBlockNum *int64
	State                   EthTxAttemptState
	EthReceipts             []EthReceipt `gorm:"foreignkey:TxHash;association_foreignkey:Hash;association_autoupdate:false;association_autocreate:false"`
}

func (EthTxAttempt) GetSignedTx added in v0.8.7

func (a EthTxAttempt) GetSignedTx() (*types.Transaction, error)

GetSignedTx decodes the SignedRawTx into a types.Transaction struct

type EthTxAttemptState added in v0.8.7

type EthTxAttemptState string

type EthTxState added in v0.8.7

type EthTxState string

type ExternalInitiator

type ExternalInitiator struct {
	ID             int64   `gorm:"primary_key"`
	Name           string  `gorm:"not null;unique"`
	URL            *WebURL `gorm:"url,omitempty"`
	AccessKey      string  `gorm:"not null"`
	Salt           string  `gorm:"not null"`
	HashedSecret   string  `gorm:"not null"`
	OutgoingSecret string  `gorm:"not null"`
	OutgoingToken  string  `gorm:"not null"`

	CreatedAt time.Time
	UpdatedAt time.Time
}

ExternalInitiator represents a user that can initiate runs remotely

func NewExternalInitiator

func NewExternalInitiator(
	eia *auth.Token,
	eir *ExternalInitiatorRequest,
) (*ExternalInitiator, error)

NewExternalInitiator generates an ExternalInitiator from an auth.Token, hashing the password for storage

type ExternalInitiatorRequest added in v0.6.6

type ExternalInitiatorRequest struct {
	Name string  `json:"name"`
	URL  *WebURL `json:"url,omitempty"`
}

ExternalInitiatorRequest is the incoming record used to create an ExternalInitiator.

type Feeds added in v0.8.2

type Feeds = JSON

Feeds holds the json of the feeds parameter in the job spec. It is an array of URL strings and/or objects containing the names of bridges

type FluxMonitorRoundStats added in v0.8.6

type FluxMonitorRoundStats struct {
	ID              uint64         `gorm:"primary key;not null;auto_increment"`
	Aggregator      common.Address `gorm:"not null"`
	RoundID         uint32         `gorm:"not null"`
	NumNewRoundLogs uint64         `gorm:"not null;default 0"`
	NumSubmissions  uint64         `gorm:"not null;default 0"`
}

type FunctionSelector

type FunctionSelector [FunctionSelectorLength]byte

FunctionSelector is the first four bytes of the call data for a function call and specifies the function to be called.

func BytesToFunctionSelector

func BytesToFunctionSelector(b []byte) FunctionSelector

BytesToFunctionSelector converts the given bytes to a FunctionSelector.

func HexToFunctionSelector

func HexToFunctionSelector(s string) FunctionSelector

HexToFunctionSelector converts the given string to a FunctionSelector.

func (FunctionSelector) Bytes

func (f FunctionSelector) Bytes() []byte

Bytes returns the FunctionSelector as a byte slice

func (FunctionSelector) MarshalJSON added in v0.6.8

func (f FunctionSelector) MarshalJSON() ([]byte, error)

MarshalJSON returns the JSON encoding of f

func (FunctionSelector) Scan added in v0.6.8

func (f FunctionSelector) Scan(value interface{}) error

Scan returns the selector from its serialization in the database

func (*FunctionSelector) SetBytes

func (f *FunctionSelector) SetBytes(b []byte)

SetBytes sets the FunctionSelector to that of the given bytes (will trim).

func (FunctionSelector) String

func (f FunctionSelector) String() string

String returns the FunctionSelector as a string type.

func (*FunctionSelector) UnmarshalJSON

func (f *FunctionSelector) UnmarshalJSON(input []byte) error

UnmarshalJSON parses the raw FunctionSelector and sets the FunctionSelector type to the given input.

func (FunctionSelector) Value added in v0.6.8

func (f FunctionSelector) Value() (driver.Value, error)

Value returns this instance serialized for database storage

func (FunctionSelector) WithoutPrefix

func (f FunctionSelector) WithoutPrefix() string

WithoutPrefix returns the FunctionSelector as a string without the '0x' prefix.

type Head struct {
	ID         uint64
	Hash       common.Hash
	Number     int64
	ParentHash common.Hash
	Parent     *Head
	Timestamp  time.Time
	CreatedAt  time.Time
}

Head represents a BlockNumber, BlockHash.

func NewHead

func NewHead(number *big.Int, blockHash common.Hash, parentHash common.Hash, timestamp uint64) Head

NewHead returns a Head instance.

func NewHeadFromBlockHeader added in v0.8.8

func NewHeadFromBlockHeader(h types.Header) Head

NewHeadFromBlockHeader returns a new Head from geth's types.Header

func (Head) ChainLength added in v0.8.7

func (h Head) ChainLength() uint32

ChainLength returns the length of the chain followed by recursively looking up parents

func (Head) EarliestInChain added in v0.8.7

func (h Head) EarliestInChain() Head

EarliestInChain recurses through parents until it finds the earliest one

func (*Head) GreaterThan

func (h *Head) GreaterThan(r *Head) bool

GreaterThan compares BlockNumbers and returns true if the receiver BlockNumber is greater than the supplied BlockNumber

func (*Head) NextInt

func (h *Head) NextInt() *big.Int

NextInt returns the next BlockNumber as big.int, or nil if nil to represent latest.

func (*Head) String

func (h *Head) String() string

String returns a string representation of this number.

func (*Head) ToInt

func (h *Head) ToInt() *big.Int

ToInt return the height as a *big.Int. Also handles nil by returning nil.

type ID added in v0.6.6

type ID uuid.UUID

ID is a UUID that has a custom display format

func NewID added in v0.6.6

func NewID() *ID

NewID returns a new ID

func NewIDFromString added in v0.6.6

func NewIDFromString(input string) (*ID, error)

NewIDFromString is a convenience function to return an id from an input string

func (*ID) Bytes added in v0.6.6

func (id *ID) Bytes() []byte

Bytes returns the raw bytes of the underlying UUID

func (*ID) MarshalText added in v0.6.6

func (id *ID) MarshalText() ([]byte, error)

MarshalText implements encoding.TextMarshaler, using String()

func (*ID) Scan added in v0.6.6

func (id *ID) Scan(value interface{}) error

Scan reads the database value and returns an instance.

func (*ID) String added in v0.6.6

func (id *ID) String() string

String satisfies the Stringer interface and removes all '-'s from the string representation of the uuid

func (ID) UUID added in v0.8.7

func (id ID) UUID() uuid.UUID

UUID converts it back into a uuid.UUID

func (*ID) UnmarshalString added in v0.6.6

func (id *ID) UnmarshalString(input string) error

UnmarshalString is a wrapper for UnmarshalText which takes a string

func (*ID) UnmarshalText added in v0.6.6

func (id *ID) UnmarshalText(input []byte) error

UnmarshalText implements encoding.TextUnmarshaler.

func (*ID) Value added in v0.6.6

func (id *ID) Value() (driver.Value, error)

Value returns this instance serialized for database storage.

type IdleTimerConfig added in v0.8.4

type IdleTimerConfig struct {
	Disabled bool     `json:"disabled,omitempty"`
	Duration Duration `json:"duration,omitempty"`
}

func (*IdleTimerConfig) Scan added in v0.8.4

func (itc *IdleTimerConfig) Scan(value interface{}) error

Scan is defined so that we can read IdleTimerConfig as JSONB, because of an error with GORM where it has trouble with nested structs as JSONB. See https://github.com/jinzhu/gorm/issues/2704

func (IdleTimerConfig) Value added in v0.8.4

func (itc IdleTimerConfig) Value() (driver.Value, error)

Value is defined so that we can store IdleTimerConfig as JSONB, because of an error with GORM where it has trouble with nested structs as JSONB. See https://github.com/jinzhu/gorm/issues/2704

type Initiator

type Initiator struct {
	ID        int64 `json:"id" gorm:"primary_key;auto_increment"`
	JobSpecID *ID   `json:"jobSpecId"`

	// Type is one of the Initiator* string constants defined just above.
	Type            string    `json:"type" gorm:"index;not null"`
	CreatedAt       time.Time `json:"createdAt" gorm:"index"`
	InitiatorParams `json:"params,omitempty"`
	DeletedAt       null.Time `json:"-" gorm:"index"`
	UpdatedAt       time.Time `json:"-"`
}

Initiator could be thought of as a trigger, defines how a Job can be started, or rather, how a JobRun can be created from a Job. Initiators will have their own unique ID, but will be associated to a parent JobID.

func NewInitiatorFromRequest added in v0.6.8

func NewInitiatorFromRequest(
	initr InitiatorRequest,
	jobSpec JobSpec,
) Initiator

NewInitiatorFromRequest creates an Initiator from the corresponding parameters in a InitiatorRequest

func (Initiator) IsLogInitiated

func (i Initiator) IsLogInitiated() bool

IsLogInitiated Returns true if triggered by event logs.

type InitiatorLogEvent

type InitiatorLogEvent struct {
	Log       Log
	Initiator Initiator
}

InitiatorLogEvent encapsulates all information as a result of a received log from an InitiatorSubscription, and acts as a base struct for other log-initiated events

func (InitiatorLogEvent) BlockNumber

func (le InitiatorLogEvent) BlockNumber() *big.Int

BlockNumber returns the block number for the given InitiatorSubscriptionLogEvent.

func (InitiatorLogEvent) ForLogger

func (le InitiatorLogEvent) ForLogger(kvs ...interface{}) []interface{}

ForLogger formats the InitiatorSubscriptionLogEvent for easy common formatting in logs (trace statements, not ethereum events).

func (InitiatorLogEvent) GetInitiator

func (le InitiatorLogEvent) GetInitiator() Initiator

GetInitiator returns the initiator.

func (InitiatorLogEvent) GetJobSpecID added in v0.8.2

func (le InitiatorLogEvent) GetJobSpecID() *ID

GetJobSpecID returns the associated JobSpecID

func (InitiatorLogEvent) GetLog

func (le InitiatorLogEvent) GetLog() Log

GetLog returns the log.

func (InitiatorLogEvent) JSON

func (le InitiatorLogEvent) JSON() (JSON, error)

JSON returns the eth log as JSON.

func (InitiatorLogEvent) LogRequest

func (le InitiatorLogEvent) LogRequest() LogRequest

LogRequest is a factory method that coerces this log event to the correct type based on Initiator.Type, exposed by the LogRequest interface.

func (InitiatorLogEvent) RunRequest

func (le InitiatorLogEvent) RunRequest() (RunRequest, error)

RunRequest returns a run request instance with the transaction hash, present on all log initiated runs.

func (InitiatorLogEvent) ToDebug

func (le InitiatorLogEvent) ToDebug()

ToDebug prints this event via logger.Debug.

func (InitiatorLogEvent) Validate

func (le InitiatorLogEvent) Validate() bool

Validate returns true, no validation on this log event type.

func (InitiatorLogEvent) ValidateRequester

func (le InitiatorLogEvent) ValidateRequester() error

ValidateRequester returns true since all requests are valid for base initiator log events.

type InitiatorParams

type InitiatorParams struct {
	Schedule   Cron              `json:"schedule,omitempty"`
	Time       AnyTime           `json:"time,omitempty"`
	Ran        bool              `json:"ran,omitempty"`
	Address    common.Address    `json:"address,omitempty" gorm:"index"`
	Requesters AddressCollection `json:"requesters,omitempty" gorm:"type:text"`
	Name       string            `json:"name,omitempty"`
	Body       *JSON             `json:"body,omitempty" gorm:"column:params"`
	FromBlock  *utils.Big        `json:"fromBlock,omitempty" gorm:"type:varchar(255)"`
	ToBlock    *utils.Big        `json:"toBlock,omitempty" gorm:"type:varchar(255)"`
	Topics     Topics            `json:"topics,omitempty"`

	RequestData JSON    `json:"requestData,omitempty" gorm:"type:text"`
	Feeds       Feeds   `json:"feeds,omitempty" gorm:"type:text"`
	Precision   int32   `json:"precision,omitempty" gorm:"type:smallint"`
	Threshold   float32 `json:"threshold,omitempty"`
	// AbsoluteThreshold is the maximum absolute change allowed in a fluxmonitored
	// value before a new round should be kicked off, so that the current value
	// can be reported on-chain.
	AbsoluteThreshold float32         `json:"absoluteThreshold" gorm:"type:float;not null"`
	PollTimer         PollTimerConfig `json:"pollTimer,omitempty" gorm:"type:jsonb"`
	IdleTimer         IdleTimerConfig `json:"idleTimer,omitempty" gorm:"type:jsonb"`
}

InitiatorParams is a collection of the possible parameters that different Initiators may require.

type InitiatorRequest

type InitiatorRequest struct {
	Type            string `json:"type"`
	InitiatorParams `json:"params,omitempty"`
}

InitiatorRequest represents a schema for incoming initiator requests as used by the API.

type JSON

type JSON struct {
	gjson.Result
}

JSON stores the json types string, number, bool, and null. Arrays and Objects are returned as their raw json types.

func Merge added in v0.8.2

func Merge(inputs ...JSON) (JSON, error)

Merge returns a new map with all keys merged from right to left

func ParseCBOR

func ParseCBOR(b []byte) (JSON, error)

ParseCBOR attempts to coerce the input byte array into valid CBOR and then coerces it into a JSON object.

func ParseJSON

func ParseJSON(b []byte) (JSON, error)

ParseJSON attempts to coerce the input byte array into valid JSON and parse it into a JSON object.

func ParseRunLog

func ParseRunLog(log Log) (JSON, error)

ParseRunLog decodes the CBOR in the ABI of the log event.

func (JSON) Add

func (j JSON) Add(insertKey string, insertValue interface{}) (JSON, error)

Add returns a new instance of JSON with the new value added.

func (JSON) AsMap added in v0.8.2

func (j JSON) AsMap() (map[string]interface{}, error)

AsMap returns j as a map

func (JSON) Bytes

func (j JSON) Bytes() []byte

Bytes returns the raw JSON.

func (JSON) CBOR

func (j JSON) CBOR() ([]byte, error)

CBOR returns a bytes array of the JSON map or array encoded to CBOR.

func (JSON) Delete

func (j JSON) Delete(key string) (JSON, error)

Delete returns a new instance of JSON with the specified key removed.

func (JSON) MarshalJSON

func (j JSON) MarshalJSON() ([]byte, error)

MarshalJSON returns the JSON data if it already exists, returns an empty JSON object as bytes if not.

func (JSON) MultiAdd added in v0.8.2

func (j JSON) MultiAdd(keyValues KV) (JSON, error)

MultiAdd returns a new instance of j with the new values added.

func (*JSON) Scan

func (j *JSON) Scan(value interface{}) error

Scan reads the database value and returns an instance.

func (*JSON) UnmarshalJSON

func (j *JSON) UnmarshalJSON(b []byte) error

UnmarshalJSON parses the JSON bytes and stores in the *JSON pointer.

func (JSON) Value

func (j JSON) Value() (driver.Value, error)

Value returns this instance serialized for database storage.

type JSONAPIError

type JSONAPIError struct {
	Detail string `json:"detail"`
}

JSONAPIError is an individual JSONAPI Error.

type JSONAPIErrors

type JSONAPIErrors struct {
	Errors []JSONAPIError `json:"errors"`
}

JSONAPIErrors holds errors conforming to the JSONAPI spec.

func NewJSONAPIErrors

func NewJSONAPIErrors() *JSONAPIErrors

NewJSONAPIErrors creates an instance of JSONAPIErrors, with the intention of managing a collection of them.

func NewJSONAPIErrorsWith

func NewJSONAPIErrorsWith(detail string) *JSONAPIErrors

NewJSONAPIErrorsWith creates an instance of JSONAPIErrors populated with this single detail.

func (*JSONAPIErrors) Add

func (jae *JSONAPIErrors) Add(detail string)

Add adds a new error to JSONAPIErrors with the passed detail.

func (*JSONAPIErrors) CoerceEmptyToNil

func (jae *JSONAPIErrors) CoerceEmptyToNil() error

CoerceEmptyToNil will return nil if JSONAPIErrors has no errors.

func (*JSONAPIErrors) Error

func (jae *JSONAPIErrors) Error() string

Error collapses the collection of errors into a collection of comma separated strings.

func (*JSONAPIErrors) Merge

func (jae *JSONAPIErrors) Merge(e error)

Merge combines the arrays of the passed error if it is of type JSONAPIErrors, otherwise simply adds a single error with the error string as detail.

type JobRun

type JobRun struct {
	ID             *ID          `json:"id" gorm:"primary_key;not null"`
	JobSpecID      *ID          `json:"jobId"`
	Result         RunResult    `json:"result" gorm:"foreignkey:ResultID;association_autoupdate:true;association_autocreate:true"`
	ResultID       clnull.Int64 `json:"-"`
	RunRequest     RunRequest   `json:"-" gorm:"foreignkey:RunRequestID;association_autoupdate:true;association_autocreate:true"`
	RunRequestID   clnull.Int64 `json:"-"`
	Status         RunStatus    `json:"status" gorm:"default:'unstarted'"`
	TaskRuns       []TaskRun    `json:"taskRuns"`
	CreatedAt      time.Time    `json:"createdAt"`
	FinishedAt     null.Time    `json:"finishedAt"`
	UpdatedAt      time.Time    `json:"updatedAt"`
	Initiator      Initiator    `json:"initiator" gorm:"foreignkey:InitiatorID;association_autoupdate:false;association_autocreate:false"`
	InitiatorID    int64        `json:"-"`
	CreationHeight *utils.Big   `json:"creationHeight"`
	ObservedHeight *utils.Big   `json:"observedHeight"`
	DeletedAt      null.Time    `json:"-"`
	Payment        *assets.Link `json:"payment,omitempty"`
}

JobRun tracks the status of a job by holding its TaskRuns and the Result of each Run.

func MakeJobRun added in v0.8.2

func MakeJobRun(job *JobSpec, now time.Time, initiator *Initiator, currentHeight *big.Int, runRequest *RunRequest) JobRun

MakeJobRun returns a new JobRun copy

func (*JobRun) ApplyBridgeRunResult added in v0.8.2

func (jr *JobRun) ApplyBridgeRunResult(result BridgeRunResult)

ApplyBridgeRunResult saves the input from a BridgeAdapter

func (*JobRun) ApplyOutput added in v0.8.2

func (jr *JobRun) ApplyOutput(result RunOutput)

ApplyOutput updates the JobRun's Result and Status

func (*JobRun) Cancel added in v0.8.2

func (jr *JobRun) Cancel()

Cancel sets this run as cancelled, it should no longer be processed.

func (*JobRun) ErrorString added in v0.8.2

func (jr *JobRun) ErrorString() string

ErrorString returns the error as a string if present, otherwise "".

func (JobRun) ForLogger

func (jr JobRun) ForLogger(kvs ...interface{}) []interface{}

ForLogger formats the JobRun for a common formatting in the log.

func (JobRun) GetID

func (jr JobRun) GetID() string

GetID returns the ID of this structure for jsonapi serialization.

func (JobRun) GetName

func (jr JobRun) GetName() string

GetName returns the pluralized "type" of this structure for jsonapi serialization.

func (*JobRun) GetStatus added in v0.8.2

func (jr *JobRun) GetStatus() RunStatus

GetStatus returns the JobRun's RunStatus

func (JobRun) HasError added in v0.8.2

func (jr JobRun) HasError() bool

HasError returns true if this JobRun has errored

func (*JobRun) NextTaskRun

func (jr *JobRun) NextTaskRun() *TaskRun

NextTaskRun returns the next immediate TaskRun in the list of unfinished TaskRuns.

func (*JobRun) NextTaskRunIndex

func (jr *JobRun) NextTaskRunIndex() (int, bool)

NextTaskRunIndex returns the position of the next unfinished task

func (*JobRun) PreviousTaskRun

func (jr *JobRun) PreviousTaskRun() *TaskRun

PreviousTaskRun returns the last task to be processed, if it exists

func (*JobRun) SetError

func (jr *JobRun) SetError(err error)

SetError sets this job run to failed and saves the error message

func (*JobRun) SetID

func (jr *JobRun) SetID(value string) error

SetID is used to set the ID of this structure when deserializing from jsonapi documents.

func (*JobRun) SetStatus added in v0.8.2

func (jr *JobRun) SetStatus(status RunStatus)

SetStatus updates run status.

func (*JobRun) TasksRemain

func (jr *JobRun) TasksRemain() bool

TasksRemain returns true if there are unfinished tasks left for this job run

type JobSpec

type JobSpec struct {
	ID         *ID            `json:"id,omitempty" gorm:"primary_key;not null"`
	CreatedAt  time.Time      `json:"createdAt" gorm:"index"`
	Initiators []Initiator    `json:"initiators"`
	MinPayment *assets.Link   `json:"minPayment,omitempty" gorm:"type:varchar(255)"`
	Tasks      []TaskSpec     `json:"tasks"`
	StartAt    null.Time      `json:"startAt" gorm:"index"`
	EndAt      null.Time      `json:"endAt" gorm:"index"`
	DeletedAt  null.Time      `json:"-" gorm:"index"`
	UpdatedAt  time.Time      `json:"-"`
	Errors     []JobSpecError `json:"-" gorm:"foreignkey:JobSpecID;association_autoupdate:false;association_autocreate:false"`
}

JobSpec is the definition for all the work to be carried out by the node for a given contract. It contains the Initiators, Tasks (which are the individual steps to be carried out), StartAt, EndAt, and CreatedAt fields.

func NewJob

func NewJob() JobSpec

NewJob initializes a new job by generating a unique ID and setting the CreatedAt field to the time of invokation.

func NewJobFromRequest

func NewJobFromRequest(jsr JobSpecRequest) JobSpec

NewJobFromRequest creates a JobSpec from the corresponding parameters in a JobSpecRequest

func (JobSpec) Archived added in v0.8.2

func (j JobSpec) Archived() bool

Archived returns true if the job spec has been soft deleted

func (JobSpec) Ended

func (j JobSpec) Ended(t time.Time) bool

Ended returns true if the job has ended.

func (JobSpec) GetID

func (j JobSpec) GetID() string

GetID returns the ID of this structure for jsonapi serialization.

func (JobSpec) GetName

func (j JobSpec) GetName() string

GetName returns the pluralized "type" of this structure for jsonapi serialization.

func (JobSpec) InitiatorExternal added in v0.6.7

func (j JobSpec) InitiatorExternal(name string) *Initiator

InitiatorExternal finds the Job Spec's Initiator field associated with the External Initiator's name using a case insensitive search.

Returns nil if not found.

func (JobSpec) InitiatorsFor

func (j JobSpec) InitiatorsFor(types ...string) []Initiator

InitiatorsFor returns an array of Initiators for the given list of Initiator types.

func (JobSpec) IsLogInitiated

func (j JobSpec) IsLogInitiated() bool

IsLogInitiated Returns true if any of the job's initiators are triggered by event logs.

func (*JobSpec) SetID

func (j *JobSpec) SetID(value string) error

SetID is used to set the ID of this structure when deserializing from jsonapi documents.

func (JobSpec) Started

func (j JobSpec) Started(t time.Time) bool

Started returns true if the job has started.

type JobSpecError added in v0.8.9

type JobSpecError struct {
	ID          int64     `json:"id"`
	JobSpecID   *ID       `json:"-"`
	Description string    `json:"description"`
	Occurrences uint      `json:"occurrences"`
	CreatedAt   time.Time `json:"createdAt"`
	UpdatedAt   time.Time `json:"updatedAt"`
}

JobSpecError represents an asynchronous error caused by a JobSpec

func NewJobSpecError added in v0.8.9

func NewJobSpecError(jobSpecID *ID, description string) JobSpecError

NewJobSpecError creates a new JobSpecError struct

type JobSpecRequest

type JobSpecRequest struct {
	Initiators []InitiatorRequest `json:"initiators"`
	Tasks      []TaskSpecRequest  `json:"tasks"`
	StartAt    null.Time          `json:"startAt"`
	EndAt      null.Time          `json:"endAt"`
	MinPayment *assets.Link       `json:"minPayment,omitempty"`
}

JobSpecRequest represents a schema for the incoming job spec request as used by the API.

type KV added in v0.8.2

type KV map[string]interface{}

KV represents a key/value pair to be added to a JSON object

type Key

type Key struct {
	ID        int32 `gorm:"primary_key"`
	Address   EIP55Address
	JSON      JSON
	CreatedAt time.Time `json:"-"`
	UpdatedAt time.Time `json:"-"`
	// This is the nonce that should be used for the next transaction.
	// Conceptually equivalent to geth's `PendingNonceAt` but more reliable
	// because we have a better view of our own transactions
	NextNonce *int64
	// LastUsed is the time that the address was last assigned to a transaction
	LastUsed *time.Time
}

Key holds the private key metadata for a given address that is used to unlock said key when given a password.

By default, a key is assumed to represent an ethereum account.

func NewKeyFromFile

func NewKeyFromFile(path string) (Key, error)

NewKeyFromFile creates an instance in memory from a key file on disk.

func (*Key) WriteToDisk

func (k *Key) WriteToDisk(path string) error

WriteToDisk writes this key to disk at the passed path.

type Log

type Log struct {
	// Consensus fields:
	// address of the contract that generated the event
	Address common.Address `json:"address" gencodec:"required"`
	// list of topics provided by the contract.
	Topics []common.Hash `json:"topics" gencodec:"required"`
	// supplied by the contract, usually ABI-encoded
	Data UntrustedBytes `json:"data" gencodec:"required"`

	// Derived fields. These fields are filled in by the node
	// but not secured by consensus.
	// block in which the transaction was included
	BlockNumber uint64 `json:"blockNumber"`
	// hash of the transaction
	TxHash common.Hash `json:"transactionHash"`
	// index of the transaction in the block
	TxIndex uint `json:"transactionIndex"`
	// hash of the block in which the transaction was included
	BlockHash common.Hash `json:"blockHash"`
	// index of the log in the receipt
	Index uint `json:"logIndex"`

	// The Removed field is true if this log was reverted due to a chain reorganisation.
	// You must pay attention to this field if you receive logs through a filter query.
	Removed bool `json:"removed"`
}

Log represents a contract log event. These events are generated by the LOG opcode and stored/indexed by the node. NOTE: This is almost (but not quite) a copy of go-ethereum/core/types.Log, in log.go

func (Log) Copy added in v0.8.8

func (l Log) Copy() Log

Copy creates a deep copy of a log. The LogBroadcaster creates a single websocket subscription for all log events that we're interested in and distributes them to the relevant subscribers elsewhere in the codebase. If a given log needs to be distributed to multiple subscribers while avoiding data races, it's necessary to make copies.

func (Log) GetBlockHash added in v0.8.8

func (l Log) GetBlockHash() common.Hash

GetBlockHash returns the log's blockhash

func (Log) GetIndex added in v0.8.8

func (l Log) GetIndex() uint

GetIndex returns the log's index in the block

func (Log) GetTopic added in v0.8.8

func (l Log) GetTopic(idx uint) (common.Hash, error)

GetTopic returns the hash for the topic at the passed index, or error.

func (Log) MarshalJSON

func (l Log) MarshalJSON() ([]byte, error)

MarshalJSON marshals as JSON.

func (*Log) UnmarshalJSON

func (l *Log) UnmarshalJSON(input []byte) error

UnmarshalJSON unmarshals from JSON.

type LogConsumption added in v0.8.3

type LogConsumption struct {
	ID        uint
	BlockHash common.Hash
	LogIndex  uint
	JobID     *ID
	CreatedAt time.Time
}

A LogConsumption is a unique record indicating that a particular job has already consumed a particular log. This record can be used to prevent consumers from re-processing duplicate logs

func NewLogConsumption added in v0.8.3

func NewLogConsumption(log RawLog, jobID *ID) LogConsumption

NewLogConsumption creates a new LogConsumption

type LogCursor added in v0.8.2

type LogCursor struct {
	Name        string `gorm:"primary_key"`
	Initialized bool   `gorm:"not null;default true"`
	BlockIndex  int64  `gorm:"not null;default 0"`
	LogIndex    int64  `gorm:"not null;default 0"`
}

type LogRequest

type LogRequest interface {
	GetLog() Log
	GetJobSpecID() *ID
	GetInitiator() Initiator

	Validate() bool
	JSON() (JSON, error)
	ToDebug()
	ForLogger(kvs ...interface{}) []interface{}
	ValidateRequester() error
	BlockNumber() *big.Int
	RunRequest() (RunRequest, error)
}

LogRequest is the interface to allow polymorphic functionality of different types of LogEvents. i.e. EthLogEvent, RunLogEvent, OracleLogEvent

type PollTimerConfig added in v0.8.4

type PollTimerConfig struct {
	Disabled bool     `json:"disabled,omitempty"`
	Period   Duration `json:"period,omitempty"`
}

func (*PollTimerConfig) Scan added in v0.8.4

func (ptc *PollTimerConfig) Scan(value interface{}) error

Scan is defined so that we can read PollTimerConfig as JSONB, because of an error with GORM where it has trouble with nested structs as JSONB. See https://github.com/jinzhu/gorm/issues/2704

func (PollTimerConfig) Value added in v0.8.4

func (ptc PollTimerConfig) Value() (driver.Value, error)

Value is defined so that we can store PollTimerConfig as JSONB, because of an error with GORM where it has trouble with nested structs as JSONB. See https://github.com/jinzhu/gorm/issues/2704

type RandomnessLogEvent added in v0.8.2

type RandomnessLogEvent struct{ InitiatorLogEvent }

RandomnessLogEvent provides functionality specific to a log event emitted for a run log initiator.

func (RandomnessLogEvent) JSON added in v0.8.2

func (le RandomnessLogEvent) JSON() (js JSON, err error)

JSON returns the JSON from this RandomnessRequest log, as it will be passed to the Randomn adapter

func (RandomnessLogEvent) Requester added in v0.8.2

func (le RandomnessLogEvent) Requester() common.Address

Requester pulls the requesting address out of the LogEvent's topics.

func (RandomnessLogEvent) RunRequest added in v0.8.2

func (le RandomnessLogEvent) RunRequest() (RunRequest, error)

RunRequest returns a RunRequest instance with all parameters from a run log topic, like RequestID.

func (RandomnessLogEvent) Validate added in v0.8.2

func (le RandomnessLogEvent) Validate() bool

Validate() is true if the contained log is parseable as a RandomnessRequest, and it's from the address specified by the job's initiator. The log filter and the go-ethereum parser should prevent any invalid logs from reacching this point, so Validate emits an error log on failure.

func (RandomnessLogEvent) ValidateRequester added in v0.8.2

func (le RandomnessLogEvent) ValidateRequester() error

ValidateRequester never errors, because the requester is not important to the node's functionality. A requesting contract cannot request the VRF output on behalf of another contract, because the initial input seed is hashed with the requesting contract's address (plus a nonce) to get the actual VRF input.

type RandomnessRequestLog added in v0.8.8

type RandomnessRequestLog struct {
	KeyHash common.Hash
	Seed    *big.Int // uint256
	JobID   common.Hash
	Sender  common.Address
	Fee     *assets.Link // uint256
	Raw     RawRandomnessRequestLog
}

RandomnessRequestLog contains the data for a RandomnessRequest log, represented as compatible golang types.

func ParseRandomnessRequestLog added in v0.8.8

func ParseRandomnessRequestLog(log Log) (*RandomnessRequestLog, error)

ParseRandomnessRequestLog returns the RandomnessRequestLog corresponding to the raw logData

func RawRandomnessRequestLogToRandomnessRequestLog added in v0.8.8

func RawRandomnessRequestLogToRandomnessRequestLog(
	l *RawRandomnessRequestLog) *RandomnessRequestLog

func (*RandomnessRequestLog) Equal added in v0.8.8

Equal(ol) is true iff l is the same log as ol, and both represent valid RandomnessRequest logs.

func (*RandomnessRequestLog) RawData added in v0.8.8

func (l *RandomnessRequestLog) RawData() ([]byte, error)

RawData returns the raw bytes corresponding to l in a solidity log

This serialization does not include the JobID, because that's an indexed field.

func (*RandomnessRequestLog) RequestID added in v0.8.8

func (l *RandomnessRequestLog) RequestID() common.Hash

type RawLog added in v0.8.8

type RawLog interface {
	GetBlockHash() common.Hash
	GetIndex() uint
}

The RawLog interface provides a consistent interface for different log types around the app

type RawRandomnessRequestLog added in v0.8.8

RawRandomnessRequestLog is used to parse a RandomnessRequest log into types go-ethereum knows about.

type RunInput added in v0.8.2

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

RunInput represents the input for performing a Task

func NewRunInput added in v0.8.2

func NewRunInput(jobRunID *ID, taskRunID ID, data JSON, status RunStatus) *RunInput

NewRunInput creates a new RunInput with arbitrary data

func NewRunInputWithResult added in v0.8.2

func NewRunInputWithResult(jobRunID *ID, taskRunID ID, value interface{}, status RunStatus) *RunInput

NewRunInputWithResult creates a new RunInput with a value in the "result" field

func (RunInput) CloneWithData added in v0.8.5

func (ri RunInput) CloneWithData(data JSON) RunInput

func (RunInput) Data added in v0.8.2

func (ri RunInput) Data() JSON

Data returns the RunInput's data

func (RunInput) JobRunID added in v0.8.2

func (ri RunInput) JobRunID() *ID

JobRunID returns this RunInput's JobRunID

func (RunInput) Result added in v0.8.2

func (ri RunInput) Result() gjson.Result

Result returns the result as a gjson object

func (RunInput) ResultString added in v0.8.2

func (ri RunInput) ResultString() (string, error)

ResultString returns the string result of the Data JSON field.

func (RunInput) Status added in v0.8.2

func (ri RunInput) Status() RunStatus

Status returns the RunInput's status

func (RunInput) TaskRunID added in v0.8.5

func (ri RunInput) TaskRunID() ID

TaskRunID returns this RunInput's TaskRunID

type RunLogEvent

type RunLogEvent struct {
	InitiatorLogEvent
}

RunLogEvent provides functionality specific to a log event emitted for a run log initiator.

func (RunLogEvent) JSON

func (le RunLogEvent) JSON() (JSON, error)

JSON decodes the RunLogEvent's data converts it to a JSON object.

func (RunLogEvent) Requester

func (le RunLogEvent) Requester() (common.Address, error)

Requester pulls the requesting address out of the LogEvent's topics.

func (RunLogEvent) RunRequest

func (le RunLogEvent) RunRequest() (RunRequest, error)

RunRequest returns an RunRequest instance with all parameters from a run log topic, like RequestID.

func (RunLogEvent) Validate

func (le RunLogEvent) Validate() bool

Validate returns whether or not the contained log has a properly encoded job id.

func (RunLogEvent) ValidateRequester

func (le RunLogEvent) ValidateRequester() error

ValidateRequester returns true if the requester matches the one associated with the initiator.

type RunOutput added in v0.8.2

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

RunOutput represents the result of performing a Task

func NewRunOutputComplete added in v0.8.2

func NewRunOutputComplete(data JSON) RunOutput

NewRunOutputComplete returns a new RunOutput that is complete and contains raw data

func NewRunOutputCompleteWithResult added in v0.8.2

func NewRunOutputCompleteWithResult(resultVal interface{}) RunOutput

NewRunOutputCompleteWithResult returns a new RunOutput that is complete and contains a result

func NewRunOutputError added in v0.8.2

func NewRunOutputError(err error) RunOutput

NewRunOutputError returns a new RunOutput with an error

func NewRunOutputInProgress added in v0.8.2

func NewRunOutputInProgress(data JSON) RunOutput

NewRunOutputInProgress returns a new RunOutput that indicates the task is still in progress

func NewRunOutputPendingBridge added in v0.8.2

func NewRunOutputPendingBridge() RunOutput

NewRunOutputPendingBridge returns a new RunOutput that indicates the task is still in progress

func NewRunOutputPendingConnection added in v0.8.2

func NewRunOutputPendingConnection() RunOutput

NewRunOutputPendingConnection returns a new RunOutput that indicates the task got disconnected

func NewRunOutputPendingConnectionWithData added in v0.8.2

func NewRunOutputPendingConnectionWithData(data JSON) RunOutput

NewRunOutputPendingConnectionWithData returns a new RunOutput that indicates the task got disconnected but also has some data that needs to be fed in on next invocation

func NewRunOutputPendingOutgoingConfirmationsWithData added in v0.8.4

func NewRunOutputPendingOutgoingConfirmationsWithData(data JSON) RunOutput

NewRunOutputPendingOutgoingConfirmationsWithData returns a new RunOutput that indicates the task is pending outgoing confirmations but also has some data that needs to be fed in on next invocation

func (RunOutput) Data added in v0.8.2

func (ro RunOutput) Data() JSON

Data returns the data held by this RunOutput

func (RunOutput) Error added in v0.8.2

func (ro RunOutput) Error() error

Error returns error for this RunOutput

func (RunOutput) Get added in v0.8.2

func (ro RunOutput) Get(path string) gjson.Result

Get searches for and returns the JSON at the given path.

func (RunOutput) HasError added in v0.8.2

func (ro RunOutput) HasError() bool

HasError returns true if the status is errored or the error message is set

func (RunOutput) Result added in v0.8.2

func (ro RunOutput) Result() gjson.Result

Result returns the result as a gjson object

func (RunOutput) Status added in v0.8.2

func (ro RunOutput) Status() RunStatus

Status returns the status returned from a task

type RunRequest

type RunRequest struct {
	ID            int64 `gorm:"primary_key"`
	RequestID     *common.Hash
	TxHash        *common.Hash
	BlockHash     *common.Hash
	Requester     *common.Address
	CreatedAt     time.Time
	Payment       *assets.Link
	RequestParams JSON `gorm:"default: '{}';not null"`
}

RunRequest stores the fields used to initiate the parent job run.

func NewRunRequest

func NewRunRequest(requestParams JSON) *RunRequest

NewRunRequest returns a new RunRequest instance.

type RunResult

type RunResult struct {
	ID           int64       `json:"-" gorm:"primary_key;auto_increment"`
	Data         JSON        `json:"data" gorm:"type:text"`
	ErrorMessage null.String `json:"error"`
	CreatedAt    time.Time   `json:"-"`
	UpdatedAt    time.Time   `json:"-"`
}

RunResult keeps track of the outcome of a TaskRun or JobRun. It stores the Data and ErrorMessage.

type RunStatus

type RunStatus string

RunStatus is a string that represents the run status

func (RunStatus) CanStart

func (s RunStatus) CanStart() bool

CanStart returns true if the run is ready to begin processed.

func (RunStatus) Cancelled added in v0.8.2

func (s RunStatus) Cancelled() bool

Cancelled returns true if the status is RunStatusCancelled.

func (RunStatus) Completed

func (s RunStatus) Completed() bool

Completed returns true if the status is RunStatusCompleted.

func (RunStatus) Errored

func (s RunStatus) Errored() bool

Errored returns true if the status is RunStatusErrored.

func (RunStatus) Finished

func (s RunStatus) Finished() bool

Finished returns true if the status is final and can't be changed.

func (RunStatus) Pending

func (s RunStatus) Pending() bool

Pending returns true if the status is pending external or confirmations.

func (RunStatus) PendingBridge

func (s RunStatus) PendingBridge() bool

PendingBridge returns true if the status is pending_bridge.

func (RunStatus) PendingConnection

func (s RunStatus) PendingConnection() bool

PendingConnection returns true if the status is pending_connection.

func (RunStatus) PendingIncomingConfirmations added in v0.8.4

func (s RunStatus) PendingIncomingConfirmations() bool

PendingIncomingConfirmations returns true if the status is pending_incoming_confirmations.

func (RunStatus) PendingOutgoingConfirmations added in v0.8.4

func (s RunStatus) PendingOutgoingConfirmations() bool

PendingOutgoingConfirmations returns true if the status is pending_incoming_confirmations.

func (RunStatus) PendingSleep

func (s RunStatus) PendingSleep() bool

PendingSleep returns true if the status is pending_sleep.

func (RunStatus) Runnable

func (s RunStatus) Runnable() bool

Runnable returns true if the status is ready to be run.

func (*RunStatus) Scan

func (s *RunStatus) Scan(value interface{}) error

Scan reads the database value and returns an instance.

func (RunStatus) Unstarted

func (s RunStatus) Unstarted() bool

Unstarted returns true if the status is the initial state.

func (RunStatus) Value

func (s RunStatus) Value() (driver.Value, error)

Value returns this instance serialized for database storage.

type RunStatusCollection

type RunStatusCollection []RunStatus

RunStatusCollection is an array of RunStatus.

func (*RunStatusCollection) Scan

func (r *RunStatusCollection) Scan(value interface{}) error

Scan reads the database value and returns an instance.

func (RunStatusCollection) ToStrings

func (r RunStatusCollection) ToStrings() []string

ToStrings returns a copy of RunStatusCollection as an array of strings.

func (RunStatusCollection) Value

func (r RunStatusCollection) Value() (driver.Value, error)

Value returns this instance serialized for database storage.

type SendEtherRequest

type SendEtherRequest struct {
	DestinationAddress common.Address `json:"address"`
	FromAddress        common.Address `json:"from"`
	Amount             assets.Eth     `json:"amount"`
}

SendEtherRequest represents a request to transfer ETH.

type ServiceAgreement

type ServiceAgreement struct {
	ID            string      `json:"id" gorm:"primary_key"`
	CreatedAt     time.Time   `json:"createdAt" gorm:"index"`
	Encumbrance   Encumbrance `json:"encumbrance"`
	EncumbranceID int64       `json:"-"`
	RequestBody   string      `json:"requestBody"`
	Signature     Signature   `json:"signature" gorm:"type:varchar(255)"`
	JobSpec       JobSpec     `gorm:"foreignkey:JobSpecID"`
	JobSpecID     *ID         `json:"jobSpecId"`
	UpdatedAt     time.Time   `json:"-"`
}

ServiceAgreement connects job specifications with on-chain encumbrances.

func BuildServiceAgreement

func BuildServiceAgreement(us UnsignedServiceAgreement, signer Signer) (ServiceAgreement, error)

BuildServiceAgreement builds a signed service agreement

func (ServiceAgreement) GetID

func (sa ServiceAgreement) GetID() string

GetID returns the ID of this structure for jsonapi serialization.

func (ServiceAgreement) GetName

func (sa ServiceAgreement) GetName() string

GetName returns the pluralized "type" of this structure for jsonapi serialization.

func (*ServiceAgreement) SetID

func (sa *ServiceAgreement) SetID(value string) error

SetID is used to set the ID of this structure when deserializing from jsonapi documents.

type ServiceAgreementRequest added in v0.6.10

type ServiceAgreementRequest struct {
	Initiators             []InitiatorRequest     `json:"initiators"`
	Tasks                  []TaskSpecRequest      `json:"tasks"`
	Payment                *assets.Link           `json:"payment,omitempty"`
	Expiration             uint64                 `json:"expiration"`
	EndAt                  AnyTime                `json:"endAt"`
	Oracles                EIP55AddressCollection `json:"oracles"`
	Aggregator             EIP55Address           `json:"aggregator"`
	AggInitiateJobSelector FunctionSelector       `json:"aggInitiateJobSelector"`
	AggFulfillSelector     FunctionSelector       `json:"aggFulfillSelector"`
	StartAt                AnyTime                `json:"startAt"`
}

ServiceAgreementRequest encodes external ServiceAgreement json representation.

type Session

type Session struct {
	ID        string    `json:"id" gorm:"primary_key"`
	LastUsed  time.Time `json:"lastUsed" gorm:"index"`
	CreatedAt time.Time `json:"createdAt" gorm:"index"`
}

Session holds the unique id for the authenticated session.

func NewSession

func NewSession() Session

NewSession returns a session instance with ID set to a random ID and LastUsed to to now.

type SessionRequest

type SessionRequest struct {
	Email    string `json:"email"`
	Password string `json:"password"`
}

SessionRequest encapsulates the fields needed to generate a new SessionID, including the hashed password.

type Signature

type Signature [SignatureLength]byte

Signature is a byte array fixed to the size of a signature

func BytesToSignature

func BytesToSignature(b []byte) Signature

BytesToSignature converts an arbitrary length byte array to a Signature

func NewSignature

func NewSignature(s string) (Signature, error)

NewSignature returns a new Signature

func (Signature) Big

func (s Signature) Big() *big.Int

Big returns a big.Int representation

func (Signature) Bytes

func (s Signature) Bytes() []byte

Bytes returns the raw bytes

func (Signature) Format

func (s Signature) Format(state fmt.State, c rune)

Format implements fmt.Formatter

func (Signature) Hex

func (s Signature) Hex() string

Hex returns a hexadecimal string

func (Signature) MarshalJSON

func (s Signature) MarshalJSON() ([]byte, error)

MarshalJSON prints the signature as a hexadecimal encoded string

func (Signature) MarshalText

func (s Signature) MarshalText() ([]byte, error)

MarshalText encodes the signature in hexadecimal

func (*Signature) Scan

func (s *Signature) Scan(value interface{}) error

Scan reads the database value and returns an instance.

func (*Signature) SetBytes

func (s *Signature) SetBytes(b []byte)

SetBytes assigns the byte array to the signature

func (Signature) String

func (s Signature) String() string

String implements the stringer interface and is used also by the logger.

func (*Signature) UnmarshalJSON

func (s *Signature) UnmarshalJSON(input []byte) error

UnmarshalJSON parses a signature from a JSON string

func (*Signature) UnmarshalText

func (s *Signature) UnmarshalText(input []byte) error

UnmarshalText parses the signature from a hexadecimal representation

func (Signature) Value

func (s Signature) Value() (driver.Value, error)

Value returns this instance serialized for database storage.

type Signer

type Signer interface {
	SignHash(hash common.Hash) (Signature, error)
}

Signer is used to produce a HMAC signature from an input digest

type SyncEvent

type SyncEvent struct {
	ID        int64 `gorm:"primary_key"`
	CreatedAt time.Time
	UpdatedAt time.Time
	Body      string
}

SyncEvent represents an event sourcing style event, which is used to sync data upstream with another service

type TaskRun

type TaskRun struct {
	ID                               *ID           `json:"id" gorm:"primary_key;not null"`
	JobRunID                         *ID           `json:"-"`
	Result                           RunResult     `json:"result"`
	ResultID                         clnull.Uint32 `json:"-"`
	Status                           RunStatus     `json:"status" gorm:"default:'unstarted'"`
	TaskSpec                         TaskSpec      `json:"task" gorm:"association_autoupdate:false;association_autocreate:false"`
	TaskSpecID                       int64         `json:"-"`
	MinRequiredIncomingConfirmations clnull.Uint32 `json:"minimumConfirmations" gorm:"column:minimum_confirmations"`
	ObservedIncomingConfirmations    clnull.Uint32 `json:"confirmations" gorm:"column:confirmations"`
	CreatedAt                        time.Time     `json:"-"`
	UpdatedAt                        time.Time     `json:"-"`
}

TaskRun stores the Task and represents the status of the Task to be ran.

func (*TaskRun) ApplyBridgeRunResult added in v0.8.2

func (tr *TaskRun) ApplyBridgeRunResult(result BridgeRunResult)

ApplyBridgeRunResult updates the TaskRun's Result and Status

func (*TaskRun) ApplyOutput added in v0.8.2

func (tr *TaskRun) ApplyOutput(result RunOutput)

ApplyOutput updates the TaskRun's Result and Status

func (*TaskRun) SetError

func (tr *TaskRun) SetError(err error)

SetError sets this task run to failed and saves the error message

func (TaskRun) String

func (tr TaskRun) String() string

String returns info on the TaskRun as "ID,Type,Status,Result".

type TaskSpec

type TaskSpec struct {
	ID                               int64         `gorm:"primary_key"`
	JobSpecID                        *ID           `json:"-"`
	Type                             TaskType      `json:"type" gorm:"index;not null"`
	MinRequiredIncomingConfirmations clnull.Uint32 `json:"confirmations" gorm:"column:confirmations"`
	Params                           JSON          `json:"params" gorm:"type:text"`
	CreatedAt                        time.Time
	UpdatedAt                        time.Time
	DeletedAt                        *time.Time
}

TaskSpec is the definition of work to be carried out. The Type will be an adapter, and the Params will contain any additional information that adapter would need to operate.

type TaskSpecRequest

type TaskSpecRequest struct {
	Type                             TaskType      `json:"type"`
	MinRequiredIncomingConfirmations clnull.Uint32 `json:"confirmations"`
	Params                           JSON          `json:"params"`
}

TaskSpecRequest represents a schema for incoming TaskSpec requests as used by the API.

type TaskType

type TaskType string

TaskType defines what Adapter a TaskSpec will use.

func MustNewTaskType

func MustNewTaskType(val string) TaskType

MustNewTaskType instantiates a new TaskType, and panics if a bad input is provided.

func NewTaskType

func NewTaskType(val string) (TaskType, error)

NewTaskType returns a formatted Task type.

func (TaskType) MarshalJSON

func (t TaskType) MarshalJSON() ([]byte, error)

MarshalJSON converts a TaskType to a JSON byte slice.

func (*TaskType) Scan

func (t *TaskType) Scan(value interface{}) error

Scan reads the database value and returns an instance.

func (TaskType) String

func (t TaskType) String() string

String returns this TaskType as a string.

func (*TaskType) UnmarshalJSON

func (t *TaskType) UnmarshalJSON(input []byte) error

UnmarshalJSON converts a bytes slice of JSON to a TaskType.

func (TaskType) Value

func (t TaskType) Value() (driver.Value, error)

Value returns this instance serialized for database storage.

type Topics added in v0.6.10

type Topics [][]common.Hash

Topics handle the serialization of ethereum log topics to and from the data store.

func (*Topics) Scan added in v0.6.10

func (t *Topics) Scan(value interface{}) error

Scan coerces the value returned from the data store to the proper data in this instance.

func (Topics) Value added in v0.6.10

func (t Topics) Value() (driver.Value, error)

Value returns this instance serialized for database storage.

type Transaction added in v0.8.8

type Transaction struct {
	GasPrice hexutil.Uint64 `json:"gasPrice"`
}

type Tx

type Tx struct {
	ID uint64 `gorm:"primary_key;auto_increment"`

	// SurrogateID is used to look up a transaction using a secondary ID, used to
	// associate jobs with transactions so that we don't double spend in certain
	// failure scenarios
	SurrogateID null.String `gorm:"index;unique"`

	Attempts []*TxAttempt `json:"-"`

	From     common.Address `gorm:"index;not null"`
	To       common.Address `gorm:"not null"`
	Data     []byte         `gorm:"not null"`
	Nonce    uint64         `gorm:"index;not null"`
	Value    *utils.Big     `gorm:"not null"`
	GasLimit uint64         `gorm:"not null"`

	// TxAttempt fields manually included; can't embed another primary_key
	Hash        common.Hash `gorm:"not null"`
	GasPrice    *utils.Big  `gorm:"not null"`
	Confirmed   bool        `gorm:"not null"`
	SentAt      uint64      `gorm:"not null"`
	SignedRawTx []byte      `gorm:"not null"`
	CreatedAt   time.Time   `json:"-"`
	UpdatedAt   time.Time   `json:"-"`
}

Tx contains fields necessary for an Ethereum transaction with an additional field for the TxAttempt.

func (Tx) EthTx

func (tx Tx) EthTx(gasPriceWei *big.Int) *types.Transaction

EthTx creates a new Ethereum transaction with a given gasPrice in wei that is ready to be signed.

func (*Tx) String

func (tx *Tx) String() string

String implements Stringer for Tx

type TxAttempt

type TxAttempt struct {
	ID uint64 `gorm:"primary_key;auto_increment"`

	TxID uint64 `gorm:"index;type:bigint REFERENCES txes(id) ON DELETE CASCADE"`
	Tx   *Tx    `json:"-" gorm:"PRELOAD:false;foreignkey:TxID"`

	CreatedAt time.Time `gorm:"index;not null"`

	Hash        common.Hash `gorm:"index;not null"`
	GasPrice    *utils.Big  `gorm:"type:varchar(78);not null"`
	Confirmed   bool        `gorm:"not null"`
	SentAt      uint64      `gorm:"not null"`
	SignedRawTx []byte      `gorm:"not null"`
	UpdatedAt   time.Time   `json:"-"`
}

TxAttempt is used for keeping track of transactions that have been written to the Ethereum blockchain. This makes it so that if the network is busy, a transaction can be resubmitted with a higher GasPrice.

func HighestPricedTxAttemptPerTx added in v0.6.10

func HighestPricedTxAttemptPerTx(items []TxAttempt) []TxAttempt

func (TxAttempt) GetID

func (txa TxAttempt) GetID() string

GetID returns the ID of this structure for jsonapi serialization.

func (TxAttempt) GetName

func (txa TxAttempt) GetName() string

GetName returns the pluralized "type" of this structure for jsonapi serialization.

func (*TxAttempt) SetID

func (txa *TxAttempt) SetID(value string) error

SetID is used to set the ID of this structure when deserializing from jsonapi documents.

func (*TxAttempt) String

func (txa *TxAttempt) String() string

String implements Stringer for TxAttempt

type TxReceipt

type TxReceipt struct {
	BlockNumber *utils.Big   `json:"blockNumber"`
	BlockHash   *common.Hash `json:"blockHash"`
	Hash        common.Hash  `json:"transactionHash"`
	Logs        []Log        `json:"logs"`
}

TxReceipt holds the block number and the transaction hash of a signed transaction that has been written to the blockchain.

func (TxReceipt) FulfilledRunLog

func (txr TxReceipt) FulfilledRunLog() bool

FulfilledRunLog returns true if this tx receipt is the result of a fulfilled run log.

func (*TxReceipt) Unconfirmed

func (txr *TxReceipt) Unconfirmed() bool

Unconfirmed returns true if the transaction is not confirmed.

type UnsignedServiceAgreement

type UnsignedServiceAgreement struct {
	Encumbrance    Encumbrance
	ID             common.Hash
	RequestBody    string
	JobSpecRequest JobSpecRequest
}

UnsignedServiceAgreement contains the information to sign a service agreement

func NewUnsignedServiceAgreementFromRequest

func NewUnsignedServiceAgreementFromRequest(reader io.Reader) (UnsignedServiceAgreement, error)

NewUnsignedServiceAgreementFromRequest builds the information required to sign a service agreement

type UntrustedBytes added in v0.8.8

type UntrustedBytes []byte

This data can contain anything and is submitted by user on-chain, so we must be extra careful how we interact with it

func (UntrustedBytes) SafeByteSlice added in v0.8.8

func (ary UntrustedBytes) SafeByteSlice(start int, end int) ([]byte, error)

SafeByteSlice returns an error on out of bounds access to a byte array, where a normal slice would panic instead

type User

type User struct {
	Email             string    `json:"email" gorm:"primary_key"`
	HashedPassword    string    `json:"hashedPassword"`
	CreatedAt         time.Time `json:"createdAt" gorm:"index"`
	TokenKey          string    `json:"tokenKey"`
	TokenSalt         string    `json:"-"`
	TokenHashedSecret string    `json:"-"`
	UpdatedAt         time.Time `json:"-"`
}

User holds the credentials for API user.

func NewUser

func NewUser(email, plainPwd string) (User, error)

NewUser creates a new user by hashing the passed plainPwd with bcrypt.

func (*User) DeleteAuthToken added in v0.8.2

func (u *User) DeleteAuthToken()

DeleteAuthToken clears and disables the users Authentication Token.

func (*User) GenerateAuthToken added in v0.8.2

func (u *User) GenerateAuthToken() (*auth.Token, error)

GenerateAuthToken randomly generates and sets the users Authentication Token.

func (*User) SetAuthToken added in v0.8.2

func (u *User) SetAuthToken(token *auth.Token) error

SetAuthToken updates the user to use the given Authentication Token.

type ValidationError

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

ValidationError is an error that occurs during validation.

func (*ValidationError) Error

func (e *ValidationError) Error() string

type WebURL

type WebURL url.URL

WebURL contains the URL of the endpoint.

func (WebURL) MarshalJSON

func (w WebURL) MarshalJSON() ([]byte, error)

MarshalJSON returns the JSON-encoded string of the given data.

func (*WebURL) Scan

func (w *WebURL) Scan(value interface{}) error

Scan reads the database value and returns an instance.

func (WebURL) String

func (w WebURL) String() string

String delegates to the wrapped URL struct or an empty string when it is nil

func (*WebURL) UnmarshalJSON

func (w *WebURL) UnmarshalJSON(j []byte) error

UnmarshalJSON parses the raw URL stored in JSON-encoded data to a URL structure and sets it to the URL field.

func (WebURL) Value

func (w WebURL) Value() (driver.Value, error)

Value returns this instance serialized for database storage.

type WithdrawalRequest

type WithdrawalRequest struct {
	DestinationAddress common.Address `json:"address"`
	ContractAddress    common.Address `json:"contractAddress"`
	Amount             *assets.Link   `json:"amount"`
}

WithdrawalRequest request to withdraw LINK.

Directories

Path Synopsis
Package vrfkey tracks the secret keys associated with VRF proofs.
Package vrfkey tracks the secret keys associated with VRF proofs.

Jump to

Keyboard shortcuts

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