types

package
v2.5.4 Latest Latest
Warning

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

Go to latest
Published: Sep 14, 2023 License: GPL-3.0 Imports: 40 Imported by: 10

Documentation

Overview

Package types is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

Index

Constants

View Source
const (
	DoNotModify = "[do-not-modify]"

	MaxNameLength        = 128
	MaxDescriptionLength = 4096
	MaxClientIDLength    = 128
	MaxSchemaLength      = 512
	MaxURLLength         = 128

	MaxExecutableSize       = 8 * 1024        // 8kB
	MaxWasmCodeSize         = 512 * 1024      // 512kB
	MaxCompiledWasmCodeSize = 1 * 1024 * 1024 // 1MB

	MaximumOwasmGas = 8000000
)

nolint

View Source
const (
	EventTypeCreateDataSource   = "create_data_source"
	EventTypeEditDataSource     = "edit_data_source"
	EventTypeCreateOracleScript = "create_oracle_script"
	EventTypeEditOracleScript   = "edit_oracle_script"
	EventTypeRequest            = "request"
	EventTypeRawRequest         = "raw_request"
	EventTypeReport             = "report"
	EventTypeActivate           = "activate"
	EventTypeDeactivate         = "deactivate"
	EventTypeAddReporter        = "add_reporter"
	EventTypeRemoveReporter     = "remove_reporter"
	EventTypeResolve            = "resolve"
	EventTypeSendPacketFail     = "send_packet_fail"

	AttributeKeyID             = "id"
	AttributeKeyDataSourceID   = "data_source_id"
	AttributeKeyOracleScriptID = "oracle_script_id"
	AttributeKeyExternalID     = "external_id"
	AttributeKeyDataSourceHash = "data_source_hash"
	AttributeKeyCalldata       = "calldata"
	AttributeKeyValidator      = "validator"
	AttributeKeyReporter       = "reporter"
	AttributeKeyClientID       = "client_id"
	AttributeKeyAskCount       = "ask_count"
	AttributeKeyMinCount       = "min_count"
	AttributeKeyResolveStatus  = "resolve_status"
	AttributeKeyGasUsed        = "gas_used"
	AttributeKeyTotalFees      = "total_fees"
	AttributeKeyFee            = "fee"
	AttributeKeyResult         = "result"
	AttributeKeyReason         = "reason"
)

nolint

View Source
const (
	// ModuleName is the name of the module.
	ModuleName = "oracle"

	// Version defines the current version the IBC oracle module supports
	Version = "bandchain-1"

	// StoreKey to be used when creating the KVStore.
	StoreKey = ModuleName

	// QuerierRoute is the querier route for the oracle module
	QuerierRoute = ModuleName

	// RouterKey is the msg router key for the oracle module
	RouterKey = ModuleName

	// PortID is the default port id that oracle module binds to.
	PortID = ModuleName
)
View Source
const (
	TypeMsgRequestData        = "request"
	TypeMsgReportData         = "report"
	TypeMsgCreateDataSource   = "create_data_source"
	TypeMsgEditDataSource     = "edit_data_source"
	TypeMsgCreateOracleScript = "create_oracle_script"
	TypeMsgEditOracleScript   = "edit_oracle_script"
	TypeMsgActivate           = "activate"
	TypeMsgAddReporter        = "add_reporter"
	TypeMsgRemoveReporter     = "remove_reporter"
)

oracle message types

View Source
const (
	// Each value below is the default value for each parameter when generating the default
	// genesis file. See comments in types.proto for explanation for each parameter.
	DefaultMaxRawRequestCount      = uint64(16)
	DefaultMaxAskCount             = uint64(16)
	DefaultMaxCalldataSize         = uint64(256) // 256B
	DefaultMaxReportDataSize       = uint64(512) // 512B
	DefaultExpirationBlockCount    = uint64(100)
	DefaultBaseRequestGas          = uint64(50000)
	DefaultPerValidatorRequestGas  = uint64(0)
	DefaultSamplingTryCount        = uint64(3)
	DefaultOracleRewardPercentage  = uint64(70)
	DefaultInactivePenaltyDuration = uint64(10 * time.Minute)
	DefaultIBCRequestEnabled       = true
)

nolint

View Source
const (
	QueryParams           = "params"
	QueryCounts           = "counts"
	QueryData             = "data"
	QueryDataSources      = "data_sources"
	QueryOracleScripts    = "oracle_scripts"
	QueryRequests         = "requests"
	QueryValidatorStatus  = "validator_status"
	QueryReporters        = "reporters"
	QueryActiveValidators = "active_validators"
	QueryPendingRequests  = "pending_requests"
)

Query endpoints supported by the oracle Querier.

Variables

View Source
var (

	// ModuleCdc references the global x/oracle module codec. Note, the codec
	// should ONLY be used in certain instances of tests and for JSON encoding.
	//
	// The actual codec used for serialization should be provided to x/oracle and
	// defined at the application level.
	ModuleCdc = codec.NewProtoCodec(codectypes.NewInterfaceRegistry())

	// AminoCdc is a amino codec created to support amino json compatible msgs.
	AminoCdc = codec.NewAminoCodec(amino)
)
View Source
var (
	ErrOwasmCompilation         = sdkerrors.Register(ModuleName, 1, "owasm compilation failed")
	ErrBadWasmExecution         = sdkerrors.Register(ModuleName, 2, "bad wasm execution")
	ErrDataSourceNotFound       = sdkerrors.Register(ModuleName, 3, "data source not found")
	ErrOracleScriptNotFound     = sdkerrors.Register(ModuleName, 4, "oracle script not found")
	ErrRequestNotFound          = sdkerrors.Register(ModuleName, 5, "request not found")
	ErrRawRequestNotFound       = sdkerrors.Register(ModuleName, 6, "raw request not found")
	ErrReporterNotFound         = sdkerrors.Register(ModuleName, 7, "reporter not found")
	ErrResultNotFound           = sdkerrors.Register(ModuleName, 8, "result not found")
	ErrReporterAlreadyExists    = sdkerrors.Register(ModuleName, 9, "reporter already exists")
	ErrValidatorNotRequested    = sdkerrors.Register(ModuleName, 10, "validator not requested")
	ErrValidatorAlreadyReported = sdkerrors.Register(ModuleName, 11, "validator already reported")
	ErrInvalidReportSize        = sdkerrors.Register(ModuleName, 12, "invalid report size")
	ErrReporterNotAuthorized    = sdkerrors.Register(ModuleName, 13, "reporter not authorized")
	ErrEditorNotAuthorized      = sdkerrors.Register(ModuleName, 14, "editor not authorized")
	ErrValidatorAlreadyActive   = sdkerrors.Register(ModuleName, 16, "validator already active")
	ErrTooSoonToActivate        = sdkerrors.Register(ModuleName, 17, "too soon to activate")
	ErrTooLongName              = sdkerrors.Register(ModuleName, 18, "too long name")
	ErrTooLongDescription       = sdkerrors.Register(ModuleName, 19, "too long description")
	ErrEmptyExecutable          = sdkerrors.Register(ModuleName, 20, "empty executable")
	ErrEmptyWasmCode            = sdkerrors.Register(ModuleName, 21, "empty wasm code")
	ErrTooLargeExecutable       = sdkerrors.Register(ModuleName, 22, "too large executable")
	ErrTooLargeWasmCode         = sdkerrors.Register(ModuleName, 23, "too large wasm code")
	ErrInvalidMinCount          = sdkerrors.Register(ModuleName, 24, "invalid min count")
	ErrInvalidAskCount          = sdkerrors.Register(ModuleName, 25, "invalid ask count")
	ErrTooLargeCalldata         = sdkerrors.Register(ModuleName, 26, "too large calldata")
	ErrTooLongClientID          = sdkerrors.Register(ModuleName, 27, "too long client id")
	ErrEmptyRawRequests         = sdkerrors.Register(ModuleName, 28, "empty raw requests")
	ErrEmptyReport              = sdkerrors.Register(ModuleName, 29, "empty report")
	ErrDuplicateExternalID      = sdkerrors.Register(ModuleName, 30, "duplicate external id")
	ErrTooLongSchema            = sdkerrors.Register(ModuleName, 31, "too long schema")
	ErrTooLongURL               = sdkerrors.Register(ModuleName, 32, "too long url")
	ErrTooLargeRawReportData    = sdkerrors.Register(ModuleName, 33, "too large raw report data")
	ErrInsufficientValidators   = sdkerrors.Register(ModuleName, 34, "insufficient available validators")
	ErrCreateWithDoNotModify    = sdkerrors.Register(ModuleName, 35, "cannot create with [do-not-modify] content")
	ErrSelfReferenceAsReporter  = sdkerrors.Register(ModuleName, 36, "cannot reference self as reporter")
	ErrOBIDecode                = sdkerrors.Register(ModuleName, 37, "obi decode failed")
	ErrUncompressionFailed      = sdkerrors.Register(ModuleName, 38, "uncompression failed")
	ErrRequestAlreadyExpired    = sdkerrors.Register(ModuleName, 39, "request already expired")
	ErrBadDrbgInitialization    = sdkerrors.Register(ModuleName, 40, "bad drbg initialization")
	ErrMaxOracleChannels        = sdkerrors.Register(ModuleName, 41, "max oracle channels")
	ErrInvalidVersion           = sdkerrors.Register(ModuleName, 42, "invalid ICS20 version")
	ErrNotEnoughFee             = sdkerrors.Register(ModuleName, 43, "not enough fee")
	ErrInvalidOwasmGas          = sdkerrors.Register(ModuleName, 44, "invalid owasm gas")
	ErrIBCRequestDisabled       = sdkerrors.Register(ModuleName, 45, "sending oracle request via IBC is disabled")
)
View Source
var (
	ErrInvalidLengthGenesis        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowGenesis          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupGenesis = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	// RollingSeedSizeInBytes is the size of rolling block hash for random seed.
	RollingSeedSizeInBytes = 32
	// GlobalStoreKeyPrefix is the prefix for global primitive state variables.
	GlobalStoreKeyPrefix = []byte{0x00}
	// RollingSeedStoreKey is the key that keeps the seed based on the first 8-bit of the most recent 32 block hashes.
	RollingSeedStoreKey = append(GlobalStoreKeyPrefix, []byte("RollingSeed")...)
	// RequestCountStoreKey is the key that keeps the total request count.
	RequestCountStoreKey = append(GlobalStoreKeyPrefix, []byte("RequestCount")...)
	// RequestLastExpiredStoreKey is the key that keeps the ID of the last expired request, or 0 if none.
	RequestLastExpiredStoreKey = append(GlobalStoreKeyPrefix, []byte("RequestLastExpired")...)
	// PendingResolveListStoreKey is the key that keeps the list of pending-resolve requests.
	PendingResolveListStoreKey = append(GlobalStoreKeyPrefix, []byte("PendingList")...)
	// DataSourceCountStoreKey is the key that keeps the total data source count.
	DataSourceCountStoreKey = append(GlobalStoreKeyPrefix, []byte("DataSourceCount")...)
	// OracleScriptCountStoreKey is the key that keeps the total oracle sciprt count.
	OracleScriptCountStoreKey = append(GlobalStoreKeyPrefix, []byte("OracleScriptCount")...)

	// RequestStoreKeyPrefix is the prefix for request store.
	RequestStoreKeyPrefix = []byte{0x01}
	// ReportStoreKeyPrefix is the prefix for report store.
	ReportStoreKeyPrefix = []byte{0x02}
	// DataSourceStoreKeyPrefix is the prefix for data source store.
	DataSourceStoreKeyPrefix = []byte{0x03}
	// OracleScriptStoreKeyPrefix is the prefix for oracle script store.
	OracleScriptStoreKeyPrefix = []byte{0x04}
	// ValidatorStatusKeyPrefix is the prefix for validator status store.
	ValidatorStatusKeyPrefix = []byte{0x05}
	// ResultStoreKeyPrefix is the prefix for request result store.
	ResultStoreKeyPrefix = []byte{0xff}

	// PortKey defines the key to store the port ID in store
	PortKey = []byte{0xf0}
)
View Source
var (
	ErrInvalidLengthOracle        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowOracle          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupOracle = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	// Each value below is the key to store the respective oracle module parameter. See comments
	// in types.proto for explanation for each parameter.
	KeyMaxRawRequestCount      = []byte("MaxRawRequestCount")
	KeyMaxAskCount             = []byte("MaxAskCount")
	KeyMaxCalldataSize         = []byte("MaxCalldataSize")
	KeyMaxReportDataSize       = []byte("MaxReportDataSize")
	KeyExpirationBlockCount    = []byte("ExpirationBlockCount")
	KeyBaseOwasmGas            = []byte("BaseOwasmGas")
	KeyPerValidatorRequestGas  = []byte("PerValidatorRequestGas")
	KeySamplingTryCount        = []byte("SamplingTryCount")
	KeyOracleRewardPercentage  = []byte("OracleRewardPercentage")
	KeyInactivePenaltyDuration = []byte("InactivePenaltyDuration")
	KeyIBCRequestEnabled       = []byte("IBCRequestEnabled")
)

nolint

View Source
var (
	ErrInvalidLengthQuery        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowQuery          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupQuery = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthTx        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowTx          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupTx = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	DoNotModifyBytes = []byte(DoNotModify)
)

nolint

View Source
var ResolveStatus_name = map[int32]string{
	0: "RESOLVE_STATUS_OPEN_UNSPECIFIED",
	1: "RESOLVE_STATUS_SUCCESS",
	2: "RESOLVE_STATUS_FAILURE",
	3: "RESOLVE_STATUS_EXPIRED",
}
View Source
var ResolveStatus_value = map[string]int32{
	"RESOLVE_STATUS_OPEN_UNSPECIFIED": 0,
	"RESOLVE_STATUS_SUCCESS":          1,
	"RESOLVE_STATUS_FAILURE":          2,
	"RESOLVE_STATUS_EXPIRED":          3,
}

Functions

func DataSourceStoreKey

func DataSourceStoreKey(dataSourceID DataSourceID) []byte

DataSourceStoreKey returns the key to retrieve a specific data source from the store.

func OracleScriptStoreKey

func OracleScriptStoreKey(oracleScriptID OracleScriptID) []byte

OracleScriptStoreKey returns the key to retrieve a specific oracle script from the store.

func ParamKeyTable

func ParamKeyTable() paramtypes.KeyTable

ParamKeyTable for oracle module

func QueryBadRequest

func QueryBadRequest(legacyQuerierCdc *codec.LegacyAmino, result interface{}) ([]byte, error)

QueryBadRequest creates and marshals a QueryResult instance with HTTP status BadRequest.

func QueryNotFound

func QueryNotFound(legacyQuerierCdc *codec.LegacyAmino, result interface{}) ([]byte, error)

QueryNotFound creates and marshals a QueryResult instance with HTTP status NotFound.

func QueryOK

func QueryOK(legacyQuerierCdc *codec.LegacyAmino, result interface{}) ([]byte, error)

QueryOK creates and marshals a QueryResult instance with HTTP status OK.

func RegisterInterfaces

func RegisterInterfaces(registry codectypes.InterfaceRegistry)

RegisterInterfaces register the oracle module interfaces to protobuf Any.

func RegisterLegacyAminoCodec

func RegisterLegacyAminoCodec(cdc *codec.LegacyAmino)

RegisterLegacyAminoCodec registers the necessary x/oracle interfaces and concrete types on the provided LegacyAmino codec. These types are used for Amino JSON serialization.

func RegisterMsgServer

func RegisterMsgServer(s grpc1.Server, srv MsgServer)

func RegisterQueryHandler

func RegisterQueryHandler(ctx context.Context, mux *runtime.ServeMux, conn *grpc.ClientConn) error

RegisterQueryHandler registers the http handlers for service Query to "mux". The handlers forward requests to the grpc endpoint over "conn".

func RegisterQueryHandlerClient

func RegisterQueryHandlerClient(ctx context.Context, mux *runtime.ServeMux, client QueryClient) error

RegisterQueryHandlerClient registers the http handlers for service Query to "mux". The handlers forward requests to the grpc endpoint over the given implementation of "QueryClient". Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "QueryClient" doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in "QueryClient" to call the correct interceptors.

func RegisterQueryHandlerFromEndpoint

func RegisterQueryHandlerFromEndpoint(ctx context.Context, mux *runtime.ServeMux, endpoint string, opts []grpc.DialOption) (err error)

RegisterQueryHandlerFromEndpoint is same as RegisterQueryHandler but automatically dials to "endpoint" and closes the connection when "ctx" gets done.

func RegisterQueryHandlerServer

func RegisterQueryHandlerServer(ctx context.Context, mux *runtime.ServeMux, server QueryServer) error

RegisterQueryHandlerServer registers the http handlers for service Query to "mux". UnaryRPC :call QueryServer directly. StreamingRPC :currently unsupported pending https://github.com/grpc/grpc-go/issues/906. Note that using this registration option will cause many gRPC library features (such as grpc.SendHeader, etc) to stop working. Consider using RegisterQueryHandlerFromEndpoint instead.

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

func ReportStoreKey

func ReportStoreKey(requestID RequestID) []byte

ReportStoreKey returns the key to retrieve all data reports for a request.

func ReportsOfValidatorPrefixKey

func ReportsOfValidatorPrefixKey(reqID RequestID, val sdk.ValAddress) []byte

ReportsOfValidatorPrefixKey returns the prefix key to get all reports for a request from a validator.

func RequestStoreKey

func RequestStoreKey(requestID RequestID) []byte

RequestStoreKey returns the key to retrieve a specific request from the store.

func ResultStoreKey

func ResultStoreKey(requestID RequestID) []byte

ResultStoreKey returns the key to a request result in the store.

func ValidatorStatusStoreKey

func ValidatorStatusStoreKey(v sdk.ValAddress) []byte

ValidatorStatusStoreKey returns the key to a validator's status.

func WrapMaxError

func WrapMaxError(err error, got int, max int) error

WrapMaxError wraps an error message with additional info of the current and max values.

Types

type AccountKeeper

type AccountKeeper interface {
	GetAccount(ctx sdk.Context, addr sdk.AccAddress) authtypes.AccountI
	GetModuleAccount(ctx sdk.Context, name string) authtypes.ModuleAccountI
}

AccountKeeper defines the expected account keeper.

type ActiveValidator

type ActiveValidator struct {
	// Address is a validator address
	Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"`
	// Power is an amount of token that the validator is holding
	Power uint64 `protobuf:"varint,2,opt,name=power,proto3" json:"power,omitempty"`
}

ActiveValidator is information of currently active validator

func (*ActiveValidator) Descriptor

func (*ActiveValidator) Descriptor() ([]byte, []int)

func (*ActiveValidator) GetAddress

func (m *ActiveValidator) GetAddress() string

func (*ActiveValidator) GetPower

func (m *ActiveValidator) GetPower() uint64

func (*ActiveValidator) Marshal

func (m *ActiveValidator) Marshal() (dAtA []byte, err error)

func (*ActiveValidator) MarshalTo

func (m *ActiveValidator) MarshalTo(dAtA []byte) (int, error)

func (*ActiveValidator) MarshalToSizedBuffer

func (m *ActiveValidator) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*ActiveValidator) ProtoMessage

func (*ActiveValidator) ProtoMessage()

func (*ActiveValidator) Reset

func (m *ActiveValidator) Reset()

func (*ActiveValidator) Size

func (m *ActiveValidator) Size() (n int)

func (*ActiveValidator) String

func (m *ActiveValidator) String() string

func (*ActiveValidator) Unmarshal

func (m *ActiveValidator) Unmarshal(dAtA []byte) error

func (*ActiveValidator) XXX_DiscardUnknown

func (m *ActiveValidator) XXX_DiscardUnknown()

func (*ActiveValidator) XXX_Marshal

func (m *ActiveValidator) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*ActiveValidator) XXX_Merge

func (m *ActiveValidator) XXX_Merge(src proto.Message)

func (*ActiveValidator) XXX_Size

func (m *ActiveValidator) XXX_Size() int

func (*ActiveValidator) XXX_Unmarshal

func (m *ActiveValidator) XXX_Unmarshal(b []byte) error

type AuthzKeeper added in v2.2.0

type AuthzKeeper interface {
	GetCleanAuthorization(
		ctx sdk.Context,
		grantee sdk.AccAddress,
		granter sdk.AccAddress,
		msgType string,
	) (cap authz.Authorization, expiration time.Time)

	SaveGrant(
		ctx sdk.Context,
		grantee, granter sdk.AccAddress,
		authorization authz.Authorization,
		expiration time.Time,
	) error
	DeleteGrant(ctx sdk.Context, grantee sdk.AccAddress, granter sdk.AccAddress, msgType string) error
	GranterGrants(c context.Context, req *authz.QueryGranterGrantsRequest) (*authz.QueryGranterGrantsResponse, error)
}

AuthzKeeper defines the expected authz keeper. for query and testing only don't use to create/remove grant on deliver tx

type BankKeeper

type BankKeeper interface {
	GetAllBalances(ctx sdk.Context, addr sdk.AccAddress) sdk.Coins
	SendCoinsFromModuleToModule(ctx sdk.Context, senderModule, recipientModule string, amt sdk.Coins) error
	SendCoins(ctx sdk.Context, fromAddr sdk.AccAddress, toAddr sdk.AccAddress, amt sdk.Coins) error
}

BankKeeper defines the expected bank keeper.

type BaseEnv

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

BaseEnv combines shared functions used in prepare and execution Owasm program,

func (*BaseEnv) AskExternalData

func (env *BaseEnv) AskExternalData(eid int64, did int64, data []byte) error

AskExternalData implements Owasm ExecEnv interface.

func (*BaseEnv) GetAnsCount

func (env *BaseEnv) GetAnsCount() (int64, error)

GetAnsCount implements Owasm ExecEnv interface.

func (*BaseEnv) GetAskCount

func (env *BaseEnv) GetAskCount() int64

GetAskCount implements Owasm ExecEnv interface.

func (*BaseEnv) GetCalldata

func (env *BaseEnv) GetCalldata() []byte

GetCalldata implements Owasm ExecEnv interface.

func (*BaseEnv) GetExecuteTime added in v2.2.0

func (env *BaseEnv) GetExecuteTime() (int64, error)

GetExecuteTime implements Owasm ExecEnv interface.

func (*BaseEnv) GetExternalData

func (env *BaseEnv) GetExternalData(eid int64, vid int64) ([]byte, error)

GetExternalData implements Owasm ExecEnv interface.

func (*BaseEnv) GetExternalDataStatus

func (env *BaseEnv) GetExternalDataStatus(eid int64, vid int64) (int64, error)

GetExternalDataStatus implements Owasm ExecEnv interface.

func (*BaseEnv) GetMinCount

func (env *BaseEnv) GetMinCount() int64

GetMinCount implements Owasm ExecEnv interface.

func (*BaseEnv) GetPrepareTime added in v2.2.0

func (env *BaseEnv) GetPrepareTime() int64

GetPrepareTime implements Owasm ExecEnv interface.

func (*BaseEnv) GetSpanSize added in v2.4.0

func (env *BaseEnv) GetSpanSize() int64

GetSpanSize implements Owasm ExecEnv interface.

func (*BaseEnv) SetReturnData

func (env *BaseEnv) SetReturnData(data []byte) error

SetReturnData implements Owasm ExecEnv interface.

type ChannelKeeper

type ChannelKeeper interface {
	GetChannel(ctx sdk.Context, srcPort, srcChan string) (channel channeltypes.Channel, found bool)
	GetNextSequenceSend(ctx sdk.Context, portID, channelID string) (uint64, bool)
	SendPacket(ctx sdk.Context, channelCap *capabilitytypes.Capability, packet ibcexported.PacketI) error
}

ChannelKeeper defines the expected IBC channel keeper

type DataSource

type DataSource struct {
	// Owner is an address of the account who own the data source
	Owner string `protobuf:"bytes,1,opt,name=owner,proto3" json:"owner,omitempty"`
	// Name is data source name used for display
	Name string `protobuf:"bytes,2,opt,name=name,proto3" json:"name,omitempty"`
	// Description is data source description used for display
	Description string `protobuf:"bytes,3,opt,name=description,proto3" json:"description,omitempty"`
	// Filename is string of file name used as reference for locating
	// data source file stored in bandchain nodes
	Filename string `protobuf:"bytes,4,opt,name=filename,proto3" json:"filename,omitempty"`
	// Treasury is the account address who receive data source fee from requester.
	Treasury string `protobuf:"bytes,5,opt,name=treasury,proto3" json:"treasury,omitempty"`
	// Fee is the data source fee per ask_count that data provider will receive
	// from requester.
	Fee github_com_cosmos_cosmos_sdk_types.Coins `protobuf:"bytes,6,rep,name=fee,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"fee"`
}

DataSource is the data structure for storing data sources in the storage.

func NewDataSource

func NewDataSource(
	owner sdk.AccAddress, name, description, filename string, fee sdk.Coins, treasury sdk.AccAddress,
) DataSource

func (*DataSource) Descriptor

func (*DataSource) Descriptor() ([]byte, []int)

func (*DataSource) Equal

func (this *DataSource) Equal(that interface{}) bool

func (*DataSource) GetDescription

func (m *DataSource) GetDescription() string

func (*DataSource) GetFee

func (*DataSource) GetFilename

func (m *DataSource) GetFilename() string

func (*DataSource) GetName

func (m *DataSource) GetName() string

func (*DataSource) GetOwner

func (m *DataSource) GetOwner() string

func (*DataSource) GetTreasury

func (m *DataSource) GetTreasury() string

func (*DataSource) Marshal

func (m *DataSource) Marshal() (dAtA []byte, err error)

func (*DataSource) MarshalTo

func (m *DataSource) MarshalTo(dAtA []byte) (int, error)

func (*DataSource) MarshalToSizedBuffer

func (m *DataSource) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*DataSource) ProtoMessage

func (*DataSource) ProtoMessage()

func (*DataSource) Reset

func (m *DataSource) Reset()

func (*DataSource) Size

func (m *DataSource) Size() (n int)

func (*DataSource) String

func (m *DataSource) String() string

func (*DataSource) Unmarshal

func (m *DataSource) Unmarshal(dAtA []byte) error

func (*DataSource) XXX_DiscardUnknown

func (m *DataSource) XXX_DiscardUnknown()

func (*DataSource) XXX_Marshal

func (m *DataSource) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*DataSource) XXX_Merge

func (m *DataSource) XXX_Merge(src proto.Message)

func (*DataSource) XXX_Size

func (m *DataSource) XXX_Size() int

func (*DataSource) XXX_Unmarshal

func (m *DataSource) XXX_Unmarshal(b []byte) error

type DataSourceID

type DataSourceID uint64

DataSourceID is the type-safe unique identifier type for data sources.

type DistrKeeper

type DistrKeeper interface {
	GetCommunityTax(ctx sdk.Context) (percent sdk.Dec)
	GetFeePool(ctx sdk.Context) (feePool distrtypes.FeePool)
	SetFeePool(ctx sdk.Context, feePool distrtypes.FeePool)
	AllocateTokensToValidator(ctx sdk.Context, val stakingtypes.ValidatorI, tokens sdk.DecCoins)
}

DistrKeeper defines the expected distribution keeper.

type ExecuteEnv

type ExecuteEnv struct {
	BaseEnv

	Retdata     []byte
	ExecuteTime int64
	// contains filtered or unexported fields
}

ExecuteEnv implements ExecEnv interface only expected function and panic on prepare related functions.

func NewExecuteEnv

func NewExecuteEnv(req Request, reports []Report, executeTime time.Time, spanSize int64) *ExecuteEnv

NewExecuteEnv creates a new environment instance for execution period.

func (*ExecuteEnv) GetAnsCount

func (env *ExecuteEnv) GetAnsCount() (int64, error)

GetAnsCount implements Owasm ExecEnv interface.

func (*ExecuteEnv) GetExecuteTime added in v2.2.0

func (env *ExecuteEnv) GetExecuteTime() (int64, error)

GetExecuteTime implements Owasm ExecEnv interface.

func (*ExecuteEnv) GetExternalData

func (env *ExecuteEnv) GetExternalData(eid int64, vid int64) ([]byte, error)

GetExternalData implements Owasm ExecEnv interface.

func (*ExecuteEnv) GetExternalDataStatus

func (env *ExecuteEnv) GetExternalDataStatus(eid int64, vid int64) (int64, error)

GetExternalDataStatus implements Owasm ExecEnv interface.

func (*ExecuteEnv) SetReturnData

func (env *ExecuteEnv) SetReturnData(data []byte) error

SetReturnData implements Owasm ExecEnv interface.

type ExternalID

type ExternalID uint64

ExternalID is the type-safe unique identifier type for raw data requests.

type GenesisState

type GenesisState struct {
	// Params defines all the paramaters of the module.
	Params Params `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
	// DataSources are data sources to be installed during genesis phase
	DataSources []DataSource `protobuf:"bytes,2,rep,name=data_sources,json=dataSources,proto3" json:"data_sources"`
	// OracleScripts are list of oracle scripts to be installed during genesis
	// phase
	OracleScripts []OracleScript `protobuf:"bytes,3,rep,name=oracle_scripts,json=oracleScripts,proto3" json:"oracle_scripts"`
}

GenesisState defines the oracle module's genesis state.

func DefaultGenesisState

func DefaultGenesisState() *GenesisState

DefaultGenesisState returns the default oracle genesis state.

func GetGenesisStateFromAppState

func GetGenesisStateFromAppState(cdc codec.JSONCodec, appState map[string]json.RawMessage) *GenesisState

GetGenesisStateFromAppState returns oracle GenesisState given raw application genesis state.

func NewGenesisState

func NewGenesisState(params Params, dataSources []DataSource, oracleScripts []OracleScript) *GenesisState

NewGenesisState creates a new GenesisState instanc e

func (*GenesisState) Descriptor

func (*GenesisState) Descriptor() ([]byte, []int)

func (*GenesisState) GetDataSources

func (m *GenesisState) GetDataSources() []DataSource

func (*GenesisState) GetOracleScripts

func (m *GenesisState) GetOracleScripts() []OracleScript

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() Params

func (*GenesisState) Marshal

func (m *GenesisState) Marshal() (dAtA []byte, err error)

func (*GenesisState) MarshalTo

func (m *GenesisState) MarshalTo(dAtA []byte) (int, error)

func (*GenesisState) MarshalToSizedBuffer

func (m *GenesisState) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*GenesisState) ProtoMessage

func (*GenesisState) ProtoMessage()

func (*GenesisState) Reset

func (m *GenesisState) Reset()

func (*GenesisState) Size

func (m *GenesisState) Size() (n int)

func (*GenesisState) String

func (m *GenesisState) String() string

func (*GenesisState) Unmarshal

func (m *GenesisState) Unmarshal(dAtA []byte) error

func (GenesisState) Validate

func (g GenesisState) Validate() error

Validate performs basic genesis state validation returning an error upon any failure.

func (*GenesisState) XXX_DiscardUnknown

func (m *GenesisState) XXX_DiscardUnknown()

func (*GenesisState) XXX_Marshal

func (m *GenesisState) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*GenesisState) XXX_Merge

func (m *GenesisState) XXX_Merge(src proto.Message)

func (*GenesisState) XXX_Size

func (m *GenesisState) XXX_Size() int

func (*GenesisState) XXX_Unmarshal

func (m *GenesisState) XXX_Unmarshal(b []byte) error

type IBCChannel

type IBCChannel struct {
	// PortID is port ID used for sending response packet when request is
	// resolved.
	PortId string `protobuf:"bytes,1,opt,name=port_id,json=portId,proto3" json:"port_id,omitempty"`
	// ChannelID is channel ID used for sending response packet when request is
	// resolved.
	ChannelId string `protobuf:"bytes,2,opt,name=channel_id,json=channelId,proto3" json:"channel_id,omitempty"`
}

IBCChannel is information of IBC protocol to allow communicating with other chain

func NewIBCChannel

func NewIBCChannel(portId, channelId string) IBCChannel

NewIBCChannel creates a new IBCChannel instance.

func (*IBCChannel) Descriptor

func (*IBCChannel) Descriptor() ([]byte, []int)

func (*IBCChannel) Equal

func (this *IBCChannel) Equal(that interface{}) bool

func (*IBCChannel) GetChannelId

func (m *IBCChannel) GetChannelId() string

func (*IBCChannel) GetPortId

func (m *IBCChannel) GetPortId() string

func (*IBCChannel) Marshal

func (m *IBCChannel) Marshal() (dAtA []byte, err error)

func (*IBCChannel) MarshalTo

func (m *IBCChannel) MarshalTo(dAtA []byte) (int, error)

func (*IBCChannel) MarshalToSizedBuffer

func (m *IBCChannel) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*IBCChannel) ProtoMessage

func (*IBCChannel) ProtoMessage()

func (*IBCChannel) Reset

func (m *IBCChannel) Reset()

func (*IBCChannel) Size

func (m *IBCChannel) Size() (n int)

func (*IBCChannel) String

func (m *IBCChannel) String() string

func (*IBCChannel) Unmarshal

func (m *IBCChannel) Unmarshal(dAtA []byte) error

func (*IBCChannel) XXX_DiscardUnknown

func (m *IBCChannel) XXX_DiscardUnknown()

func (*IBCChannel) XXX_Marshal

func (m *IBCChannel) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*IBCChannel) XXX_Merge

func (m *IBCChannel) XXX_Merge(src proto.Message)

func (*IBCChannel) XXX_Size

func (m *IBCChannel) XXX_Size() int

func (*IBCChannel) XXX_Unmarshal

func (m *IBCChannel) XXX_Unmarshal(b []byte) error

type MsgActivate

type MsgActivate struct {
	// Validator is the validator address who sign this message and request to be
	// activated.
	Validator string `protobuf:"bytes,1,opt,name=validator,proto3" json:"validator,omitempty"`
}

MsgEditOracleScript is a message for activating a validator to become an oracle provider. However, the activation can be revoked once the validator is unable to provide data to fulfill requests

func NewMsgActivate

func NewMsgActivate(validator sdk.ValAddress) *MsgActivate

NewMsgActivate creates a new MsgActivate instance

func (*MsgActivate) Descriptor

func (*MsgActivate) Descriptor() ([]byte, []int)

func (*MsgActivate) Equal

func (this *MsgActivate) Equal(that interface{}) bool

func (MsgActivate) GetSignBytes

func (msg MsgActivate) GetSignBytes() []byte

GetSignBytes returns raw JSON bytes to be signed by the signers (sdk.Msg interface).

func (MsgActivate) GetSigners

func (msg MsgActivate) GetSigners() []sdk.AccAddress

GetSigners returns the required signers for the given MsgActivate (sdk.Msg interface).

func (*MsgActivate) GetValidator

func (m *MsgActivate) GetValidator() string

func (*MsgActivate) Marshal

func (m *MsgActivate) Marshal() (dAtA []byte, err error)

func (*MsgActivate) MarshalTo

func (m *MsgActivate) MarshalTo(dAtA []byte) (int, error)

func (*MsgActivate) MarshalToSizedBuffer

func (m *MsgActivate) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgActivate) ProtoMessage

func (*MsgActivate) ProtoMessage()

func (*MsgActivate) Reset

func (m *MsgActivate) Reset()

func (MsgActivate) Route

func (msg MsgActivate) Route() string

Route returns the route of MsgActivate - "oracle" (sdk.Msg interface).

func (*MsgActivate) Size

func (m *MsgActivate) Size() (n int)

func (*MsgActivate) String

func (m *MsgActivate) String() string

func (MsgActivate) Type

func (msg MsgActivate) Type() string

Type returns the message type of MsgActivate (sdk.Msg interface).

func (*MsgActivate) Unmarshal

func (m *MsgActivate) Unmarshal(dAtA []byte) error

func (MsgActivate) ValidateBasic

func (msg MsgActivate) ValidateBasic() error

ValidateBasic checks whether the given MsgActivate instance (sdk.Msg interface).

func (*MsgActivate) XXX_DiscardUnknown

func (m *MsgActivate) XXX_DiscardUnknown()

func (*MsgActivate) XXX_Marshal

func (m *MsgActivate) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgActivate) XXX_Merge

func (m *MsgActivate) XXX_Merge(src proto.Message)

func (*MsgActivate) XXX_Size

func (m *MsgActivate) XXX_Size() int

func (*MsgActivate) XXX_Unmarshal

func (m *MsgActivate) XXX_Unmarshal(b []byte) error

type MsgActivateResponse

type MsgActivateResponse struct {
}

MsgActivateResponse is response data for MsgActivate message

func (*MsgActivateResponse) Descriptor

func (*MsgActivateResponse) Descriptor() ([]byte, []int)

func (*MsgActivateResponse) Marshal

func (m *MsgActivateResponse) Marshal() (dAtA []byte, err error)

func (*MsgActivateResponse) MarshalTo

func (m *MsgActivateResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgActivateResponse) MarshalToSizedBuffer

func (m *MsgActivateResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgActivateResponse) ProtoMessage

func (*MsgActivateResponse) ProtoMessage()

func (*MsgActivateResponse) Reset

func (m *MsgActivateResponse) Reset()

func (*MsgActivateResponse) Size

func (m *MsgActivateResponse) Size() (n int)

func (*MsgActivateResponse) String

func (m *MsgActivateResponse) String() string

func (*MsgActivateResponse) Unmarshal

func (m *MsgActivateResponse) Unmarshal(dAtA []byte) error

func (*MsgActivateResponse) XXX_DiscardUnknown

func (m *MsgActivateResponse) XXX_DiscardUnknown()

func (*MsgActivateResponse) XXX_Marshal

func (m *MsgActivateResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgActivateResponse) XXX_Merge

func (m *MsgActivateResponse) XXX_Merge(src proto.Message)

func (*MsgActivateResponse) XXX_Size

func (m *MsgActivateResponse) XXX_Size() int

func (*MsgActivateResponse) XXX_Unmarshal

func (m *MsgActivateResponse) XXX_Unmarshal(b []byte) error

type MsgClient

type MsgClient interface {
	// RequestData defines a method for submitting a new request.
	RequestData(ctx context.Context, in *MsgRequestData, opts ...grpc.CallOption) (*MsgRequestDataResponse, error)
	// ReportData defines a method for reporting a data to resolve the request.
	ReportData(ctx context.Context, in *MsgReportData, opts ...grpc.CallOption) (*MsgReportDataResponse, error)
	// CreateDataSource defines a method for creating a new data source.
	CreateDataSource(ctx context.Context, in *MsgCreateDataSource, opts ...grpc.CallOption) (*MsgCreateDataSourceResponse, error)
	// EditDataSource defines a method for editing an existing data source.
	EditDataSource(ctx context.Context, in *MsgEditDataSource, opts ...grpc.CallOption) (*MsgEditDataSourceResponse, error)
	// CreateOracleScript defines a method for creating a new oracle script.
	CreateOracleScript(ctx context.Context, in *MsgCreateOracleScript, opts ...grpc.CallOption) (*MsgCreateOracleScriptResponse, error)
	// EditOracleScript defines a method for editing an existing oracle script.
	EditOracleScript(ctx context.Context, in *MsgEditOracleScript, opts ...grpc.CallOption) (*MsgEditOracleScriptResponse, error)
	// Activate defines a method for applying to be an oracle validator.
	Activate(ctx context.Context, in *MsgActivate, opts ...grpc.CallOption) (*MsgActivateResponse, error)
}

MsgClient is the client API for Msg service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

func NewMsgClient

func NewMsgClient(cc grpc1.ClientConn) MsgClient

type MsgCreateDataSource

type MsgCreateDataSource struct {
	// Name is the name of this data source used for display (optional).
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Description is the description of this data source used for display
	// (optional).
	Description string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	// Executable is the content of executable script or binary file to be run by
	// validators upon execution.
	Executable []byte `protobuf:"bytes,3,opt,name=executable,proto3" json:"executable,omitempty"`
	// Fee is the data source fee per ask_count that data provider will receive
	// from requester.
	Fee github_com_cosmos_cosmos_sdk_types.Coins `protobuf:"bytes,4,rep,name=fee,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"fee"`
	// Treasury is the account address who receive data source fee from requester.
	Treasury string `protobuf:"bytes,5,opt,name=treasury,proto3" json:"treasury,omitempty"`
	// Owner is the account address who is allowed to make further changes to the
	// data source.
	Owner string `protobuf:"bytes,6,opt,name=owner,proto3" json:"owner,omitempty"`
	// Sender is the signer of this message.
	Sender string `protobuf:"bytes,7,opt,name=sender,proto3" json:"sender,omitempty"`
}

MsgCreateDataSource is a message for creating a new data source.

func NewMsgCreateDataSource

func NewMsgCreateDataSource(
	name, description string, executable []byte, fee sdk.Coins, treasury, owner, sender sdk.AccAddress,
) *MsgCreateDataSource

NewMsgCreateDataSource creates a new MsgCreateDataSource instance

func (*MsgCreateDataSource) Descriptor

func (*MsgCreateDataSource) Descriptor() ([]byte, []int)

func (*MsgCreateDataSource) Equal

func (this *MsgCreateDataSource) Equal(that interface{}) bool

func (*MsgCreateDataSource) GetDescription

func (m *MsgCreateDataSource) GetDescription() string

func (*MsgCreateDataSource) GetExecutable

func (m *MsgCreateDataSource) GetExecutable() []byte

func (*MsgCreateDataSource) GetFee

func (*MsgCreateDataSource) GetName

func (m *MsgCreateDataSource) GetName() string

func (*MsgCreateDataSource) GetOwner

func (m *MsgCreateDataSource) GetOwner() string

func (*MsgCreateDataSource) GetSender

func (m *MsgCreateDataSource) GetSender() string

func (MsgCreateDataSource) GetSignBytes

func (msg MsgCreateDataSource) GetSignBytes() []byte

GetSignBytes returns raw JSON bytes to be signed by the signers (sdk.Msg interface).

func (MsgCreateDataSource) GetSigners

func (msg MsgCreateDataSource) GetSigners() []sdk.AccAddress

GetSigners returns the required signers for the given MsgCreateDataSource (sdk.Msg interface).

func (*MsgCreateDataSource) GetTreasury

func (m *MsgCreateDataSource) GetTreasury() string

func (*MsgCreateDataSource) Marshal

func (m *MsgCreateDataSource) Marshal() (dAtA []byte, err error)

func (*MsgCreateDataSource) MarshalTo

func (m *MsgCreateDataSource) MarshalTo(dAtA []byte) (int, error)

func (*MsgCreateDataSource) MarshalToSizedBuffer

func (m *MsgCreateDataSource) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgCreateDataSource) ProtoMessage

func (*MsgCreateDataSource) ProtoMessage()

func (*MsgCreateDataSource) Reset

func (m *MsgCreateDataSource) Reset()

func (MsgCreateDataSource) Route

func (msg MsgCreateDataSource) Route() string

Route returns the route of MsgCreateDataSource - "oracle" (sdk.Msg interface).

func (*MsgCreateDataSource) Size

func (m *MsgCreateDataSource) Size() (n int)

func (*MsgCreateDataSource) String

func (m *MsgCreateDataSource) String() string

func (MsgCreateDataSource) Type

func (msg MsgCreateDataSource) Type() string

Type returns the message type of MsgCreateDataSource (sdk.Msg interface).

func (*MsgCreateDataSource) Unmarshal

func (m *MsgCreateDataSource) Unmarshal(dAtA []byte) error

func (MsgCreateDataSource) ValidateBasic

func (msg MsgCreateDataSource) ValidateBasic() error

ValidateBasic checks whether the given MsgCreateDataSource instance (sdk.Msg interface).

func (*MsgCreateDataSource) XXX_DiscardUnknown

func (m *MsgCreateDataSource) XXX_DiscardUnknown()

func (*MsgCreateDataSource) XXX_Marshal

func (m *MsgCreateDataSource) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgCreateDataSource) XXX_Merge

func (m *MsgCreateDataSource) XXX_Merge(src proto.Message)

func (*MsgCreateDataSource) XXX_Size

func (m *MsgCreateDataSource) XXX_Size() int

func (*MsgCreateDataSource) XXX_Unmarshal

func (m *MsgCreateDataSource) XXX_Unmarshal(b []byte) error

type MsgCreateDataSourceResponse

type MsgCreateDataSourceResponse struct {
}

MsgCreateDataSourceResponse is response data for MsgCreateDataSource message

func (*MsgCreateDataSourceResponse) Descriptor

func (*MsgCreateDataSourceResponse) Descriptor() ([]byte, []int)

func (*MsgCreateDataSourceResponse) Marshal

func (m *MsgCreateDataSourceResponse) Marshal() (dAtA []byte, err error)

func (*MsgCreateDataSourceResponse) MarshalTo

func (m *MsgCreateDataSourceResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgCreateDataSourceResponse) MarshalToSizedBuffer

func (m *MsgCreateDataSourceResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgCreateDataSourceResponse) ProtoMessage

func (*MsgCreateDataSourceResponse) ProtoMessage()

func (*MsgCreateDataSourceResponse) Reset

func (m *MsgCreateDataSourceResponse) Reset()

func (*MsgCreateDataSourceResponse) Size

func (m *MsgCreateDataSourceResponse) Size() (n int)

func (*MsgCreateDataSourceResponse) String

func (m *MsgCreateDataSourceResponse) String() string

func (*MsgCreateDataSourceResponse) Unmarshal

func (m *MsgCreateDataSourceResponse) Unmarshal(dAtA []byte) error

func (*MsgCreateDataSourceResponse) XXX_DiscardUnknown

func (m *MsgCreateDataSourceResponse) XXX_DiscardUnknown()

func (*MsgCreateDataSourceResponse) XXX_Marshal

func (m *MsgCreateDataSourceResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgCreateDataSourceResponse) XXX_Merge

func (m *MsgCreateDataSourceResponse) XXX_Merge(src proto.Message)

func (*MsgCreateDataSourceResponse) XXX_Size

func (m *MsgCreateDataSourceResponse) XXX_Size() int

func (*MsgCreateDataSourceResponse) XXX_Unmarshal

func (m *MsgCreateDataSourceResponse) XXX_Unmarshal(b []byte) error

type MsgCreateOracleScript

type MsgCreateOracleScript struct {
	// Name is the name of this oracle script used for display (optional).
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Description is the description of this oracle script used for display
	// (optional).
	Description string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	// Schema is the OBI schema of this oracle script (optional).
	Schema string `protobuf:"bytes,3,opt,name=schema,proto3" json:"schema,omitempty"`
	// SourceCodeURL is the absolute URI to the script's source code (optional).
	SourceCodeURL string `protobuf:"bytes,4,opt,name=source_code_url,json=sourceCodeUrl,proto3" json:"source_code_url,omitempty"`
	// Code is the oracle WebAssembly binary code. Can be raw of gzip compressed.
	Code []byte `protobuf:"bytes,5,opt,name=code,proto3" json:"code,omitempty"`
	// Owner is the address who is allowed to make further changes to the oracle
	// script.
	Owner string `protobuf:"bytes,6,opt,name=owner,proto3" json:"owner,omitempty"`
	// Sender is the signer of this message.
	Sender string `protobuf:"bytes,7,opt,name=sender,proto3" json:"sender,omitempty"`
}

MsgCreateOracleScript is a message for creating an oracle script.

func NewMsgCreateOracleScript

func NewMsgCreateOracleScript(
	name, description, schema, sourceCodeURL string, code []byte, owner, sender sdk.AccAddress,
) *MsgCreateOracleScript

NewMsgCreateOracleScript creates a new MsgCreateOracleScript instance

func (*MsgCreateOracleScript) Descriptor

func (*MsgCreateOracleScript) Descriptor() ([]byte, []int)

func (*MsgCreateOracleScript) Equal

func (this *MsgCreateOracleScript) Equal(that interface{}) bool

func (*MsgCreateOracleScript) GetCode

func (m *MsgCreateOracleScript) GetCode() []byte

func (*MsgCreateOracleScript) GetDescription

func (m *MsgCreateOracleScript) GetDescription() string

func (*MsgCreateOracleScript) GetName

func (m *MsgCreateOracleScript) GetName() string

func (*MsgCreateOracleScript) GetOwner

func (m *MsgCreateOracleScript) GetOwner() string

func (*MsgCreateOracleScript) GetSchema

func (m *MsgCreateOracleScript) GetSchema() string

func (*MsgCreateOracleScript) GetSender

func (m *MsgCreateOracleScript) GetSender() string

func (MsgCreateOracleScript) GetSignBytes

func (msg MsgCreateOracleScript) GetSignBytes() []byte

GetSignBytes returns raw JSON bytes to be signed by the signers (sdk.Msg interface).

func (MsgCreateOracleScript) GetSigners

func (msg MsgCreateOracleScript) GetSigners() []sdk.AccAddress

GetSigners returns the required signers for the given MsgCreateOracleScript (sdk.Msg interface).

func (*MsgCreateOracleScript) GetSourceCodeURL

func (m *MsgCreateOracleScript) GetSourceCodeURL() string

func (*MsgCreateOracleScript) Marshal

func (m *MsgCreateOracleScript) Marshal() (dAtA []byte, err error)

func (*MsgCreateOracleScript) MarshalTo

func (m *MsgCreateOracleScript) MarshalTo(dAtA []byte) (int, error)

func (*MsgCreateOracleScript) MarshalToSizedBuffer

func (m *MsgCreateOracleScript) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgCreateOracleScript) ProtoMessage

func (*MsgCreateOracleScript) ProtoMessage()

func (*MsgCreateOracleScript) Reset

func (m *MsgCreateOracleScript) Reset()

func (MsgCreateOracleScript) Route

func (msg MsgCreateOracleScript) Route() string

Route returns the route of MsgCreateOracleScript - "oracle" (sdk.Msg interface).

func (*MsgCreateOracleScript) Size

func (m *MsgCreateOracleScript) Size() (n int)

func (*MsgCreateOracleScript) String

func (m *MsgCreateOracleScript) String() string

func (MsgCreateOracleScript) Type

func (msg MsgCreateOracleScript) Type() string

Type returns the message type of MsgCreateOracleScript (sdk.Msg interface).

func (*MsgCreateOracleScript) Unmarshal

func (m *MsgCreateOracleScript) Unmarshal(dAtA []byte) error

func (MsgCreateOracleScript) ValidateBasic

func (msg MsgCreateOracleScript) ValidateBasic() error

ValidateBasic checks whether the given MsgCreateOracleScript instance (sdk.Msg interface).

func (*MsgCreateOracleScript) XXX_DiscardUnknown

func (m *MsgCreateOracleScript) XXX_DiscardUnknown()

func (*MsgCreateOracleScript) XXX_Marshal

func (m *MsgCreateOracleScript) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgCreateOracleScript) XXX_Merge

func (m *MsgCreateOracleScript) XXX_Merge(src proto.Message)

func (*MsgCreateOracleScript) XXX_Size

func (m *MsgCreateOracleScript) XXX_Size() int

func (*MsgCreateOracleScript) XXX_Unmarshal

func (m *MsgCreateOracleScript) XXX_Unmarshal(b []byte) error

type MsgCreateOracleScriptResponse

type MsgCreateOracleScriptResponse struct {
}

MsgCreateOracleScriptResponse is response data for MsgCreateOracleScript message

func (*MsgCreateOracleScriptResponse) Descriptor

func (*MsgCreateOracleScriptResponse) Descriptor() ([]byte, []int)

func (*MsgCreateOracleScriptResponse) Marshal

func (m *MsgCreateOracleScriptResponse) Marshal() (dAtA []byte, err error)

func (*MsgCreateOracleScriptResponse) MarshalTo

func (m *MsgCreateOracleScriptResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgCreateOracleScriptResponse) MarshalToSizedBuffer

func (m *MsgCreateOracleScriptResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgCreateOracleScriptResponse) ProtoMessage

func (*MsgCreateOracleScriptResponse) ProtoMessage()

func (*MsgCreateOracleScriptResponse) Reset

func (m *MsgCreateOracleScriptResponse) Reset()

func (*MsgCreateOracleScriptResponse) Size

func (m *MsgCreateOracleScriptResponse) Size() (n int)

func (*MsgCreateOracleScriptResponse) String

func (*MsgCreateOracleScriptResponse) Unmarshal

func (m *MsgCreateOracleScriptResponse) Unmarshal(dAtA []byte) error

func (*MsgCreateOracleScriptResponse) XXX_DiscardUnknown

func (m *MsgCreateOracleScriptResponse) XXX_DiscardUnknown()

func (*MsgCreateOracleScriptResponse) XXX_Marshal

func (m *MsgCreateOracleScriptResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgCreateOracleScriptResponse) XXX_Merge

func (m *MsgCreateOracleScriptResponse) XXX_Merge(src proto.Message)

func (*MsgCreateOracleScriptResponse) XXX_Size

func (m *MsgCreateOracleScriptResponse) XXX_Size() int

func (*MsgCreateOracleScriptResponse) XXX_Unmarshal

func (m *MsgCreateOracleScriptResponse) XXX_Unmarshal(b []byte) error

type MsgEditDataSource

type MsgEditDataSource struct {
	// DataSourceID is the unique identifier of the data source to be edited.
	DataSourceID DataSourceID `protobuf:"varint,1,opt,name=data_source_id,json=dataSourceId,proto3,casttype=DataSourceID" json:"data_source_id,omitempty"`
	// Name is the name of this data source used for display (optional).
	Name string `protobuf:"bytes,2,opt,name=name,proto3" json:"name,omitempty"`
	// Description is the description of this data source used for display
	// (optional).
	Description string `protobuf:"bytes,3,opt,name=description,proto3" json:"description,omitempty"`
	// Executable is the executable script or binary to be run by validators upon
	// execution.
	Executable []byte `protobuf:"bytes,4,opt,name=executable,proto3" json:"executable,omitempty"`
	// Fee is the data source fee per ask_count that data provider will receive
	// from requester.
	Fee github_com_cosmos_cosmos_sdk_types.Coins `protobuf:"bytes,5,rep,name=fee,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"fee"`
	// Treasury is the address who receive data source fee from requester.
	Treasury string `protobuf:"bytes,6,opt,name=treasury,proto3" json:"treasury,omitempty"`
	// Owner is the address who is allowed to make further changes to the data
	// source.
	Owner string `protobuf:"bytes,7,opt,name=owner,proto3" json:"owner,omitempty"`
	// Sender is the signer of this message. Must be the current data source's
	// owner.
	Sender string `protobuf:"bytes,8,opt,name=sender,proto3" json:"sender,omitempty"`
}

MsgEditDataSource is a message for editing an existing data source.

func NewMsgEditDataSource

func NewMsgEditDataSource(
	dataSourceID DataSourceID,
	name string,
	description string,
	executable []byte,
	fee sdk.Coins,
	treasury, owner, sender sdk.AccAddress,
) *MsgEditDataSource

NewMsgEditDataSource creates a new MsgEditDataSource instance

func (*MsgEditDataSource) Descriptor

func (*MsgEditDataSource) Descriptor() ([]byte, []int)

func (*MsgEditDataSource) Equal

func (this *MsgEditDataSource) Equal(that interface{}) bool

func (*MsgEditDataSource) GetDataSourceID

func (m *MsgEditDataSource) GetDataSourceID() DataSourceID

func (*MsgEditDataSource) GetDescription

func (m *MsgEditDataSource) GetDescription() string

func (*MsgEditDataSource) GetExecutable

func (m *MsgEditDataSource) GetExecutable() []byte

func (*MsgEditDataSource) GetFee

func (*MsgEditDataSource) GetName

func (m *MsgEditDataSource) GetName() string

func (*MsgEditDataSource) GetOwner

func (m *MsgEditDataSource) GetOwner() string

func (*MsgEditDataSource) GetSender

func (m *MsgEditDataSource) GetSender() string

func (MsgEditDataSource) GetSignBytes

func (msg MsgEditDataSource) GetSignBytes() []byte

GetSignBytes returns raw JSON bytes to be signed by the signers (sdk.Msg interface).

func (MsgEditDataSource) GetSigners

func (msg MsgEditDataSource) GetSigners() []sdk.AccAddress

GetSigners returns the required signers for the given MsgEditDataSource (sdk.Msg interface).

func (*MsgEditDataSource) GetTreasury

func (m *MsgEditDataSource) GetTreasury() string

func (*MsgEditDataSource) Marshal

func (m *MsgEditDataSource) Marshal() (dAtA []byte, err error)

func (*MsgEditDataSource) MarshalTo

func (m *MsgEditDataSource) MarshalTo(dAtA []byte) (int, error)

func (*MsgEditDataSource) MarshalToSizedBuffer

func (m *MsgEditDataSource) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgEditDataSource) ProtoMessage

func (*MsgEditDataSource) ProtoMessage()

func (*MsgEditDataSource) Reset

func (m *MsgEditDataSource) Reset()

func (MsgEditDataSource) Route

func (msg MsgEditDataSource) Route() string

Route returns the route of MsgEditDataSource - "oracle" (sdk.Msg interface).

func (*MsgEditDataSource) Size

func (m *MsgEditDataSource) Size() (n int)

func (*MsgEditDataSource) String

func (m *MsgEditDataSource) String() string

func (MsgEditDataSource) Type

func (msg MsgEditDataSource) Type() string

Type returns the message type of MsgEditDataSource (sdk.Msg interface).

func (*MsgEditDataSource) Unmarshal

func (m *MsgEditDataSource) Unmarshal(dAtA []byte) error

func (MsgEditDataSource) ValidateBasic

func (msg MsgEditDataSource) ValidateBasic() error

ValidateBasic checks whether the given MsgEditDataSource instance (sdk.Msg interface).

func (*MsgEditDataSource) XXX_DiscardUnknown

func (m *MsgEditDataSource) XXX_DiscardUnknown()

func (*MsgEditDataSource) XXX_Marshal

func (m *MsgEditDataSource) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgEditDataSource) XXX_Merge

func (m *MsgEditDataSource) XXX_Merge(src proto.Message)

func (*MsgEditDataSource) XXX_Size

func (m *MsgEditDataSource) XXX_Size() int

func (*MsgEditDataSource) XXX_Unmarshal

func (m *MsgEditDataSource) XXX_Unmarshal(b []byte) error

type MsgEditDataSourceResponse

type MsgEditDataSourceResponse struct {
}

MsgEditDataSourceResponse is response data for MsgEditDataSource message

func (*MsgEditDataSourceResponse) Descriptor

func (*MsgEditDataSourceResponse) Descriptor() ([]byte, []int)

func (*MsgEditDataSourceResponse) Marshal

func (m *MsgEditDataSourceResponse) Marshal() (dAtA []byte, err error)

func (*MsgEditDataSourceResponse) MarshalTo

func (m *MsgEditDataSourceResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgEditDataSourceResponse) MarshalToSizedBuffer

func (m *MsgEditDataSourceResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgEditDataSourceResponse) ProtoMessage

func (*MsgEditDataSourceResponse) ProtoMessage()

func (*MsgEditDataSourceResponse) Reset

func (m *MsgEditDataSourceResponse) Reset()

func (*MsgEditDataSourceResponse) Size

func (m *MsgEditDataSourceResponse) Size() (n int)

func (*MsgEditDataSourceResponse) String

func (m *MsgEditDataSourceResponse) String() string

func (*MsgEditDataSourceResponse) Unmarshal

func (m *MsgEditDataSourceResponse) Unmarshal(dAtA []byte) error

func (*MsgEditDataSourceResponse) XXX_DiscardUnknown

func (m *MsgEditDataSourceResponse) XXX_DiscardUnknown()

func (*MsgEditDataSourceResponse) XXX_Marshal

func (m *MsgEditDataSourceResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgEditDataSourceResponse) XXX_Merge

func (m *MsgEditDataSourceResponse) XXX_Merge(src proto.Message)

func (*MsgEditDataSourceResponse) XXX_Size

func (m *MsgEditDataSourceResponse) XXX_Size() int

func (*MsgEditDataSourceResponse) XXX_Unmarshal

func (m *MsgEditDataSourceResponse) XXX_Unmarshal(b []byte) error

type MsgEditOracleScript

type MsgEditOracleScript struct {
	// OracleScriptID is the unique identifier of the oracle script to be edited.
	OracleScriptID OracleScriptID `` /* 130-byte string literal not displayed */
	// Name is the name of this oracle script used for display (optional).
	Name string `protobuf:"bytes,2,opt,name=name,proto3" json:"name,omitempty"`
	// Description is the description of this oracle script used for display
	// (optional).
	Description string `protobuf:"bytes,3,opt,name=description,proto3" json:"description,omitempty"`
	// Schema is the OBI schema of this oracle script (optional).
	Schema string `protobuf:"bytes,4,opt,name=schema,proto3" json:"schema,omitempty"`
	// SourceCodeURL is the absolute URI to the script's source code (optional).
	SourceCodeURL string `protobuf:"bytes,5,opt,name=source_code_url,json=sourceCodeUrl,proto3" json:"source_code_url,omitempty"`
	// Code is the oracle WebAssembly binary code. Can be raw of gzip compressed.
	Code []byte `protobuf:"bytes,6,opt,name=code,proto3" json:"code,omitempty"`
	// Owner is an account address who is allowed to make further changes to the
	// oracle script.
	Owner string `protobuf:"bytes,7,opt,name=owner,proto3" json:"owner,omitempty"`
	// Sender is an account address who sign this message. Must be the current
	// oracle script's owner.
	Sender string `protobuf:"bytes,8,opt,name=sender,proto3" json:"sender,omitempty"`
}

MsgEditOracleScript is a message for editing an existing oracle script.

func NewMsgEditOracleScript

func NewMsgEditOracleScript(
	oracleScriptID OracleScriptID,
	name, description, schema, sourceCodeURL string,
	code []byte,
	owner, sender sdk.AccAddress,
) *MsgEditOracleScript

NewMsgEditOracleScript creates a new MsgEditOracleScript instance

func (*MsgEditOracleScript) Descriptor

func (*MsgEditOracleScript) Descriptor() ([]byte, []int)

func (*MsgEditOracleScript) Equal

func (this *MsgEditOracleScript) Equal(that interface{}) bool

func (*MsgEditOracleScript) GetCode

func (m *MsgEditOracleScript) GetCode() []byte

func (*MsgEditOracleScript) GetDescription

func (m *MsgEditOracleScript) GetDescription() string

func (*MsgEditOracleScript) GetName

func (m *MsgEditOracleScript) GetName() string

func (*MsgEditOracleScript) GetOracleScriptID

func (m *MsgEditOracleScript) GetOracleScriptID() OracleScriptID

func (*MsgEditOracleScript) GetOwner

func (m *MsgEditOracleScript) GetOwner() string

func (*MsgEditOracleScript) GetSchema

func (m *MsgEditOracleScript) GetSchema() string

func (*MsgEditOracleScript) GetSender

func (m *MsgEditOracleScript) GetSender() string

func (MsgEditOracleScript) GetSignBytes

func (msg MsgEditOracleScript) GetSignBytes() []byte

GetSignBytes returns raw JSON bytes to be signed by the signers (sdk.Msg interface).

func (MsgEditOracleScript) GetSigners

func (msg MsgEditOracleScript) GetSigners() []sdk.AccAddress

GetSigners returns the required signers for the given MsgEditOracleScript (sdk.Msg interface).

func (*MsgEditOracleScript) GetSourceCodeURL

func (m *MsgEditOracleScript) GetSourceCodeURL() string

func (*MsgEditOracleScript) Marshal

func (m *MsgEditOracleScript) Marshal() (dAtA []byte, err error)

func (*MsgEditOracleScript) MarshalTo

func (m *MsgEditOracleScript) MarshalTo(dAtA []byte) (int, error)

func (*MsgEditOracleScript) MarshalToSizedBuffer

func (m *MsgEditOracleScript) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgEditOracleScript) ProtoMessage

func (*MsgEditOracleScript) ProtoMessage()

func (*MsgEditOracleScript) Reset

func (m *MsgEditOracleScript) Reset()

func (MsgEditOracleScript) Route

func (msg MsgEditOracleScript) Route() string

Route returns the route of MsgEditOracleScript - "oracle" (sdk.Msg interface).

func (*MsgEditOracleScript) Size

func (m *MsgEditOracleScript) Size() (n int)

func (*MsgEditOracleScript) String

func (m *MsgEditOracleScript) String() string

func (MsgEditOracleScript) Type

func (msg MsgEditOracleScript) Type() string

Type returns the message type of MsgEditOracleScript (sdk.Msg interface).

func (*MsgEditOracleScript) Unmarshal

func (m *MsgEditOracleScript) Unmarshal(dAtA []byte) error

func (MsgEditOracleScript) ValidateBasic

func (msg MsgEditOracleScript) ValidateBasic() error

ValidateBasic checks whether the given MsgEditOracleScript instance (sdk.Msg interface).

func (*MsgEditOracleScript) XXX_DiscardUnknown

func (m *MsgEditOracleScript) XXX_DiscardUnknown()

func (*MsgEditOracleScript) XXX_Marshal

func (m *MsgEditOracleScript) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgEditOracleScript) XXX_Merge

func (m *MsgEditOracleScript) XXX_Merge(src proto.Message)

func (*MsgEditOracleScript) XXX_Size

func (m *MsgEditOracleScript) XXX_Size() int

func (*MsgEditOracleScript) XXX_Unmarshal

func (m *MsgEditOracleScript) XXX_Unmarshal(b []byte) error

type MsgEditOracleScriptResponse

type MsgEditOracleScriptResponse struct {
}

MsgEditOracleScriptResponse is response data for MsgEditOracleScript message

func (*MsgEditOracleScriptResponse) Descriptor

func (*MsgEditOracleScriptResponse) Descriptor() ([]byte, []int)

func (*MsgEditOracleScriptResponse) Marshal

func (m *MsgEditOracleScriptResponse) Marshal() (dAtA []byte, err error)

func (*MsgEditOracleScriptResponse) MarshalTo

func (m *MsgEditOracleScriptResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgEditOracleScriptResponse) MarshalToSizedBuffer

func (m *MsgEditOracleScriptResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgEditOracleScriptResponse) ProtoMessage

func (*MsgEditOracleScriptResponse) ProtoMessage()

func (*MsgEditOracleScriptResponse) Reset

func (m *MsgEditOracleScriptResponse) Reset()

func (*MsgEditOracleScriptResponse) Size

func (m *MsgEditOracleScriptResponse) Size() (n int)

func (*MsgEditOracleScriptResponse) String

func (m *MsgEditOracleScriptResponse) String() string

func (*MsgEditOracleScriptResponse) Unmarshal

func (m *MsgEditOracleScriptResponse) Unmarshal(dAtA []byte) error

func (*MsgEditOracleScriptResponse) XXX_DiscardUnknown

func (m *MsgEditOracleScriptResponse) XXX_DiscardUnknown()

func (*MsgEditOracleScriptResponse) XXX_Marshal

func (m *MsgEditOracleScriptResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgEditOracleScriptResponse) XXX_Merge

func (m *MsgEditOracleScriptResponse) XXX_Merge(src proto.Message)

func (*MsgEditOracleScriptResponse) XXX_Size

func (m *MsgEditOracleScriptResponse) XXX_Size() int

func (*MsgEditOracleScriptResponse) XXX_Unmarshal

func (m *MsgEditOracleScriptResponse) XXX_Unmarshal(b []byte) error

type MsgReportData

type MsgReportData struct {
	// RequestID is the identifier of the request to be reported to.
	RequestID RequestID `protobuf:"varint,1,opt,name=request_id,json=requestId,proto3,casttype=RequestID" json:"request_id,omitempty"`
	// RawReports is the list of report information provided by data sources
	// identified by external ID
	RawReports []RawReport `protobuf:"bytes,2,rep,name=raw_reports,json=rawReports,proto3" json:"raw_reports"`
	// Validator is the address of the validator that owns this report.
	Validator string `protobuf:"bytes,3,opt,name=validator,proto3" json:"validator,omitempty"`
}

MsgReportData is a message for reporting to a data request by a validator.

func NewMsgReportData

func NewMsgReportData(requestID RequestID, rawReports []RawReport, validator sdk.ValAddress) *MsgReportData

NewMsgReportData creates a new MsgReportData instance

func (*MsgReportData) Descriptor

func (*MsgReportData) Descriptor() ([]byte, []int)

func (*MsgReportData) Equal

func (this *MsgReportData) Equal(that interface{}) bool

func (*MsgReportData) GetRawReports

func (m *MsgReportData) GetRawReports() []RawReport

func (*MsgReportData) GetRequestID

func (m *MsgReportData) GetRequestID() RequestID

func (MsgReportData) GetSignBytes

func (msg MsgReportData) GetSignBytes() []byte

GetSignBytes returns raw JSON bytes to be signed by the signers (sdk.Msg interface).

func (MsgReportData) GetSigners

func (msg MsgReportData) GetSigners() []sdk.AccAddress

GetSigners returns the required signers for the given MsgReportData (sdk.Msg interface).

func (*MsgReportData) GetValidator

func (m *MsgReportData) GetValidator() string

func (*MsgReportData) Marshal

func (m *MsgReportData) Marshal() (dAtA []byte, err error)

func (*MsgReportData) MarshalTo

func (m *MsgReportData) MarshalTo(dAtA []byte) (int, error)

func (*MsgReportData) MarshalToSizedBuffer

func (m *MsgReportData) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgReportData) ProtoMessage

func (*MsgReportData) ProtoMessage()

func (*MsgReportData) Reset

func (m *MsgReportData) Reset()

func (MsgReportData) Route

func (msg MsgReportData) Route() string

Route returns the route of MsgReportData - "oracle" (sdk.Msg interface).

func (*MsgReportData) Size

func (m *MsgReportData) Size() (n int)

func (*MsgReportData) String

func (m *MsgReportData) String() string

func (MsgReportData) Type

func (msg MsgReportData) Type() string

Type returns the message type of MsgReportData (sdk.Msg interface).

func (*MsgReportData) Unmarshal

func (m *MsgReportData) Unmarshal(dAtA []byte) error

func (MsgReportData) ValidateBasic

func (msg MsgReportData) ValidateBasic() error

ValidateBasic checks whether the given MsgReportData instance (sdk.Msg interface).

func (*MsgReportData) XXX_DiscardUnknown

func (m *MsgReportData) XXX_DiscardUnknown()

func (*MsgReportData) XXX_Marshal

func (m *MsgReportData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgReportData) XXX_Merge

func (m *MsgReportData) XXX_Merge(src proto.Message)

func (*MsgReportData) XXX_Size

func (m *MsgReportData) XXX_Size() int

func (*MsgReportData) XXX_Unmarshal

func (m *MsgReportData) XXX_Unmarshal(b []byte) error

type MsgReportDataResponse

type MsgReportDataResponse struct {
}

MsgReportDataResponse is response data for MsgReportData message

func (*MsgReportDataResponse) Descriptor

func (*MsgReportDataResponse) Descriptor() ([]byte, []int)

func (*MsgReportDataResponse) Marshal

func (m *MsgReportDataResponse) Marshal() (dAtA []byte, err error)

func (*MsgReportDataResponse) MarshalTo

func (m *MsgReportDataResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgReportDataResponse) MarshalToSizedBuffer

func (m *MsgReportDataResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgReportDataResponse) ProtoMessage

func (*MsgReportDataResponse) ProtoMessage()

func (*MsgReportDataResponse) Reset

func (m *MsgReportDataResponse) Reset()

func (*MsgReportDataResponse) Size

func (m *MsgReportDataResponse) Size() (n int)

func (*MsgReportDataResponse) String

func (m *MsgReportDataResponse) String() string

func (*MsgReportDataResponse) Unmarshal

func (m *MsgReportDataResponse) Unmarshal(dAtA []byte) error

func (*MsgReportDataResponse) XXX_DiscardUnknown

func (m *MsgReportDataResponse) XXX_DiscardUnknown()

func (*MsgReportDataResponse) XXX_Marshal

func (m *MsgReportDataResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgReportDataResponse) XXX_Merge

func (m *MsgReportDataResponse) XXX_Merge(src proto.Message)

func (*MsgReportDataResponse) XXX_Size

func (m *MsgReportDataResponse) XXX_Size() int

func (*MsgReportDataResponse) XXX_Unmarshal

func (m *MsgReportDataResponse) XXX_Unmarshal(b []byte) error

type MsgRequestData

type MsgRequestData struct {
	// OracleScriptID is the identifier of the oracle script to be called.
	OracleScriptID OracleScriptID `` /* 130-byte string literal not displayed */
	// Calldata is the OBI-encoded call parameters for the oracle script.
	Calldata []byte `protobuf:"bytes,2,opt,name=calldata,proto3" json:"calldata,omitempty"`
	// AskCount is the number of validators to perform the oracle task.
	AskCount uint64 `protobuf:"varint,3,opt,name=ask_count,json=askCount,proto3" json:"ask_count,omitempty"`
	// MinCount is the minimum number of validators sufficient to resolve the
	// oracle tasks.
	MinCount uint64 `protobuf:"varint,4,opt,name=min_count,json=minCount,proto3" json:"min_count,omitempty"`
	// ClientID is the client-provided unique identifier to track the request.
	ClientID string `protobuf:"bytes,5,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"`
	// FeeLimit is the maximum tokens that will be paid to all data source
	// providers.
	FeeLimit github_com_cosmos_cosmos_sdk_types.Coins `` /* 129-byte string literal not displayed */
	// PrepareGas is amount of gas to pay to prepare raw requests
	PrepareGas uint64 `protobuf:"varint,7,opt,name=prepare_gas,json=prepareGas,proto3" json:"prepare_gas,omitempty"`
	// ExecuteGas is amount of gas to reserve for executing
	ExecuteGas uint64 `protobuf:"varint,8,opt,name=execute_gas,json=executeGas,proto3" json:"execute_gas,omitempty"`
	// Sender is an account address of message sender.
	Sender string `protobuf:"bytes,9,opt,name=sender,proto3" json:"sender,omitempty"`
}

MsgRequestData is a message for sending a data oracle request.

func NewMsgRequestData

func NewMsgRequestData(
	oracleScriptID OracleScriptID,
	calldata []byte,
	askCount, minCount uint64,
	clientID string,
	feeLimit sdk.Coins,
	prepareGas, executeGas uint64,
	sender sdk.AccAddress,
) *MsgRequestData

NewMsgRequestData creates a new MsgRequestData instance.

func (*MsgRequestData) Descriptor

func (*MsgRequestData) Descriptor() ([]byte, []int)

func (*MsgRequestData) Equal

func (this *MsgRequestData) Equal(that interface{}) bool

func (*MsgRequestData) GetAskCount

func (m *MsgRequestData) GetAskCount() uint64

func (*MsgRequestData) GetCalldata

func (m *MsgRequestData) GetCalldata() []byte

func (*MsgRequestData) GetClientID

func (m *MsgRequestData) GetClientID() string

func (*MsgRequestData) GetExecuteGas

func (m *MsgRequestData) GetExecuteGas() uint64

func (*MsgRequestData) GetFeeLimit

func (*MsgRequestData) GetMinCount

func (m *MsgRequestData) GetMinCount() uint64

func (*MsgRequestData) GetOracleScriptID

func (m *MsgRequestData) GetOracleScriptID() OracleScriptID

func (*MsgRequestData) GetPrepareGas

func (m *MsgRequestData) GetPrepareGas() uint64

func (*MsgRequestData) GetSender

func (m *MsgRequestData) GetSender() string

func (MsgRequestData) GetSignBytes

func (msg MsgRequestData) GetSignBytes() []byte

GetSignBytes returns raw JSON bytes to be signed by the signers (sdk.Msg interface).

func (MsgRequestData) GetSigners

func (msg MsgRequestData) GetSigners() []sdk.AccAddress

GetSigners returns the required signers for the given MsgRequestData (sdk.Msg interface).

func (*MsgRequestData) Marshal

func (m *MsgRequestData) Marshal() (dAtA []byte, err error)

func (*MsgRequestData) MarshalTo

func (m *MsgRequestData) MarshalTo(dAtA []byte) (int, error)

func (*MsgRequestData) MarshalToSizedBuffer

func (m *MsgRequestData) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgRequestData) ProtoMessage

func (*MsgRequestData) ProtoMessage()

func (*MsgRequestData) Reset

func (m *MsgRequestData) Reset()

func (MsgRequestData) Route

func (msg MsgRequestData) Route() string

Route returns the route of MsgRequestData - "oracle" (sdk.Msg interface).

func (*MsgRequestData) Size

func (m *MsgRequestData) Size() (n int)

func (*MsgRequestData) String

func (m *MsgRequestData) String() string

func (MsgRequestData) Type

func (msg MsgRequestData) Type() string

Type returns the message type of MsgRequestData (sdk.Msg interface).

func (*MsgRequestData) Unmarshal

func (m *MsgRequestData) Unmarshal(dAtA []byte) error

func (MsgRequestData) ValidateBasic

func (msg MsgRequestData) ValidateBasic() error

ValidateBasic checks whether the given MsgRequestData instance (sdk.Msg interface).

func (*MsgRequestData) XXX_DiscardUnknown

func (m *MsgRequestData) XXX_DiscardUnknown()

func (*MsgRequestData) XXX_Marshal

func (m *MsgRequestData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgRequestData) XXX_Merge

func (m *MsgRequestData) XXX_Merge(src proto.Message)

func (*MsgRequestData) XXX_Size

func (m *MsgRequestData) XXX_Size() int

func (*MsgRequestData) XXX_Unmarshal

func (m *MsgRequestData) XXX_Unmarshal(b []byte) error

type MsgRequestDataResponse

type MsgRequestDataResponse struct {
}

MsgRequestDataResponse is response data for MsgRequestData message

func (*MsgRequestDataResponse) Descriptor

func (*MsgRequestDataResponse) Descriptor() ([]byte, []int)

func (*MsgRequestDataResponse) Marshal

func (m *MsgRequestDataResponse) Marshal() (dAtA []byte, err error)

func (*MsgRequestDataResponse) MarshalTo

func (m *MsgRequestDataResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgRequestDataResponse) MarshalToSizedBuffer

func (m *MsgRequestDataResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgRequestDataResponse) ProtoMessage

func (*MsgRequestDataResponse) ProtoMessage()

func (*MsgRequestDataResponse) Reset

func (m *MsgRequestDataResponse) Reset()

func (*MsgRequestDataResponse) Size

func (m *MsgRequestDataResponse) Size() (n int)

func (*MsgRequestDataResponse) String

func (m *MsgRequestDataResponse) String() string

func (*MsgRequestDataResponse) Unmarshal

func (m *MsgRequestDataResponse) Unmarshal(dAtA []byte) error

func (*MsgRequestDataResponse) XXX_DiscardUnknown

func (m *MsgRequestDataResponse) XXX_DiscardUnknown()

func (*MsgRequestDataResponse) XXX_Marshal

func (m *MsgRequestDataResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgRequestDataResponse) XXX_Merge

func (m *MsgRequestDataResponse) XXX_Merge(src proto.Message)

func (*MsgRequestDataResponse) XXX_Size

func (m *MsgRequestDataResponse) XXX_Size() int

func (*MsgRequestDataResponse) XXX_Unmarshal

func (m *MsgRequestDataResponse) XXX_Unmarshal(b []byte) error

type MsgServer

type MsgServer interface {
	// RequestData defines a method for submitting a new request.
	RequestData(context.Context, *MsgRequestData) (*MsgRequestDataResponse, error)
	// ReportData defines a method for reporting a data to resolve the request.
	ReportData(context.Context, *MsgReportData) (*MsgReportDataResponse, error)
	// CreateDataSource defines a method for creating a new data source.
	CreateDataSource(context.Context, *MsgCreateDataSource) (*MsgCreateDataSourceResponse, error)
	// EditDataSource defines a method for editing an existing data source.
	EditDataSource(context.Context, *MsgEditDataSource) (*MsgEditDataSourceResponse, error)
	// CreateOracleScript defines a method for creating a new oracle script.
	CreateOracleScript(context.Context, *MsgCreateOracleScript) (*MsgCreateOracleScriptResponse, error)
	// EditOracleScript defines a method for editing an existing oracle script.
	EditOracleScript(context.Context, *MsgEditOracleScript) (*MsgEditOracleScriptResponse, error)
	// Activate defines a method for applying to be an oracle validator.
	Activate(context.Context, *MsgActivate) (*MsgActivateResponse, error)
}

MsgServer is the server API for Msg service.

type OracleRequestPacketAcknowledgement

type OracleRequestPacketAcknowledgement struct {
	// RequestID is BandChain's unique identifier for this oracle request.
	RequestID RequestID `protobuf:"varint,1,opt,name=request_id,json=requestId,proto3,casttype=RequestID" json:"request_id,omitempty"`
}

OracleRequestPacketAcknowledgement encodes an oracle request acknowledgement send back to requester chain.

func NewOracleRequestPacketAcknowledgement

func NewOracleRequestPacketAcknowledgement(requestID RequestID) *OracleRequestPacketAcknowledgement

func (*OracleRequestPacketAcknowledgement) Descriptor

func (*OracleRequestPacketAcknowledgement) Descriptor() ([]byte, []int)

func (*OracleRequestPacketAcknowledgement) Equal

func (this *OracleRequestPacketAcknowledgement) Equal(that interface{}) bool

func (*OracleRequestPacketAcknowledgement) GetRequestID

func (*OracleRequestPacketAcknowledgement) Marshal

func (m *OracleRequestPacketAcknowledgement) Marshal() (dAtA []byte, err error)

func (*OracleRequestPacketAcknowledgement) MarshalTo

func (m *OracleRequestPacketAcknowledgement) MarshalTo(dAtA []byte) (int, error)

func (*OracleRequestPacketAcknowledgement) MarshalToSizedBuffer

func (m *OracleRequestPacketAcknowledgement) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*OracleRequestPacketAcknowledgement) ProtoMessage

func (*OracleRequestPacketAcknowledgement) ProtoMessage()

func (*OracleRequestPacketAcknowledgement) Reset

func (*OracleRequestPacketAcknowledgement) Size

func (*OracleRequestPacketAcknowledgement) String

func (*OracleRequestPacketAcknowledgement) Unmarshal

func (m *OracleRequestPacketAcknowledgement) Unmarshal(dAtA []byte) error

func (*OracleRequestPacketAcknowledgement) XXX_DiscardUnknown

func (m *OracleRequestPacketAcknowledgement) XXX_DiscardUnknown()

func (*OracleRequestPacketAcknowledgement) XXX_Marshal

func (m *OracleRequestPacketAcknowledgement) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*OracleRequestPacketAcknowledgement) XXX_Merge

func (*OracleRequestPacketAcknowledgement) XXX_Size

func (*OracleRequestPacketAcknowledgement) XXX_Unmarshal

func (m *OracleRequestPacketAcknowledgement) XXX_Unmarshal(b []byte) error

type OracleRequestPacketData

type OracleRequestPacketData struct {
	// ClientID is the unique identifier of this oracle request, as specified by
	// the client. This same unique ID will be sent back to the requester with the
	// oracle response.
	ClientID string `protobuf:"bytes,1,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"`
	// OracleScriptID is the unique identifier of the oracle script to be
	// executed.
	OracleScriptID OracleScriptID `` /* 130-byte string literal not displayed */
	// Calldata is the OBI-encoded calldata bytes available for oracle executor to
	// read.
	Calldata []byte `protobuf:"bytes,3,opt,name=calldata,proto3" json:"calldata,omitempty"`
	// AskCount is the number of validators that are requested to respond to this
	// oracle request. Higher value means more security, at a higher gas cost.
	AskCount uint64 `protobuf:"varint,4,opt,name=ask_count,json=askCount,proto3" json:"ask_count,omitempty"`
	// MinCount is the minimum number of validators necessary for the request to
	// proceed to the execution phase. Higher value means more security, at the
	// cost of liveness.
	MinCount uint64 `protobuf:"varint,5,opt,name=min_count,json=minCount,proto3" json:"min_count,omitempty"`
	// FeeLimit is the maximum tokens that will be paid to all data source
	// providers.
	FeeLimit github_com_cosmos_cosmos_sdk_types.Coins `` /* 129-byte string literal not displayed */
	// PrepareGas is amount of gas to pay to prepare raw requests
	PrepareGas uint64 `protobuf:"varint,7,opt,name=prepare_gas,json=prepareGas,proto3" json:"prepare_gas,omitempty"`
	// ExecuteGas is amount of gas to reserve for executing
	ExecuteGas uint64 `protobuf:"varint,8,opt,name=execute_gas,json=executeGas,proto3" json:"execute_gas,omitempty"`
}

OracleRequestPacketData encodes an oracle request sent from other blockchains to BandChain.

func NewOracleRequestPacketData

func NewOracleRequestPacketData(
	clientID string,
	oracleScriptID OracleScriptID,
	calldata []byte,
	askCount uint64,
	minCount uint64,
	feeLimit sdk.Coins,
	prepareGas uint64,
	executeGas uint64,
) OracleRequestPacketData

NewOracleRequestPacketData contructs a new OracleRequestPacketData instance

func (*OracleRequestPacketData) Descriptor

func (*OracleRequestPacketData) Descriptor() ([]byte, []int)

func (*OracleRequestPacketData) Equal

func (this *OracleRequestPacketData) Equal(that interface{}) bool

func (*OracleRequestPacketData) GetAskCount

func (m *OracleRequestPacketData) GetAskCount() uint64

func (OracleRequestPacketData) GetBytes

func (p OracleRequestPacketData) GetBytes() []byte

GetBytes is a helper for serialising

func (*OracleRequestPacketData) GetCalldata

func (m *OracleRequestPacketData) GetCalldata() []byte

func (*OracleRequestPacketData) GetClientID

func (m *OracleRequestPacketData) GetClientID() string

func (*OracleRequestPacketData) GetExecuteGas

func (m *OracleRequestPacketData) GetExecuteGas() uint64

func (*OracleRequestPacketData) GetFeeLimit

func (*OracleRequestPacketData) GetMinCount

func (m *OracleRequestPacketData) GetMinCount() uint64

func (*OracleRequestPacketData) GetOracleScriptID

func (m *OracleRequestPacketData) GetOracleScriptID() OracleScriptID

func (*OracleRequestPacketData) GetPrepareGas

func (m *OracleRequestPacketData) GetPrepareGas() uint64

func (*OracleRequestPacketData) Marshal

func (m *OracleRequestPacketData) Marshal() (dAtA []byte, err error)

func (*OracleRequestPacketData) MarshalTo

func (m *OracleRequestPacketData) MarshalTo(dAtA []byte) (int, error)

func (*OracleRequestPacketData) MarshalToSizedBuffer

func (m *OracleRequestPacketData) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*OracleRequestPacketData) ProtoMessage

func (*OracleRequestPacketData) ProtoMessage()

func (*OracleRequestPacketData) Reset

func (m *OracleRequestPacketData) Reset()

func (*OracleRequestPacketData) Size

func (m *OracleRequestPacketData) Size() (n int)

func (*OracleRequestPacketData) String

func (m *OracleRequestPacketData) String() string

func (*OracleRequestPacketData) Unmarshal

func (m *OracleRequestPacketData) Unmarshal(dAtA []byte) error

func (OracleRequestPacketData) ValidateBasic

func (p OracleRequestPacketData) ValidateBasic() error

ValidateBasic is used for validating the request.

func (*OracleRequestPacketData) XXX_DiscardUnknown

func (m *OracleRequestPacketData) XXX_DiscardUnknown()

func (*OracleRequestPacketData) XXX_Marshal

func (m *OracleRequestPacketData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*OracleRequestPacketData) XXX_Merge

func (m *OracleRequestPacketData) XXX_Merge(src proto.Message)

func (*OracleRequestPacketData) XXX_Size

func (m *OracleRequestPacketData) XXX_Size() int

func (*OracleRequestPacketData) XXX_Unmarshal

func (m *OracleRequestPacketData) XXX_Unmarshal(b []byte) error

type OracleResponsePacketData

type OracleResponsePacketData struct {
	// ClientID is the unique identifier matched with that of the oracle request
	// packet.
	ClientID string `protobuf:"bytes,1,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"`
	// RequestID is BandChain's unique identifier for this oracle request.
	RequestID RequestID `protobuf:"varint,2,opt,name=request_id,json=requestId,proto3,casttype=RequestID" json:"request_id,omitempty"`
	// AnsCount is the number of validators among to the asked validators that
	// actually responded to this oracle request prior to this oracle request
	// being resolved.
	AnsCount uint64 `protobuf:"varint,3,opt,name=ans_count,json=ansCount,proto3" json:"ans_count,omitempty"`
	// RequestTime is the UNIX epoch time at which the request was sent to
	// BandChain.
	RequestTime int64 `protobuf:"varint,4,opt,name=request_time,json=requestTime,proto3" json:"request_time,omitempty"`
	// ResolveTime is the UNIX epoch time at which the request was resolved to the
	// final result.
	ResolveTime int64 `protobuf:"varint,5,opt,name=resolve_time,json=resolveTime,proto3" json:"resolve_time,omitempty"`
	// ResolveStatus is the status of this oracle request, which can be OK,
	// FAILURE, or EXPIRED.
	ResolveStatus ResolveStatus `` /* 130-byte string literal not displayed */
	// Result is the final aggregated value encoded in OBI format. Only available
	// if status if OK.
	Result []byte `protobuf:"bytes,7,opt,name=result,proto3" json:"result,omitempty"`
}

OracleResponsePacketData encodes an oracle response from BandChain to the requester.

func NewOracleResponsePacketData

func NewOracleResponsePacketData(
	clientID string, requestID RequestID, ansCount uint64, requestTime int64,
	resolveTime int64, resolveStatus ResolveStatus, result []byte,
) OracleResponsePacketData

NewOracleResponsePacketData contructs a new OracleResponsePacketData instance

func (*OracleResponsePacketData) Descriptor

func (*OracleResponsePacketData) Descriptor() ([]byte, []int)

func (*OracleResponsePacketData) Equal

func (this *OracleResponsePacketData) Equal(that interface{}) bool

func (*OracleResponsePacketData) GetAnsCount

func (m *OracleResponsePacketData) GetAnsCount() uint64

func (OracleResponsePacketData) GetBytes

func (p OracleResponsePacketData) GetBytes() []byte

GetBytes returns the bytes representation of this oracle response packet data.

func (*OracleResponsePacketData) GetClientID

func (m *OracleResponsePacketData) GetClientID() string

func (*OracleResponsePacketData) GetRequestID

func (m *OracleResponsePacketData) GetRequestID() RequestID

func (*OracleResponsePacketData) GetRequestTime

func (m *OracleResponsePacketData) GetRequestTime() int64

func (*OracleResponsePacketData) GetResolveStatus

func (m *OracleResponsePacketData) GetResolveStatus() ResolveStatus

func (*OracleResponsePacketData) GetResolveTime

func (m *OracleResponsePacketData) GetResolveTime() int64

func (*OracleResponsePacketData) GetResult

func (m *OracleResponsePacketData) GetResult() []byte

func (*OracleResponsePacketData) Marshal

func (m *OracleResponsePacketData) Marshal() (dAtA []byte, err error)

func (*OracleResponsePacketData) MarshalTo

func (m *OracleResponsePacketData) MarshalTo(dAtA []byte) (int, error)

func (*OracleResponsePacketData) MarshalToSizedBuffer

func (m *OracleResponsePacketData) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*OracleResponsePacketData) ProtoMessage

func (*OracleResponsePacketData) ProtoMessage()

func (*OracleResponsePacketData) Reset

func (m *OracleResponsePacketData) Reset()

func (*OracleResponsePacketData) Size

func (m *OracleResponsePacketData) Size() (n int)

func (*OracleResponsePacketData) String

func (m *OracleResponsePacketData) String() string

func (*OracleResponsePacketData) Unmarshal

func (m *OracleResponsePacketData) Unmarshal(dAtA []byte) error

func (*OracleResponsePacketData) XXX_DiscardUnknown

func (m *OracleResponsePacketData) XXX_DiscardUnknown()

func (*OracleResponsePacketData) XXX_Marshal

func (m *OracleResponsePacketData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*OracleResponsePacketData) XXX_Merge

func (m *OracleResponsePacketData) XXX_Merge(src proto.Message)

func (*OracleResponsePacketData) XXX_Size

func (m *OracleResponsePacketData) XXX_Size() int

func (*OracleResponsePacketData) XXX_Unmarshal

func (m *OracleResponsePacketData) XXX_Unmarshal(b []byte) error

type OracleScript

type OracleScript struct {
	// Owner is an address of the account who own the oracle script
	Owner string `protobuf:"bytes,1,opt,name=owner,proto3" json:"owner,omitempty"`
	// Name is oracle script name used for display
	Name string `protobuf:"bytes,2,opt,name=name,proto3" json:"name,omitempty"`
	// Description is oracle script description used for display
	Description string `protobuf:"bytes,3,opt,name=description,proto3" json:"description,omitempty"`
	// Filename is string of file name used as reference for locating
	// compiled oracle script WASM file stored in bandchain nodes
	Filename string `protobuf:"bytes,4,opt,name=filename,proto3" json:"filename,omitempty"`
	// Schema is the schema of the oracle script input/output
	// which is formatted in OBI format e.g.
	// "{symbol:string,multiplier:u64}/{px:u64}"
	Schema string `protobuf:"bytes,5,opt,name=schema,proto3" json:"schema,omitempty"`
	// SourceCodeURL is the URL of oracle script's source code.
	// It is recommendded to store source code on IPFS and get its URL to preserve
	// decentralization.
	SourceCodeURL string `protobuf:"bytes,6,opt,name=source_code_url,json=sourceCodeUrl,proto3" json:"source_code_url,omitempty"`
}

OracleScript is the data structure for storing oracle scripts in the storage.

func NewOracleScript

func NewOracleScript(
	Owner sdk.AccAddress,
	Name string,
	Description string,
	Filename string,
	Schema string,
	SourceCodeURL string,
) OracleScript

func (*OracleScript) Descriptor

func (*OracleScript) Descriptor() ([]byte, []int)

func (*OracleScript) Equal

func (this *OracleScript) Equal(that interface{}) bool

func (*OracleScript) GetDescription

func (m *OracleScript) GetDescription() string

func (*OracleScript) GetFilename

func (m *OracleScript) GetFilename() string

func (*OracleScript) GetName

func (m *OracleScript) GetName() string

func (*OracleScript) GetOwner

func (m *OracleScript) GetOwner() string

func (*OracleScript) GetSchema

func (m *OracleScript) GetSchema() string

func (*OracleScript) GetSourceCodeURL

func (m *OracleScript) GetSourceCodeURL() string

func (*OracleScript) Marshal

func (m *OracleScript) Marshal() (dAtA []byte, err error)

func (*OracleScript) MarshalTo

func (m *OracleScript) MarshalTo(dAtA []byte) (int, error)

func (*OracleScript) MarshalToSizedBuffer

func (m *OracleScript) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*OracleScript) ProtoMessage

func (*OracleScript) ProtoMessage()

func (*OracleScript) Reset

func (m *OracleScript) Reset()

func (*OracleScript) Size

func (m *OracleScript) Size() (n int)

func (*OracleScript) String

func (m *OracleScript) String() string

func (*OracleScript) Unmarshal

func (m *OracleScript) Unmarshal(dAtA []byte) error

func (*OracleScript) XXX_DiscardUnknown

func (m *OracleScript) XXX_DiscardUnknown()

func (*OracleScript) XXX_Marshal

func (m *OracleScript) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*OracleScript) XXX_Merge

func (m *OracleScript) XXX_Merge(src proto.Message)

func (*OracleScript) XXX_Size

func (m *OracleScript) XXX_Size() int

func (*OracleScript) XXX_Unmarshal

func (m *OracleScript) XXX_Unmarshal(b []byte) error

type OracleScriptID

type OracleScriptID uint64

OracleScriptID is the type-safe unique identifier type for oracle scripts.

type Params

type Params struct {
	// MaxRawRequestCount is the maximum number of data source raw requests a
	// request can make.
	MaxRawRequestCount uint64 `protobuf:"varint,1,opt,name=max_raw_request_count,json=maxRawRequestCount,proto3" json:"max_raw_request_count,omitempty"`
	// MaxAskCount is the maximum number of validators a request can target.
	MaxAskCount uint64 `protobuf:"varint,2,opt,name=max_ask_count,json=maxAskCount,proto3" json:"max_ask_count,omitempty"`
	// MaxCalldataSize is the maximum size limit of calldata (bytes) in a request.
	MaxCalldataSize uint64 `protobuf:"varint,3,opt,name=max_calldata_size,json=maxCalldataSize,proto3" json:"max_calldata_size,omitempty"`
	// MaxReportDataSize is the maximum size limit of report data (bytes) in a
	// report.
	MaxReportDataSize uint64 `protobuf:"varint,4,opt,name=max_report_data_size,json=maxReportDataSize,proto3" json:"max_report_data_size,omitempty"`
	// ExpirationBlockCount is the number of blocks a request stays valid before
	// it gets expired due to insufficient reports.
	ExpirationBlockCount uint64 `protobuf:"varint,5,opt,name=expiration_block_count,json=expirationBlockCount,proto3" json:"expiration_block_count,omitempty"`
	// BaseOwasmGas is the base amount of Cosmos-SDK gas charged for owasm
	// execution.
	BaseOwasmGas uint64 `protobuf:"varint,6,opt,name=base_owasm_gas,json=baseOwasmGas,proto3" json:"base_owasm_gas,omitempty"`
	// PerValidatorRequestGas is the amount of Cosmos-SDK gas charged per
	// requested validator.
	PerValidatorRequestGas uint64 `` /* 132-byte string literal not displayed */
	// SamplingTryCount the number of validator sampling tries to pick the highest
	// voting power subset of validators to perform an oracle task.
	SamplingTryCount uint64 `protobuf:"varint,8,opt,name=sampling_try_count,json=samplingTryCount,proto3" json:"sampling_try_count,omitempty"`
	// OracleRewardPercentage is the percentage of block rewards allocated to
	// active oracle validators.
	OracleRewardPercentage uint64 `` /* 130-byte string literal not displayed */
	// InactivePenaltyDuration is the duration period where a validator cannot
	// activate back after missing an oracle report.
	InactivePenaltyDuration uint64 `` /* 134-byte string literal not displayed */
	// IBCRequestEnabled is a flag indicating whether sending oracle request via
	// IBC is allowed
	IBCRequestEnabled bool `protobuf:"varint,11,opt,name=ibc_request_enabled,json=ibcRequestEnabled,proto3" json:"ibc_request_enabled,omitempty"`
}

Params is the data structure that keeps the parameters of the oracle module.

func DefaultParams

func DefaultParams() Params

DefaultParams defines the default parameters.

func NewParams

func NewParams(
	maxRawRequestCount, maxAskCount, maxCalldataSize, maxReportDataSize, expirationBlockCount, baseRequestGas, perValidatorRequestGas,
	samplingTryCount, oracleRewardPercentage, inactivePenaltyDuration uint64,
	ibcRequestEnabled bool,
) Params

NewParams creates a new parameter configuration for the oracle module

func (*Params) Descriptor

func (*Params) Descriptor() ([]byte, []int)

func (*Params) Equal

func (this *Params) Equal(that interface{}) bool

func (*Params) GetBaseOwasmGas

func (m *Params) GetBaseOwasmGas() uint64

func (*Params) GetExpirationBlockCount

func (m *Params) GetExpirationBlockCount() uint64

func (*Params) GetIBCRequestEnabled

func (m *Params) GetIBCRequestEnabled() bool

func (*Params) GetInactivePenaltyDuration

func (m *Params) GetInactivePenaltyDuration() uint64

func (*Params) GetMaxAskCount

func (m *Params) GetMaxAskCount() uint64

func (*Params) GetMaxCalldataSize added in v2.1.1

func (m *Params) GetMaxCalldataSize() uint64

func (*Params) GetMaxRawRequestCount

func (m *Params) GetMaxRawRequestCount() uint64

func (*Params) GetMaxReportDataSize added in v2.1.1

func (m *Params) GetMaxReportDataSize() uint64

func (*Params) GetOracleRewardPercentage

func (m *Params) GetOracleRewardPercentage() uint64

func (*Params) GetPerValidatorRequestGas

func (m *Params) GetPerValidatorRequestGas() uint64

func (*Params) GetSamplingTryCount

func (m *Params) GetSamplingTryCount() uint64

func (*Params) Marshal

func (m *Params) Marshal() (dAtA []byte, err error)

func (*Params) MarshalTo

func (m *Params) MarshalTo(dAtA []byte) (int, error)

func (*Params) MarshalToSizedBuffer

func (m *Params) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*Params) ParamSetPairs

func (p *Params) ParamSetPairs() paramtypes.ParamSetPairs

ParamSetPairs implements the paramtypes.ParamSet interface for Params.

func (*Params) ProtoMessage

func (*Params) ProtoMessage()

func (*Params) Reset

func (m *Params) Reset()

func (*Params) Size

func (m *Params) Size() (n int)

func (Params) String

func (p Params) String() string

String returns a human readable string representation of the parameters.

func (*Params) Unmarshal

func (m *Params) Unmarshal(dAtA []byte) error

func (*Params) XXX_DiscardUnknown

func (m *Params) XXX_DiscardUnknown()

func (*Params) XXX_Marshal

func (m *Params) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Params) XXX_Merge

func (m *Params) XXX_Merge(src proto.Message)

func (*Params) XXX_Size

func (m *Params) XXX_Size() int

func (*Params) XXX_Unmarshal

func (m *Params) XXX_Unmarshal(b []byte) error

type PendingResolveList

type PendingResolveList struct {
	// RequestIDs is a list of request IDs that are waiting to be resolved
	RequestIds []uint64 `protobuf:"varint,1,rep,packed,name=request_ids,json=requestIds,proto3" json:"request_ids,omitempty"`
}

PendingResolveList is a list of requests that are waiting to be resolved

func (*PendingResolveList) Descriptor

func (*PendingResolveList) Descriptor() ([]byte, []int)

func (*PendingResolveList) Equal

func (this *PendingResolveList) Equal(that interface{}) bool

func (*PendingResolveList) GetRequestIds

func (m *PendingResolveList) GetRequestIds() []uint64

func (*PendingResolveList) Marshal

func (m *PendingResolveList) Marshal() (dAtA []byte, err error)

func (*PendingResolveList) MarshalTo

func (m *PendingResolveList) MarshalTo(dAtA []byte) (int, error)

func (*PendingResolveList) MarshalToSizedBuffer

func (m *PendingResolveList) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*PendingResolveList) ProtoMessage

func (*PendingResolveList) ProtoMessage()

func (*PendingResolveList) Reset

func (m *PendingResolveList) Reset()

func (*PendingResolveList) Size

func (m *PendingResolveList) Size() (n int)

func (*PendingResolveList) String

func (m *PendingResolveList) String() string

func (*PendingResolveList) Unmarshal

func (m *PendingResolveList) Unmarshal(dAtA []byte) error

func (*PendingResolveList) XXX_DiscardUnknown

func (m *PendingResolveList) XXX_DiscardUnknown()

func (*PendingResolveList) XXX_Marshal

func (m *PendingResolveList) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*PendingResolveList) XXX_Merge

func (m *PendingResolveList) XXX_Merge(src proto.Message)

func (*PendingResolveList) XXX_Size

func (m *PendingResolveList) XXX_Size() int

func (*PendingResolveList) XXX_Unmarshal

func (m *PendingResolveList) XXX_Unmarshal(b []byte) error

type PortKeeper

type PortKeeper interface {
	BindPort(ctx sdk.Context, portID string) *capabilitytypes.Capability
}

PortKeeper defines the expected IBC port keeper

type PrepareEnv

type PrepareEnv struct {
	BaseEnv
	// contains filtered or unexported fields
}

PrepareEnv implements ExecEnv interface only expected function and panic on non-prepare functions.

func NewPrepareEnv

func NewPrepareEnv(req Request, maxCalldataSize int64, maxRawRequests int64, spanSize int64) *PrepareEnv

NewPrepareEnv creates a new environment instance for prepare period.

func (*PrepareEnv) AskExternalData

func (env *PrepareEnv) AskExternalData(eid int64, did int64, data []byte) error

AskExternalData implements Owasm ExecEnv interface.

func (*PrepareEnv) GetRawRequests

func (env *PrepareEnv) GetRawRequests() []RawRequest

GetRawRequests returns the list of raw requests made during Owasm prepare run.

type PriceResult

type PriceResult struct {
	// Symbol is unit of data indicating what the data is. It is price currencies
	// for this case.
	Symbol string `protobuf:"bytes,1,opt,name=symbol,proto3" json:"symbol,omitempty"`
	// Multiplier is a number used for left-shifting value to eliminate decimal
	// digits
	Multiplier uint64 `protobuf:"varint,2,opt,name=multiplier,proto3" json:"multiplier,omitempty"`
	// Px is the actual data, which is rate number multiplied by the multiplier.
	Px uint64 `protobuf:"varint,3,opt,name=px,proto3" json:"px,omitempty"`
	// RequestID is oracle request ID that contains this price
	RequestID RequestID `protobuf:"varint,4,opt,name=request_id,json=requestId,proto3,casttype=RequestID" json:"request_id,omitempty"`
	// ResolveTime is epoch timestamp indicating the time when the request had
	// been resolved
	ResolveTime int64 `protobuf:"varint,5,opt,name=resolve_time,json=resolveTime,proto3" json:"resolve_time,omitempty"`
}

PriceResult is a result from standard price reference

func (*PriceResult) Descriptor

func (*PriceResult) Descriptor() ([]byte, []int)

func (*PriceResult) GetMultiplier

func (m *PriceResult) GetMultiplier() uint64

func (*PriceResult) GetPx

func (m *PriceResult) GetPx() uint64

func (*PriceResult) GetRequestID

func (m *PriceResult) GetRequestID() RequestID

func (*PriceResult) GetResolveTime

func (m *PriceResult) GetResolveTime() int64

func (*PriceResult) GetSymbol

func (m *PriceResult) GetSymbol() string

func (*PriceResult) Marshal

func (m *PriceResult) Marshal() (dAtA []byte, err error)

func (*PriceResult) MarshalTo

func (m *PriceResult) MarshalTo(dAtA []byte) (int, error)

func (*PriceResult) MarshalToSizedBuffer

func (m *PriceResult) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*PriceResult) ProtoMessage

func (*PriceResult) ProtoMessage()

func (*PriceResult) Reset

func (m *PriceResult) Reset()

func (*PriceResult) Size

func (m *PriceResult) Size() (n int)

func (*PriceResult) String

func (m *PriceResult) String() string

func (*PriceResult) Unmarshal

func (m *PriceResult) Unmarshal(dAtA []byte) error

func (*PriceResult) XXX_DiscardUnknown

func (m *PriceResult) XXX_DiscardUnknown()

func (*PriceResult) XXX_Marshal

func (m *PriceResult) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*PriceResult) XXX_Merge

func (m *PriceResult) XXX_Merge(src proto.Message)

func (*PriceResult) XXX_Size

func (m *PriceResult) XXX_Size() int

func (*PriceResult) XXX_Unmarshal

func (m *PriceResult) XXX_Unmarshal(b []byte) error

type QueryActiveValidatorResult

type QueryActiveValidatorResult struct {
	Address sdk.ValAddress `json:"address"`
	Power   uint64         `json:"power"`
}

QueryActiveValidatorResult is the struct for the result of request active validators.

type QueryActiveValidatorsRequest

type QueryActiveValidatorsRequest struct {
}

QueryActiveValidatorsRequest is request type for the Query/ActiveValidators RPC method.

func (*QueryActiveValidatorsRequest) Descriptor

func (*QueryActiveValidatorsRequest) Descriptor() ([]byte, []int)

func (*QueryActiveValidatorsRequest) Marshal

func (m *QueryActiveValidatorsRequest) Marshal() (dAtA []byte, err error)

func (*QueryActiveValidatorsRequest) MarshalTo

func (m *QueryActiveValidatorsRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryActiveValidatorsRequest) MarshalToSizedBuffer

func (m *QueryActiveValidatorsRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryActiveValidatorsRequest) ProtoMessage

func (*QueryActiveValidatorsRequest) ProtoMessage()

func (*QueryActiveValidatorsRequest) Reset

func (m *QueryActiveValidatorsRequest) Reset()

func (*QueryActiveValidatorsRequest) Size

func (m *QueryActiveValidatorsRequest) Size() (n int)

func (*QueryActiveValidatorsRequest) String

func (*QueryActiveValidatorsRequest) Unmarshal

func (m *QueryActiveValidatorsRequest) Unmarshal(dAtA []byte) error

func (*QueryActiveValidatorsRequest) XXX_DiscardUnknown

func (m *QueryActiveValidatorsRequest) XXX_DiscardUnknown()

func (*QueryActiveValidatorsRequest) XXX_Marshal

func (m *QueryActiveValidatorsRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryActiveValidatorsRequest) XXX_Merge

func (m *QueryActiveValidatorsRequest) XXX_Merge(src proto.Message)

func (*QueryActiveValidatorsRequest) XXX_Size

func (m *QueryActiveValidatorsRequest) XXX_Size() int

func (*QueryActiveValidatorsRequest) XXX_Unmarshal

func (m *QueryActiveValidatorsRequest) XXX_Unmarshal(b []byte) error

type QueryActiveValidatorsResponse

type QueryActiveValidatorsResponse struct {
	// Validators is a list of active validators
	Validators []*ActiveValidator `protobuf:"bytes,1,rep,name=validators,proto3" json:"validators,omitempty"`
}

QueryActiveValidatorsResponse is response type for the Query/ActiveValidators RPC method.

func (*QueryActiveValidatorsResponse) Descriptor

func (*QueryActiveValidatorsResponse) Descriptor() ([]byte, []int)

func (*QueryActiveValidatorsResponse) GetValidators

func (m *QueryActiveValidatorsResponse) GetValidators() []*ActiveValidator

func (*QueryActiveValidatorsResponse) Marshal

func (m *QueryActiveValidatorsResponse) Marshal() (dAtA []byte, err error)

func (*QueryActiveValidatorsResponse) MarshalTo

func (m *QueryActiveValidatorsResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryActiveValidatorsResponse) MarshalToSizedBuffer

func (m *QueryActiveValidatorsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryActiveValidatorsResponse) ProtoMessage

func (*QueryActiveValidatorsResponse) ProtoMessage()

func (*QueryActiveValidatorsResponse) Reset

func (m *QueryActiveValidatorsResponse) Reset()

func (*QueryActiveValidatorsResponse) Size

func (m *QueryActiveValidatorsResponse) Size() (n int)

func (*QueryActiveValidatorsResponse) String

func (*QueryActiveValidatorsResponse) Unmarshal

func (m *QueryActiveValidatorsResponse) Unmarshal(dAtA []byte) error

func (*QueryActiveValidatorsResponse) XXX_DiscardUnknown

func (m *QueryActiveValidatorsResponse) XXX_DiscardUnknown()

func (*QueryActiveValidatorsResponse) XXX_Marshal

func (m *QueryActiveValidatorsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryActiveValidatorsResponse) XXX_Merge

func (m *QueryActiveValidatorsResponse) XXX_Merge(src proto.Message)

func (*QueryActiveValidatorsResponse) XXX_Size

func (m *QueryActiveValidatorsResponse) XXX_Size() int

func (*QueryActiveValidatorsResponse) XXX_Unmarshal

func (m *QueryActiveValidatorsResponse) XXX_Unmarshal(b []byte) error

type QueryClient

type QueryClient interface {
	// Counts queries the number of existing data sources, oracle scripts, and
	// requests.
	Counts(ctx context.Context, in *QueryCountsRequest, opts ...grpc.CallOption) (*QueryCountsResponse, error)
	// Data queries content of the data source or oracle script for given SHA256
	// file hash.
	Data(ctx context.Context, in *QueryDataRequest, opts ...grpc.CallOption) (*QueryDataResponse, error)
	// DataSource queries data source summary info for given data source id.
	DataSource(ctx context.Context, in *QueryDataSourceRequest, opts ...grpc.CallOption) (*QueryDataSourceResponse, error)
	// OracleScript queries oracle script summary info for given oracle script id.
	OracleScript(ctx context.Context, in *QueryOracleScriptRequest, opts ...grpc.CallOption) (*QueryOracleScriptResponse, error)
	// Request queries request info for given request id.
	Request(ctx context.Context, in *QueryRequestRequest, opts ...grpc.CallOption) (*QueryRequestResponse, error)
	// PendingRequests queries list of pending request IDs assigned to given
	// validator.
	PendingRequests(ctx context.Context, in *QueryPendingRequestsRequest, opts ...grpc.CallOption) (*QueryPendingRequestsResponse, error)
	// Validator queries properties of given validator address.
	Validator(ctx context.Context, in *QueryValidatorRequest, opts ...grpc.CallOption) (*QueryValidatorResponse, error)
	// IsReporter queries grant of account on this validator.
	IsReporter(ctx context.Context, in *QueryIsReporterRequest, opts ...grpc.CallOption) (*QueryIsReporterResponse, error)
	// Reporters queries all reporters associated with given validator address.
	Reporters(ctx context.Context, in *QueryReportersRequest, opts ...grpc.CallOption) (*QueryReportersResponse, error)
	// ActiveValidators queries all active oracle validators.
	ActiveValidators(ctx context.Context, in *QueryActiveValidatorsRequest, opts ...grpc.CallOption) (*QueryActiveValidatorsResponse, error)
	// Params queries parameters used for runnning bandchain network.
	Params(ctx context.Context, in *QueryParamsRequest, opts ...grpc.CallOption) (*QueryParamsResponse, error)
	// RequestSearch queries the latest request that match search criteria.
	RequestSearch(ctx context.Context, in *QueryRequestSearchRequest, opts ...grpc.CallOption) (*QueryRequestSearchResponse, error)
	// RequestPrice queries the latest price on standard price reference oracle
	// script.
	RequestPrice(ctx context.Context, in *QueryRequestPriceRequest, opts ...grpc.CallOption) (*QueryRequestPriceResponse, error)
	// RequestVerification verifies a request to make sure that
	// all information that will be used to report the data is valid
	RequestVerification(ctx context.Context, in *QueryRequestVerificationRequest, opts ...grpc.CallOption) (*QueryRequestVerificationResponse, error)
}

QueryClient is the client API for Query service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

func NewQueryClient

func NewQueryClient(cc grpc1.ClientConn) QueryClient

type QueryCountsRequest

type QueryCountsRequest struct {
}

QueryCountsRequest is request type for the Query/Count RPC method.

func (*QueryCountsRequest) Descriptor

func (*QueryCountsRequest) Descriptor() ([]byte, []int)

func (*QueryCountsRequest) Marshal

func (m *QueryCountsRequest) Marshal() (dAtA []byte, err error)

func (*QueryCountsRequest) MarshalTo

func (m *QueryCountsRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryCountsRequest) MarshalToSizedBuffer

func (m *QueryCountsRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryCountsRequest) ProtoMessage

func (*QueryCountsRequest) ProtoMessage()

func (*QueryCountsRequest) Reset

func (m *QueryCountsRequest) Reset()

func (*QueryCountsRequest) Size

func (m *QueryCountsRequest) Size() (n int)

func (*QueryCountsRequest) String

func (m *QueryCountsRequest) String() string

func (*QueryCountsRequest) Unmarshal

func (m *QueryCountsRequest) Unmarshal(dAtA []byte) error

func (*QueryCountsRequest) XXX_DiscardUnknown

func (m *QueryCountsRequest) XXX_DiscardUnknown()

func (*QueryCountsRequest) XXX_Marshal

func (m *QueryCountsRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryCountsRequest) XXX_Merge

func (m *QueryCountsRequest) XXX_Merge(src proto.Message)

func (*QueryCountsRequest) XXX_Size

func (m *QueryCountsRequest) XXX_Size() int

func (*QueryCountsRequest) XXX_Unmarshal

func (m *QueryCountsRequest) XXX_Unmarshal(b []byte) error

type QueryCountsResponse

type QueryCountsResponse struct {
	// DataSourceCount is total number of data sources available on the chain
	DataSourceCount uint64 `protobuf:"varint,1,opt,name=data_source_count,json=dataSourceCount,proto3" json:"data_source_count,omitempty"`
	// OracleScriptCount is total number of oracle scripts available on the chain
	OracleScriptCount uint64 `protobuf:"varint,2,opt,name=oracle_script_count,json=oracleScriptCount,proto3" json:"oracle_script_count,omitempty"`
	// RequestCount is total number of requests submitted to the chain
	RequestCount uint64 `protobuf:"varint,3,opt,name=request_count,json=requestCount,proto3" json:"request_count,omitempty"`
}

QueryCountsResponse is response type for the Query/Count RPC method.

func (*QueryCountsResponse) Descriptor

func (*QueryCountsResponse) Descriptor() ([]byte, []int)

func (*QueryCountsResponse) GetDataSourceCount

func (m *QueryCountsResponse) GetDataSourceCount() uint64

func (*QueryCountsResponse) GetOracleScriptCount

func (m *QueryCountsResponse) GetOracleScriptCount() uint64

func (*QueryCountsResponse) GetRequestCount

func (m *QueryCountsResponse) GetRequestCount() uint64

func (*QueryCountsResponse) Marshal

func (m *QueryCountsResponse) Marshal() (dAtA []byte, err error)

func (*QueryCountsResponse) MarshalTo

func (m *QueryCountsResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryCountsResponse) MarshalToSizedBuffer

func (m *QueryCountsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryCountsResponse) ProtoMessage

func (*QueryCountsResponse) ProtoMessage()

func (*QueryCountsResponse) Reset

func (m *QueryCountsResponse) Reset()

func (*QueryCountsResponse) Size

func (m *QueryCountsResponse) Size() (n int)

func (*QueryCountsResponse) String

func (m *QueryCountsResponse) String() string

func (*QueryCountsResponse) Unmarshal

func (m *QueryCountsResponse) Unmarshal(dAtA []byte) error

func (*QueryCountsResponse) XXX_DiscardUnknown

func (m *QueryCountsResponse) XXX_DiscardUnknown()

func (*QueryCountsResponse) XXX_Marshal

func (m *QueryCountsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryCountsResponse) XXX_Merge

func (m *QueryCountsResponse) XXX_Merge(src proto.Message)

func (*QueryCountsResponse) XXX_Size

func (m *QueryCountsResponse) XXX_Size() int

func (*QueryCountsResponse) XXX_Unmarshal

func (m *QueryCountsResponse) XXX_Unmarshal(b []byte) error

type QueryCountsResult

type QueryCountsResult struct {
	DataSourceCount   uint64 `json:"data_source_count"`
	OracleScriptCount uint64 `json:"oracle_script_count"`
	RequestCount      uint64 `json:"request_count"`
}

QueryCountsResult is the struct for the result of query counts.

type QueryDataRequest

type QueryDataRequest struct {
	// DataHash is SHA256 hash of the file's content, which can be data source or
	// oracle script
	DataHash string `protobuf:"bytes,1,opt,name=data_hash,json=dataHash,proto3" json:"data_hash,omitempty"`
}

QueryDataRequest is request type for the Query/Data RPC method.

func (*QueryDataRequest) Descriptor

func (*QueryDataRequest) Descriptor() ([]byte, []int)

func (*QueryDataRequest) GetDataHash

func (m *QueryDataRequest) GetDataHash() string

func (*QueryDataRequest) Marshal

func (m *QueryDataRequest) Marshal() (dAtA []byte, err error)

func (*QueryDataRequest) MarshalTo

func (m *QueryDataRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryDataRequest) MarshalToSizedBuffer

func (m *QueryDataRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryDataRequest) ProtoMessage

func (*QueryDataRequest) ProtoMessage()

func (*QueryDataRequest) Reset

func (m *QueryDataRequest) Reset()

func (*QueryDataRequest) Size

func (m *QueryDataRequest) Size() (n int)

func (*QueryDataRequest) String

func (m *QueryDataRequest) String() string

func (*QueryDataRequest) Unmarshal

func (m *QueryDataRequest) Unmarshal(dAtA []byte) error

func (*QueryDataRequest) XXX_DiscardUnknown

func (m *QueryDataRequest) XXX_DiscardUnknown()

func (*QueryDataRequest) XXX_Marshal

func (m *QueryDataRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryDataRequest) XXX_Merge

func (m *QueryDataRequest) XXX_Merge(src proto.Message)

func (*QueryDataRequest) XXX_Size

func (m *QueryDataRequest) XXX_Size() int

func (*QueryDataRequest) XXX_Unmarshal

func (m *QueryDataRequest) XXX_Unmarshal(b []byte) error

type QueryDataResponse

type QueryDataResponse struct {
	// Data is file's content, which can be data source or oracle script
	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
}

QueryDataResponse is response type for the Query/Data RPC method.

func (*QueryDataResponse) Descriptor

func (*QueryDataResponse) Descriptor() ([]byte, []int)

func (*QueryDataResponse) GetData

func (m *QueryDataResponse) GetData() []byte

func (*QueryDataResponse) Marshal

func (m *QueryDataResponse) Marshal() (dAtA []byte, err error)

func (*QueryDataResponse) MarshalTo

func (m *QueryDataResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryDataResponse) MarshalToSizedBuffer

func (m *QueryDataResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryDataResponse) ProtoMessage

func (*QueryDataResponse) ProtoMessage()

func (*QueryDataResponse) Reset

func (m *QueryDataResponse) Reset()

func (*QueryDataResponse) Size

func (m *QueryDataResponse) Size() (n int)

func (*QueryDataResponse) String

func (m *QueryDataResponse) String() string

func (*QueryDataResponse) Unmarshal

func (m *QueryDataResponse) Unmarshal(dAtA []byte) error

func (*QueryDataResponse) XXX_DiscardUnknown

func (m *QueryDataResponse) XXX_DiscardUnknown()

func (*QueryDataResponse) XXX_Marshal

func (m *QueryDataResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryDataResponse) XXX_Merge

func (m *QueryDataResponse) XXX_Merge(src proto.Message)

func (*QueryDataResponse) XXX_Size

func (m *QueryDataResponse) XXX_Size() int

func (*QueryDataResponse) XXX_Unmarshal

func (m *QueryDataResponse) XXX_Unmarshal(b []byte) error

type QueryDataSourceRequest

type QueryDataSourceRequest struct {
	// DataSourceID is ID of a data source script
	DataSourceId uint64 `protobuf:"varint,1,opt,name=data_source_id,json=dataSourceId,proto3" json:"data_source_id,omitempty"`
}

QueryDataSourceRequest is request type for the Query/DataSource RPC method.

func (*QueryDataSourceRequest) Descriptor

func (*QueryDataSourceRequest) Descriptor() ([]byte, []int)

func (*QueryDataSourceRequest) GetDataSourceId

func (m *QueryDataSourceRequest) GetDataSourceId() uint64

func (*QueryDataSourceRequest) Marshal

func (m *QueryDataSourceRequest) Marshal() (dAtA []byte, err error)

func (*QueryDataSourceRequest) MarshalTo

func (m *QueryDataSourceRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryDataSourceRequest) MarshalToSizedBuffer

func (m *QueryDataSourceRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryDataSourceRequest) ProtoMessage

func (*QueryDataSourceRequest) ProtoMessage()

func (*QueryDataSourceRequest) Reset

func (m *QueryDataSourceRequest) Reset()

func (*QueryDataSourceRequest) Size

func (m *QueryDataSourceRequest) Size() (n int)

func (*QueryDataSourceRequest) String

func (m *QueryDataSourceRequest) String() string

func (*QueryDataSourceRequest) Unmarshal

func (m *QueryDataSourceRequest) Unmarshal(dAtA []byte) error

func (*QueryDataSourceRequest) XXX_DiscardUnknown

func (m *QueryDataSourceRequest) XXX_DiscardUnknown()

func (*QueryDataSourceRequest) XXX_Marshal

func (m *QueryDataSourceRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryDataSourceRequest) XXX_Merge

func (m *QueryDataSourceRequest) XXX_Merge(src proto.Message)

func (*QueryDataSourceRequest) XXX_Size

func (m *QueryDataSourceRequest) XXX_Size() int

func (*QueryDataSourceRequest) XXX_Unmarshal

func (m *QueryDataSourceRequest) XXX_Unmarshal(b []byte) error

type QueryDataSourceResponse

type QueryDataSourceResponse struct {
	// DataSource is summary information of a data source
	DataSource *DataSource `protobuf:"bytes,1,opt,name=data_source,json=dataSource,proto3" json:"data_source,omitempty"`
}

QueryDataSourceResponse is response type for the Query/DataSource RPC method.

func (*QueryDataSourceResponse) Descriptor

func (*QueryDataSourceResponse) Descriptor() ([]byte, []int)

func (*QueryDataSourceResponse) GetDataSource

func (m *QueryDataSourceResponse) GetDataSource() *DataSource

func (*QueryDataSourceResponse) Marshal

func (m *QueryDataSourceResponse) Marshal() (dAtA []byte, err error)

func (*QueryDataSourceResponse) MarshalTo

func (m *QueryDataSourceResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryDataSourceResponse) MarshalToSizedBuffer

func (m *QueryDataSourceResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryDataSourceResponse) ProtoMessage

func (*QueryDataSourceResponse) ProtoMessage()

func (*QueryDataSourceResponse) Reset

func (m *QueryDataSourceResponse) Reset()

func (*QueryDataSourceResponse) Size

func (m *QueryDataSourceResponse) Size() (n int)

func (*QueryDataSourceResponse) String

func (m *QueryDataSourceResponse) String() string

func (*QueryDataSourceResponse) Unmarshal

func (m *QueryDataSourceResponse) Unmarshal(dAtA []byte) error

func (*QueryDataSourceResponse) XXX_DiscardUnknown

func (m *QueryDataSourceResponse) XXX_DiscardUnknown()

func (*QueryDataSourceResponse) XXX_Marshal

func (m *QueryDataSourceResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryDataSourceResponse) XXX_Merge

func (m *QueryDataSourceResponse) XXX_Merge(src proto.Message)

func (*QueryDataSourceResponse) XXX_Size

func (m *QueryDataSourceResponse) XXX_Size() int

func (*QueryDataSourceResponse) XXX_Unmarshal

func (m *QueryDataSourceResponse) XXX_Unmarshal(b []byte) error

type QueryIsReporterRequest added in v2.2.0

type QueryIsReporterRequest struct {
	// ValidatorAddress is a validator address
	ValidatorAddress string `protobuf:"bytes,1,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
	// ReporterAddress is a candidate account
	ReporterAddress string `protobuf:"bytes,2,opt,name=reporter_address,json=reporterAddress,proto3" json:"reporter_address,omitempty"`
}

QueryIsReporterRequest is request type for the Query/Reporter RPC method.

func (*QueryIsReporterRequest) Descriptor added in v2.2.0

func (*QueryIsReporterRequest) Descriptor() ([]byte, []int)

func (*QueryIsReporterRequest) GetReporterAddress added in v2.2.0

func (m *QueryIsReporterRequest) GetReporterAddress() string

func (*QueryIsReporterRequest) GetValidatorAddress added in v2.2.0

func (m *QueryIsReporterRequest) GetValidatorAddress() string

func (*QueryIsReporterRequest) Marshal added in v2.2.0

func (m *QueryIsReporterRequest) Marshal() (dAtA []byte, err error)

func (*QueryIsReporterRequest) MarshalTo added in v2.2.0

func (m *QueryIsReporterRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryIsReporterRequest) MarshalToSizedBuffer added in v2.2.0

func (m *QueryIsReporterRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryIsReporterRequest) ProtoMessage added in v2.2.0

func (*QueryIsReporterRequest) ProtoMessage()

func (*QueryIsReporterRequest) Reset added in v2.2.0

func (m *QueryIsReporterRequest) Reset()

func (*QueryIsReporterRequest) Size added in v2.2.0

func (m *QueryIsReporterRequest) Size() (n int)

func (*QueryIsReporterRequest) String added in v2.2.0

func (m *QueryIsReporterRequest) String() string

func (*QueryIsReporterRequest) Unmarshal added in v2.2.0

func (m *QueryIsReporterRequest) Unmarshal(dAtA []byte) error

func (*QueryIsReporterRequest) XXX_DiscardUnknown added in v2.2.0

func (m *QueryIsReporterRequest) XXX_DiscardUnknown()

func (*QueryIsReporterRequest) XXX_Marshal added in v2.2.0

func (m *QueryIsReporterRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryIsReporterRequest) XXX_Merge added in v2.2.0

func (m *QueryIsReporterRequest) XXX_Merge(src proto.Message)

func (*QueryIsReporterRequest) XXX_Size added in v2.2.0

func (m *QueryIsReporterRequest) XXX_Size() int

func (*QueryIsReporterRequest) XXX_Unmarshal added in v2.2.0

func (m *QueryIsReporterRequest) XXX_Unmarshal(b []byte) error

type QueryIsReporterResponse added in v2.2.0

type QueryIsReporterResponse struct {
	// IsReporter is true if this account has been granted by validator
	IsReporter bool `protobuf:"varint,1,opt,name=is_reporter,json=isReporter,proto3" json:"is_reporter,omitempty"`
}

QueryIsReporterResponse is response type for the Query/Reporter RPC method.

func (*QueryIsReporterResponse) Descriptor added in v2.2.0

func (*QueryIsReporterResponse) Descriptor() ([]byte, []int)

func (*QueryIsReporterResponse) GetIsReporter added in v2.2.0

func (m *QueryIsReporterResponse) GetIsReporter() bool

func (*QueryIsReporterResponse) Marshal added in v2.2.0

func (m *QueryIsReporterResponse) Marshal() (dAtA []byte, err error)

func (*QueryIsReporterResponse) MarshalTo added in v2.2.0

func (m *QueryIsReporterResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryIsReporterResponse) MarshalToSizedBuffer added in v2.2.0

func (m *QueryIsReporterResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryIsReporterResponse) ProtoMessage added in v2.2.0

func (*QueryIsReporterResponse) ProtoMessage()

func (*QueryIsReporterResponse) Reset added in v2.2.0

func (m *QueryIsReporterResponse) Reset()

func (*QueryIsReporterResponse) Size added in v2.2.0

func (m *QueryIsReporterResponse) Size() (n int)

func (*QueryIsReporterResponse) String added in v2.2.0

func (m *QueryIsReporterResponse) String() string

func (*QueryIsReporterResponse) Unmarshal added in v2.2.0

func (m *QueryIsReporterResponse) Unmarshal(dAtA []byte) error

func (*QueryIsReporterResponse) XXX_DiscardUnknown added in v2.2.0

func (m *QueryIsReporterResponse) XXX_DiscardUnknown()

func (*QueryIsReporterResponse) XXX_Marshal added in v2.2.0

func (m *QueryIsReporterResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryIsReporterResponse) XXX_Merge added in v2.2.0

func (m *QueryIsReporterResponse) XXX_Merge(src proto.Message)

func (*QueryIsReporterResponse) XXX_Size added in v2.2.0

func (m *QueryIsReporterResponse) XXX_Size() int

func (*QueryIsReporterResponse) XXX_Unmarshal added in v2.2.0

func (m *QueryIsReporterResponse) XXX_Unmarshal(b []byte) error

type QueryOracleScriptRequest

type QueryOracleScriptRequest struct {
	// OracleScriptID is ID of an oracle script
	OracleScriptId uint64 `protobuf:"varint,1,opt,name=oracle_script_id,json=oracleScriptId,proto3" json:"oracle_script_id,omitempty"`
}

QueryOracleScriptRequest is request type for the Query/OracleScript RPC method.

func (*QueryOracleScriptRequest) Descriptor

func (*QueryOracleScriptRequest) Descriptor() ([]byte, []int)

func (*QueryOracleScriptRequest) GetOracleScriptId

func (m *QueryOracleScriptRequest) GetOracleScriptId() uint64

func (*QueryOracleScriptRequest) Marshal

func (m *QueryOracleScriptRequest) Marshal() (dAtA []byte, err error)

func (*QueryOracleScriptRequest) MarshalTo

func (m *QueryOracleScriptRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryOracleScriptRequest) MarshalToSizedBuffer

func (m *QueryOracleScriptRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryOracleScriptRequest) ProtoMessage

func (*QueryOracleScriptRequest) ProtoMessage()

func (*QueryOracleScriptRequest) Reset

func (m *QueryOracleScriptRequest) Reset()

func (*QueryOracleScriptRequest) Size

func (m *QueryOracleScriptRequest) Size() (n int)

func (*QueryOracleScriptRequest) String

func (m *QueryOracleScriptRequest) String() string

func (*QueryOracleScriptRequest) Unmarshal

func (m *QueryOracleScriptRequest) Unmarshal(dAtA []byte) error

func (*QueryOracleScriptRequest) XXX_DiscardUnknown

func (m *QueryOracleScriptRequest) XXX_DiscardUnknown()

func (*QueryOracleScriptRequest) XXX_Marshal

func (m *QueryOracleScriptRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryOracleScriptRequest) XXX_Merge

func (m *QueryOracleScriptRequest) XXX_Merge(src proto.Message)

func (*QueryOracleScriptRequest) XXX_Size

func (m *QueryOracleScriptRequest) XXX_Size() int

func (*QueryOracleScriptRequest) XXX_Unmarshal

func (m *QueryOracleScriptRequest) XXX_Unmarshal(b []byte) error

type QueryOracleScriptResponse

type QueryOracleScriptResponse struct {
	// OracleScript is summary information of an oracle script
	OracleScript *OracleScript `protobuf:"bytes,1,opt,name=oracle_script,json=oracleScript,proto3" json:"oracle_script,omitempty"`
}

QueryOracleScriptResponse is response type for the Query/OracleScript RPC method.

func (*QueryOracleScriptResponse) Descriptor

func (*QueryOracleScriptResponse) Descriptor() ([]byte, []int)

func (*QueryOracleScriptResponse) GetOracleScript

func (m *QueryOracleScriptResponse) GetOracleScript() *OracleScript

func (*QueryOracleScriptResponse) Marshal

func (m *QueryOracleScriptResponse) Marshal() (dAtA []byte, err error)

func (*QueryOracleScriptResponse) MarshalTo

func (m *QueryOracleScriptResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryOracleScriptResponse) MarshalToSizedBuffer

func (m *QueryOracleScriptResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryOracleScriptResponse) ProtoMessage

func (*QueryOracleScriptResponse) ProtoMessage()

func (*QueryOracleScriptResponse) Reset

func (m *QueryOracleScriptResponse) Reset()

func (*QueryOracleScriptResponse) Size

func (m *QueryOracleScriptResponse) Size() (n int)

func (*QueryOracleScriptResponse) String

func (m *QueryOracleScriptResponse) String() string

func (*QueryOracleScriptResponse) Unmarshal

func (m *QueryOracleScriptResponse) Unmarshal(dAtA []byte) error

func (*QueryOracleScriptResponse) XXX_DiscardUnknown

func (m *QueryOracleScriptResponse) XXX_DiscardUnknown()

func (*QueryOracleScriptResponse) XXX_Marshal

func (m *QueryOracleScriptResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryOracleScriptResponse) XXX_Merge

func (m *QueryOracleScriptResponse) XXX_Merge(src proto.Message)

func (*QueryOracleScriptResponse) XXX_Size

func (m *QueryOracleScriptResponse) XXX_Size() int

func (*QueryOracleScriptResponse) XXX_Unmarshal

func (m *QueryOracleScriptResponse) XXX_Unmarshal(b []byte) error

type QueryParamsRequest

type QueryParamsRequest struct {
}

QueryParamsRequest is request type for the Query/Params RPC method.

func (*QueryParamsRequest) Descriptor

func (*QueryParamsRequest) Descriptor() ([]byte, []int)

func (*QueryParamsRequest) Marshal

func (m *QueryParamsRequest) Marshal() (dAtA []byte, err error)

func (*QueryParamsRequest) MarshalTo

func (m *QueryParamsRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryParamsRequest) MarshalToSizedBuffer

func (m *QueryParamsRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryParamsRequest) ProtoMessage

func (*QueryParamsRequest) ProtoMessage()

func (*QueryParamsRequest) Reset

func (m *QueryParamsRequest) Reset()

func (*QueryParamsRequest) Size

func (m *QueryParamsRequest) Size() (n int)

func (*QueryParamsRequest) String

func (m *QueryParamsRequest) String() string

func (*QueryParamsRequest) Unmarshal

func (m *QueryParamsRequest) Unmarshal(dAtA []byte) error

func (*QueryParamsRequest) XXX_DiscardUnknown

func (m *QueryParamsRequest) XXX_DiscardUnknown()

func (*QueryParamsRequest) XXX_Marshal

func (m *QueryParamsRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryParamsRequest) XXX_Merge

func (m *QueryParamsRequest) XXX_Merge(src proto.Message)

func (*QueryParamsRequest) XXX_Size

func (m *QueryParamsRequest) XXX_Size() int

func (*QueryParamsRequest) XXX_Unmarshal

func (m *QueryParamsRequest) XXX_Unmarshal(b []byte) error

type QueryParamsResponse

type QueryParamsResponse struct {
	// pagination defines an optional pagination for the request.
	Params Params `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
}

QueryParamsResponse is response type for the Query/Params RPC method.

func (*QueryParamsResponse) Descriptor

func (*QueryParamsResponse) Descriptor() ([]byte, []int)

func (*QueryParamsResponse) GetParams

func (m *QueryParamsResponse) GetParams() Params

func (*QueryParamsResponse) Marshal

func (m *QueryParamsResponse) Marshal() (dAtA []byte, err error)

func (*QueryParamsResponse) MarshalTo

func (m *QueryParamsResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryParamsResponse) MarshalToSizedBuffer

func (m *QueryParamsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryParamsResponse) ProtoMessage

func (*QueryParamsResponse) ProtoMessage()

func (*QueryParamsResponse) Reset

func (m *QueryParamsResponse) Reset()

func (*QueryParamsResponse) Size

func (m *QueryParamsResponse) Size() (n int)

func (*QueryParamsResponse) String

func (m *QueryParamsResponse) String() string

func (*QueryParamsResponse) Unmarshal

func (m *QueryParamsResponse) Unmarshal(dAtA []byte) error

func (*QueryParamsResponse) XXX_DiscardUnknown

func (m *QueryParamsResponse) XXX_DiscardUnknown()

func (*QueryParamsResponse) XXX_Marshal

func (m *QueryParamsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryParamsResponse) XXX_Merge

func (m *QueryParamsResponse) XXX_Merge(src proto.Message)

func (*QueryParamsResponse) XXX_Size

func (m *QueryParamsResponse) XXX_Size() int

func (*QueryParamsResponse) XXX_Unmarshal

func (m *QueryParamsResponse) XXX_Unmarshal(b []byte) error

type QueryPendingRequestsRequest

type QueryPendingRequestsRequest struct {
	// ValidatorAddress is address of a validator
	ValidatorAddress string `protobuf:"bytes,1,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
}

QueryPendingRequestRequest is request type for the Query/PendingRequests RPC method.

func (*QueryPendingRequestsRequest) Descriptor

func (*QueryPendingRequestsRequest) Descriptor() ([]byte, []int)

func (*QueryPendingRequestsRequest) GetValidatorAddress

func (m *QueryPendingRequestsRequest) GetValidatorAddress() string

func (*QueryPendingRequestsRequest) Marshal

func (m *QueryPendingRequestsRequest) Marshal() (dAtA []byte, err error)

func (*QueryPendingRequestsRequest) MarshalTo

func (m *QueryPendingRequestsRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryPendingRequestsRequest) MarshalToSizedBuffer

func (m *QueryPendingRequestsRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryPendingRequestsRequest) ProtoMessage

func (*QueryPendingRequestsRequest) ProtoMessage()

func (*QueryPendingRequestsRequest) Reset

func (m *QueryPendingRequestsRequest) Reset()

func (*QueryPendingRequestsRequest) Size

func (m *QueryPendingRequestsRequest) Size() (n int)

func (*QueryPendingRequestsRequest) String

func (m *QueryPendingRequestsRequest) String() string

func (*QueryPendingRequestsRequest) Unmarshal

func (m *QueryPendingRequestsRequest) Unmarshal(dAtA []byte) error

func (*QueryPendingRequestsRequest) XXX_DiscardUnknown

func (m *QueryPendingRequestsRequest) XXX_DiscardUnknown()

func (*QueryPendingRequestsRequest) XXX_Marshal

func (m *QueryPendingRequestsRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryPendingRequestsRequest) XXX_Merge

func (m *QueryPendingRequestsRequest) XXX_Merge(src proto.Message)

func (*QueryPendingRequestsRequest) XXX_Size

func (m *QueryPendingRequestsRequest) XXX_Size() int

func (*QueryPendingRequestsRequest) XXX_Unmarshal

func (m *QueryPendingRequestsRequest) XXX_Unmarshal(b []byte) error

type QueryPendingRequestsResponse

type QueryPendingRequestsResponse struct {
	// RequestIDs is a list of pending request IDs assigned to the given validator
	RequestIDs []uint64 `protobuf:"varint,1,rep,packed,name=request_ids,json=requestIds,proto3" json:"request_ids,omitempty"`
}

QueryPendingRequestResponse is response type for the Query/PendingRequests RPC method.

func (*QueryPendingRequestsResponse) Descriptor

func (*QueryPendingRequestsResponse) Descriptor() ([]byte, []int)

func (*QueryPendingRequestsResponse) GetRequestIDs

func (m *QueryPendingRequestsResponse) GetRequestIDs() []uint64

func (*QueryPendingRequestsResponse) Marshal

func (m *QueryPendingRequestsResponse) Marshal() (dAtA []byte, err error)

func (*QueryPendingRequestsResponse) MarshalTo

func (m *QueryPendingRequestsResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryPendingRequestsResponse) MarshalToSizedBuffer

func (m *QueryPendingRequestsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryPendingRequestsResponse) ProtoMessage

func (*QueryPendingRequestsResponse) ProtoMessage()

func (*QueryPendingRequestsResponse) Reset

func (m *QueryPendingRequestsResponse) Reset()

func (*QueryPendingRequestsResponse) Size

func (m *QueryPendingRequestsResponse) Size() (n int)

func (*QueryPendingRequestsResponse) String

func (*QueryPendingRequestsResponse) Unmarshal

func (m *QueryPendingRequestsResponse) Unmarshal(dAtA []byte) error

func (*QueryPendingRequestsResponse) XXX_DiscardUnknown

func (m *QueryPendingRequestsResponse) XXX_DiscardUnknown()

func (*QueryPendingRequestsResponse) XXX_Marshal

func (m *QueryPendingRequestsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryPendingRequestsResponse) XXX_Merge

func (m *QueryPendingRequestsResponse) XXX_Merge(src proto.Message)

func (*QueryPendingRequestsResponse) XXX_Size

func (m *QueryPendingRequestsResponse) XXX_Size() int

func (*QueryPendingRequestsResponse) XXX_Unmarshal

func (m *QueryPendingRequestsResponse) XXX_Unmarshal(b []byte) error

type QueryReportersRequest

type QueryReportersRequest struct {
	// ValidatorAddress is a validator address
	ValidatorAddress string `protobuf:"bytes,1,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
}

QueryReportersRequest is request type for the Query/Reporters RPC method.

func (*QueryReportersRequest) Descriptor

func (*QueryReportersRequest) Descriptor() ([]byte, []int)

func (*QueryReportersRequest) GetValidatorAddress

func (m *QueryReportersRequest) GetValidatorAddress() string

func (*QueryReportersRequest) Marshal

func (m *QueryReportersRequest) Marshal() (dAtA []byte, err error)

func (*QueryReportersRequest) MarshalTo

func (m *QueryReportersRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryReportersRequest) MarshalToSizedBuffer

func (m *QueryReportersRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryReportersRequest) ProtoMessage

func (*QueryReportersRequest) ProtoMessage()

func (*QueryReportersRequest) Reset

func (m *QueryReportersRequest) Reset()

func (*QueryReportersRequest) Size

func (m *QueryReportersRequest) Size() (n int)

func (*QueryReportersRequest) String

func (m *QueryReportersRequest) String() string

func (*QueryReportersRequest) Unmarshal

func (m *QueryReportersRequest) Unmarshal(dAtA []byte) error

func (*QueryReportersRequest) XXX_DiscardUnknown

func (m *QueryReportersRequest) XXX_DiscardUnknown()

func (*QueryReportersRequest) XXX_Marshal

func (m *QueryReportersRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryReportersRequest) XXX_Merge

func (m *QueryReportersRequest) XXX_Merge(src proto.Message)

func (*QueryReportersRequest) XXX_Size

func (m *QueryReportersRequest) XXX_Size() int

func (*QueryReportersRequest) XXX_Unmarshal

func (m *QueryReportersRequest) XXX_Unmarshal(b []byte) error

type QueryReportersResponse

type QueryReportersResponse struct {
	// Reporter is a list of account addresses of reporters
	Reporter []string `protobuf:"bytes,1,rep,name=reporter,proto3" json:"reporter,omitempty"`
}

QueryReportersResponse is response type for the Query/Reporters RPC method.

func (*QueryReportersResponse) Descriptor

func (*QueryReportersResponse) Descriptor() ([]byte, []int)

func (*QueryReportersResponse) GetReporter

func (m *QueryReportersResponse) GetReporter() []string

func (*QueryReportersResponse) Marshal

func (m *QueryReportersResponse) Marshal() (dAtA []byte, err error)

func (*QueryReportersResponse) MarshalTo

func (m *QueryReportersResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryReportersResponse) MarshalToSizedBuffer

func (m *QueryReportersResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryReportersResponse) ProtoMessage

func (*QueryReportersResponse) ProtoMessage()

func (*QueryReportersResponse) Reset

func (m *QueryReportersResponse) Reset()

func (*QueryReportersResponse) Size

func (m *QueryReportersResponse) Size() (n int)

func (*QueryReportersResponse) String

func (m *QueryReportersResponse) String() string

func (*QueryReportersResponse) Unmarshal

func (m *QueryReportersResponse) Unmarshal(dAtA []byte) error

func (*QueryReportersResponse) XXX_DiscardUnknown

func (m *QueryReportersResponse) XXX_DiscardUnknown()

func (*QueryReportersResponse) XXX_Marshal

func (m *QueryReportersResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryReportersResponse) XXX_Merge

func (m *QueryReportersResponse) XXX_Merge(src proto.Message)

func (*QueryReportersResponse) XXX_Size

func (m *QueryReportersResponse) XXX_Size() int

func (*QueryReportersResponse) XXX_Unmarshal

func (m *QueryReportersResponse) XXX_Unmarshal(b []byte) error

type QueryRequestPriceRequest

type QueryRequestPriceRequest struct {
	// Symbol is unit of data indicating what the data is
	Symbols []string `protobuf:"bytes,1,rep,name=symbols,proto3" json:"symbols,omitempty"`
	// AskCount is number of validators allowed for fulfilling the request
	AskCount uint64 `protobuf:"varint,2,opt,name=ask_count,json=askCount,proto3" json:"ask_count,omitempty"`
	// MinCount is number of validators required for fulfilling the request
	MinCount uint64 `protobuf:"varint,3,opt,name=min_count,json=minCount,proto3" json:"min_count,omitempty"`
}

QueryRequestPriceRequest is request type for the Query/RequestPrice RPC method.

func (*QueryRequestPriceRequest) Descriptor

func (*QueryRequestPriceRequest) Descriptor() ([]byte, []int)

func (*QueryRequestPriceRequest) GetAskCount

func (m *QueryRequestPriceRequest) GetAskCount() uint64

func (*QueryRequestPriceRequest) GetMinCount

func (m *QueryRequestPriceRequest) GetMinCount() uint64

func (*QueryRequestPriceRequest) GetSymbols

func (m *QueryRequestPriceRequest) GetSymbols() []string

func (*QueryRequestPriceRequest) Marshal

func (m *QueryRequestPriceRequest) Marshal() (dAtA []byte, err error)

func (*QueryRequestPriceRequest) MarshalTo

func (m *QueryRequestPriceRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryRequestPriceRequest) MarshalToSizedBuffer

func (m *QueryRequestPriceRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryRequestPriceRequest) ProtoMessage

func (*QueryRequestPriceRequest) ProtoMessage()

func (*QueryRequestPriceRequest) Reset

func (m *QueryRequestPriceRequest) Reset()

func (*QueryRequestPriceRequest) Size

func (m *QueryRequestPriceRequest) Size() (n int)

func (*QueryRequestPriceRequest) String

func (m *QueryRequestPriceRequest) String() string

func (*QueryRequestPriceRequest) Unmarshal

func (m *QueryRequestPriceRequest) Unmarshal(dAtA []byte) error

func (*QueryRequestPriceRequest) XXX_DiscardUnknown

func (m *QueryRequestPriceRequest) XXX_DiscardUnknown()

func (*QueryRequestPriceRequest) XXX_Marshal

func (m *QueryRequestPriceRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryRequestPriceRequest) XXX_Merge

func (m *QueryRequestPriceRequest) XXX_Merge(src proto.Message)

func (*QueryRequestPriceRequest) XXX_Size

func (m *QueryRequestPriceRequest) XXX_Size() int

func (*QueryRequestPriceRequest) XXX_Unmarshal

func (m *QueryRequestPriceRequest) XXX_Unmarshal(b []byte) error

type QueryRequestPriceResponse

type QueryRequestPriceResponse struct {
	// PriceResult is a list of price results for given symbols
	PriceResults []*PriceResult `protobuf:"bytes,1,rep,name=price_results,json=priceResults,proto3" json:"price_results,omitempty"`
}

QueryRequestPriceResponse is response type for the Query/RequestPrice RPC method.

func (*QueryRequestPriceResponse) Descriptor

func (*QueryRequestPriceResponse) Descriptor() ([]byte, []int)

func (*QueryRequestPriceResponse) GetPriceResults

func (m *QueryRequestPriceResponse) GetPriceResults() []*PriceResult

func (*QueryRequestPriceResponse) Marshal

func (m *QueryRequestPriceResponse) Marshal() (dAtA []byte, err error)

func (*QueryRequestPriceResponse) MarshalTo

func (m *QueryRequestPriceResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryRequestPriceResponse) MarshalToSizedBuffer

func (m *QueryRequestPriceResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryRequestPriceResponse) ProtoMessage

func (*QueryRequestPriceResponse) ProtoMessage()

func (*QueryRequestPriceResponse) Reset

func (m *QueryRequestPriceResponse) Reset()

func (*QueryRequestPriceResponse) Size

func (m *QueryRequestPriceResponse) Size() (n int)

func (*QueryRequestPriceResponse) String

func (m *QueryRequestPriceResponse) String() string

func (*QueryRequestPriceResponse) Unmarshal

func (m *QueryRequestPriceResponse) Unmarshal(dAtA []byte) error

func (*QueryRequestPriceResponse) XXX_DiscardUnknown

func (m *QueryRequestPriceResponse) XXX_DiscardUnknown()

func (*QueryRequestPriceResponse) XXX_Marshal

func (m *QueryRequestPriceResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryRequestPriceResponse) XXX_Merge

func (m *QueryRequestPriceResponse) XXX_Merge(src proto.Message)

func (*QueryRequestPriceResponse) XXX_Size

func (m *QueryRequestPriceResponse) XXX_Size() int

func (*QueryRequestPriceResponse) XXX_Unmarshal

func (m *QueryRequestPriceResponse) XXX_Unmarshal(b []byte) error

type QueryRequestRequest

type QueryRequestRequest struct {
	// RequestID is ID of an oracle request
	RequestId uint64 `protobuf:"varint,1,opt,name=request_id,json=requestId,proto3" json:"request_id,omitempty"`
}

QueryRequestRequest is request type for the Query/Request RPC method.

func (*QueryRequestRequest) Descriptor

func (*QueryRequestRequest) Descriptor() ([]byte, []int)

func (*QueryRequestRequest) GetRequestId

func (m *QueryRequestRequest) GetRequestId() uint64

func (*QueryRequestRequest) Marshal

func (m *QueryRequestRequest) Marshal() (dAtA []byte, err error)

func (*QueryRequestRequest) MarshalTo

func (m *QueryRequestRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryRequestRequest) MarshalToSizedBuffer

func (m *QueryRequestRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryRequestRequest) ProtoMessage

func (*QueryRequestRequest) ProtoMessage()

func (*QueryRequestRequest) Reset

func (m *QueryRequestRequest) Reset()

func (*QueryRequestRequest) Size

func (m *QueryRequestRequest) Size() (n int)

func (*QueryRequestRequest) String

func (m *QueryRequestRequest) String() string

func (*QueryRequestRequest) Unmarshal

func (m *QueryRequestRequest) Unmarshal(dAtA []byte) error

func (*QueryRequestRequest) XXX_DiscardUnknown

func (m *QueryRequestRequest) XXX_DiscardUnknown()

func (*QueryRequestRequest) XXX_Marshal

func (m *QueryRequestRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryRequestRequest) XXX_Merge

func (m *QueryRequestRequest) XXX_Merge(src proto.Message)

func (*QueryRequestRequest) XXX_Size

func (m *QueryRequestRequest) XXX_Size() int

func (*QueryRequestRequest) XXX_Unmarshal

func (m *QueryRequestRequest) XXX_Unmarshal(b []byte) error

type QueryRequestResponse

type QueryRequestResponse struct {
	// Request is an oracle request
	Request *Request `protobuf:"bytes,1,opt,name=request,proto3" json:"request,omitempty"`
	// Reports is list of result data as raw reports that are fulfilled by
	// assigned validators
	Reports []Report `protobuf:"bytes,2,rep,name=reports,proto3" json:"reports"`
	// Result is a final form of result data
	Result *Result `protobuf:"bytes,3,opt,name=result,proto3" json:"result,omitempty"`
}

QueryRequestResponse is response type for the Query/Request RPC method.

func (*QueryRequestResponse) Descriptor

func (*QueryRequestResponse) Descriptor() ([]byte, []int)

func (*QueryRequestResponse) GetReports

func (m *QueryRequestResponse) GetReports() []Report

func (*QueryRequestResponse) GetRequest

func (m *QueryRequestResponse) GetRequest() *Request

func (*QueryRequestResponse) GetResult

func (m *QueryRequestResponse) GetResult() *Result

func (*QueryRequestResponse) Marshal

func (m *QueryRequestResponse) Marshal() (dAtA []byte, err error)

func (*QueryRequestResponse) MarshalTo

func (m *QueryRequestResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryRequestResponse) MarshalToSizedBuffer

func (m *QueryRequestResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryRequestResponse) ProtoMessage

func (*QueryRequestResponse) ProtoMessage()

func (*QueryRequestResponse) Reset

func (m *QueryRequestResponse) Reset()

func (*QueryRequestResponse) Size

func (m *QueryRequestResponse) Size() (n int)

func (*QueryRequestResponse) String

func (m *QueryRequestResponse) String() string

func (*QueryRequestResponse) Unmarshal

func (m *QueryRequestResponse) Unmarshal(dAtA []byte) error

func (*QueryRequestResponse) XXX_DiscardUnknown

func (m *QueryRequestResponse) XXX_DiscardUnknown()

func (*QueryRequestResponse) XXX_Marshal

func (m *QueryRequestResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryRequestResponse) XXX_Merge

func (m *QueryRequestResponse) XXX_Merge(src proto.Message)

func (*QueryRequestResponse) XXX_Size

func (m *QueryRequestResponse) XXX_Size() int

func (*QueryRequestResponse) XXX_Unmarshal

func (m *QueryRequestResponse) XXX_Unmarshal(b []byte) error

type QueryRequestResult

type QueryRequestResult struct {
	Request Request  `json:"request"`
	Reports []Report `json:"reports"`
	Result  *Result  `json:"result"`
}

QueryRequestResult is the struct for the result of request query.

type QueryRequestSearchRequest

type QueryRequestSearchRequest struct {
	// OracleScriptID is ID of an oracle script
	OracleScriptId uint64 `protobuf:"varint,1,opt,name=oracle_script_id,json=oracleScriptId,proto3" json:"oracle_script_id,omitempty"`
	// Calldata is OBI-encoded data in hex format as argument params for the
	// oracle script
	Calldata string `protobuf:"bytes,2,opt,name=calldata,proto3" json:"calldata,omitempty"`
	// AskCount is number of validators allowed for fulfilling the request
	AskCount uint64 `protobuf:"varint,3,opt,name=ask_count,json=askCount,proto3" json:"ask_count,omitempty"`
	// MinCount is number of validators required for fulfilling the request
	MinCount uint64 `protobuf:"varint,4,opt,name=min_count,json=minCount,proto3" json:"min_count,omitempty"`
}

QueryRequestSearchRequest is request type for the Query/RequestSearch RPC method.

func (*QueryRequestSearchRequest) Descriptor

func (*QueryRequestSearchRequest) Descriptor() ([]byte, []int)

func (*QueryRequestSearchRequest) GetAskCount

func (m *QueryRequestSearchRequest) GetAskCount() uint64

func (*QueryRequestSearchRequest) GetCalldata

func (m *QueryRequestSearchRequest) GetCalldata() string

func (*QueryRequestSearchRequest) GetMinCount

func (m *QueryRequestSearchRequest) GetMinCount() uint64

func (*QueryRequestSearchRequest) GetOracleScriptId

func (m *QueryRequestSearchRequest) GetOracleScriptId() uint64

func (*QueryRequestSearchRequest) Marshal

func (m *QueryRequestSearchRequest) Marshal() (dAtA []byte, err error)

func (*QueryRequestSearchRequest) MarshalTo

func (m *QueryRequestSearchRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryRequestSearchRequest) MarshalToSizedBuffer

func (m *QueryRequestSearchRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryRequestSearchRequest) ProtoMessage

func (*QueryRequestSearchRequest) ProtoMessage()

func (*QueryRequestSearchRequest) Reset

func (m *QueryRequestSearchRequest) Reset()

func (*QueryRequestSearchRequest) Size

func (m *QueryRequestSearchRequest) Size() (n int)

func (*QueryRequestSearchRequest) String

func (m *QueryRequestSearchRequest) String() string

func (*QueryRequestSearchRequest) Unmarshal

func (m *QueryRequestSearchRequest) Unmarshal(dAtA []byte) error

func (*QueryRequestSearchRequest) XXX_DiscardUnknown

func (m *QueryRequestSearchRequest) XXX_DiscardUnknown()

func (*QueryRequestSearchRequest) XXX_Marshal

func (m *QueryRequestSearchRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryRequestSearchRequest) XXX_Merge

func (m *QueryRequestSearchRequest) XXX_Merge(src proto.Message)

func (*QueryRequestSearchRequest) XXX_Size

func (m *QueryRequestSearchRequest) XXX_Size() int

func (*QueryRequestSearchRequest) XXX_Unmarshal

func (m *QueryRequestSearchRequest) XXX_Unmarshal(b []byte) error

type QueryRequestSearchResponse

type QueryRequestSearchResponse struct {
	// Request is details of an oracle request
	Request *QueryRequestResponse `protobuf:"bytes,1,opt,name=request,proto3" json:"request,omitempty"`
}

QueryRequestSearchResponse is response type for the Query/RequestSearch RPC method.

func (*QueryRequestSearchResponse) Descriptor

func (*QueryRequestSearchResponse) Descriptor() ([]byte, []int)

func (*QueryRequestSearchResponse) GetRequest

func (*QueryRequestSearchResponse) Marshal

func (m *QueryRequestSearchResponse) Marshal() (dAtA []byte, err error)

func (*QueryRequestSearchResponse) MarshalTo

func (m *QueryRequestSearchResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryRequestSearchResponse) MarshalToSizedBuffer

func (m *QueryRequestSearchResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryRequestSearchResponse) ProtoMessage

func (*QueryRequestSearchResponse) ProtoMessage()

func (*QueryRequestSearchResponse) Reset

func (m *QueryRequestSearchResponse) Reset()

func (*QueryRequestSearchResponse) Size

func (m *QueryRequestSearchResponse) Size() (n int)

func (*QueryRequestSearchResponse) String

func (m *QueryRequestSearchResponse) String() string

func (*QueryRequestSearchResponse) Unmarshal

func (m *QueryRequestSearchResponse) Unmarshal(dAtA []byte) error

func (*QueryRequestSearchResponse) XXX_DiscardUnknown

func (m *QueryRequestSearchResponse) XXX_DiscardUnknown()

func (*QueryRequestSearchResponse) XXX_Marshal

func (m *QueryRequestSearchResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryRequestSearchResponse) XXX_Merge

func (m *QueryRequestSearchResponse) XXX_Merge(src proto.Message)

func (*QueryRequestSearchResponse) XXX_Size

func (m *QueryRequestSearchResponse) XXX_Size() int

func (*QueryRequestSearchResponse) XXX_Unmarshal

func (m *QueryRequestSearchResponse) XXX_Unmarshal(b []byte) error

type QueryRequestVerificationRequest

type QueryRequestVerificationRequest struct {
	// ChainID is the chain ID to identify which chain ID is used for the
	// verification
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// Validator is a validator address
	Validator string `protobuf:"bytes,2,opt,name=validator,proto3" json:"validator,omitempty"`
	// RequestID is oracle request ID
	RequestId uint64 `protobuf:"varint,3,opt,name=request_id,json=requestId,proto3" json:"request_id,omitempty"`
	// ExternalID is an oracle's external ID
	ExternalId uint64 `protobuf:"varint,4,opt,name=external_id,json=externalId,proto3" json:"external_id,omitempty"`
	// DataSourceID is the ID of data source
	DataSourceId uint64 `protobuf:"varint,5,opt,name=data_source_id,json=dataSourceId,proto3" json:"data_source_id,omitempty"`
	// Reporter is an bech32-encoded public key of the reporter authorized by the
	// validator
	Reporter string `protobuf:"bytes,6,opt,name=reporter,proto3" json:"reporter,omitempty"`
	// Signature is a signature signed by the reporter using reporter's private
	// key
	Signature []byte `protobuf:"bytes,7,opt,name=signature,proto3" json:"signature,omitempty"`
	// MaxDelay is a max number of RequestID delay acceptable in case of node
	// delay
	MaxDelay uint64 `protobuf:"varint,8,opt,name=max_delay,json=maxDelay,proto3" json:"max_delay,omitempty"`
}

QueryRequestVerificationRequest is request type for the Query/RequestVerification RPC

func (*QueryRequestVerificationRequest) Descriptor

func (*QueryRequestVerificationRequest) Descriptor() ([]byte, []int)

func (*QueryRequestVerificationRequest) GetChainId

func (m *QueryRequestVerificationRequest) GetChainId() string

func (*QueryRequestVerificationRequest) GetDataSourceId added in v2.3.4

func (m *QueryRequestVerificationRequest) GetDataSourceId() uint64

func (*QueryRequestVerificationRequest) GetExternalId

func (m *QueryRequestVerificationRequest) GetExternalId() uint64

func (*QueryRequestVerificationRequest) GetMaxDelay added in v2.3.4

func (m *QueryRequestVerificationRequest) GetMaxDelay() uint64

func (*QueryRequestVerificationRequest) GetReporter

func (m *QueryRequestVerificationRequest) GetReporter() string

func (*QueryRequestVerificationRequest) GetRequestId

func (m *QueryRequestVerificationRequest) GetRequestId() uint64

func (*QueryRequestVerificationRequest) GetSignature

func (m *QueryRequestVerificationRequest) GetSignature() []byte

func (*QueryRequestVerificationRequest) GetValidator

func (m *QueryRequestVerificationRequest) GetValidator() string

func (*QueryRequestVerificationRequest) Marshal

func (m *QueryRequestVerificationRequest) Marshal() (dAtA []byte, err error)

func (*QueryRequestVerificationRequest) MarshalTo

func (m *QueryRequestVerificationRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryRequestVerificationRequest) MarshalToSizedBuffer

func (m *QueryRequestVerificationRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryRequestVerificationRequest) ProtoMessage

func (*QueryRequestVerificationRequest) ProtoMessage()

func (*QueryRequestVerificationRequest) Reset

func (*QueryRequestVerificationRequest) Size

func (m *QueryRequestVerificationRequest) Size() (n int)

func (*QueryRequestVerificationRequest) String

func (*QueryRequestVerificationRequest) Unmarshal

func (m *QueryRequestVerificationRequest) Unmarshal(dAtA []byte) error

func (*QueryRequestVerificationRequest) XXX_DiscardUnknown

func (m *QueryRequestVerificationRequest) XXX_DiscardUnknown()

func (*QueryRequestVerificationRequest) XXX_Marshal

func (m *QueryRequestVerificationRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryRequestVerificationRequest) XXX_Merge

func (m *QueryRequestVerificationRequest) XXX_Merge(src proto.Message)

func (*QueryRequestVerificationRequest) XXX_Size

func (m *QueryRequestVerificationRequest) XXX_Size() int

func (*QueryRequestVerificationRequest) XXX_Unmarshal

func (m *QueryRequestVerificationRequest) XXX_Unmarshal(b []byte) error

type QueryRequestVerificationResponse

type QueryRequestVerificationResponse struct {
	// ChainID is the targeted chain ID
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// Validator is the targeted validator address
	Validator string `protobuf:"bytes,2,opt,name=validator,proto3" json:"validator,omitempty"`
	// RequestID is the ID of targeted request
	RequestId uint64 `protobuf:"varint,3,opt,name=request_id,json=requestId,proto3" json:"request_id,omitempty"`
	// ExternalID is the ID of targeted oracle's external data source
	ExternalId uint64 `protobuf:"varint,4,opt,name=external_id,json=externalId,proto3" json:"external_id,omitempty"`
	// DataSourceID is the ID of a data source that relates to the targeted
	// external ID
	DataSourceId uint64 `protobuf:"varint,5,opt,name=data_source_id,json=dataSourceId,proto3" json:"data_source_id,omitempty"`
	// IsDelay is a flag to tell that this request is not exist yet but in
	// MaxDelay range
	IsDelay bool `protobuf:"varint,6,opt,name=is_delay,json=isDelay,proto3" json:"is_delay,omitempty"`
}

QueryRequestVerificationResponse is response type for the Query/RequestVerification RPC

func (*QueryRequestVerificationResponse) Descriptor

func (*QueryRequestVerificationResponse) Descriptor() ([]byte, []int)

func (*QueryRequestVerificationResponse) GetChainId

func (m *QueryRequestVerificationResponse) GetChainId() string

func (*QueryRequestVerificationResponse) GetDataSourceId

func (m *QueryRequestVerificationResponse) GetDataSourceId() uint64

func (*QueryRequestVerificationResponse) GetExternalId

func (m *QueryRequestVerificationResponse) GetExternalId() uint64

func (*QueryRequestVerificationResponse) GetIsDelay added in v2.3.4

func (m *QueryRequestVerificationResponse) GetIsDelay() bool

func (*QueryRequestVerificationResponse) GetRequestId

func (m *QueryRequestVerificationResponse) GetRequestId() uint64

func (*QueryRequestVerificationResponse) GetValidator

func (m *QueryRequestVerificationResponse) GetValidator() string

func (*QueryRequestVerificationResponse) Marshal

func (m *QueryRequestVerificationResponse) Marshal() (dAtA []byte, err error)

func (*QueryRequestVerificationResponse) MarshalTo

func (m *QueryRequestVerificationResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryRequestVerificationResponse) MarshalToSizedBuffer

func (m *QueryRequestVerificationResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryRequestVerificationResponse) ProtoMessage

func (*QueryRequestVerificationResponse) ProtoMessage()

func (*QueryRequestVerificationResponse) Reset

func (*QueryRequestVerificationResponse) Size

func (m *QueryRequestVerificationResponse) Size() (n int)

func (*QueryRequestVerificationResponse) String

func (*QueryRequestVerificationResponse) Unmarshal

func (m *QueryRequestVerificationResponse) Unmarshal(dAtA []byte) error

func (*QueryRequestVerificationResponse) XXX_DiscardUnknown

func (m *QueryRequestVerificationResponse) XXX_DiscardUnknown()

func (*QueryRequestVerificationResponse) XXX_Marshal

func (m *QueryRequestVerificationResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryRequestVerificationResponse) XXX_Merge

func (*QueryRequestVerificationResponse) XXX_Size

func (m *QueryRequestVerificationResponse) XXX_Size() int

func (*QueryRequestVerificationResponse) XXX_Unmarshal

func (m *QueryRequestVerificationResponse) XXX_Unmarshal(b []byte) error

type QueryResult

type QueryResult struct {
	Status int             `json:"status"`
	Result json.RawMessage `json:"result"`
}

QueryResult wraps querier result with HTTP status to return to application.

type QueryServer

type QueryServer interface {
	// Counts queries the number of existing data sources, oracle scripts, and
	// requests.
	Counts(context.Context, *QueryCountsRequest) (*QueryCountsResponse, error)
	// Data queries content of the data source or oracle script for given SHA256
	// file hash.
	Data(context.Context, *QueryDataRequest) (*QueryDataResponse, error)
	// DataSource queries data source summary info for given data source id.
	DataSource(context.Context, *QueryDataSourceRequest) (*QueryDataSourceResponse, error)
	// OracleScript queries oracle script summary info for given oracle script id.
	OracleScript(context.Context, *QueryOracleScriptRequest) (*QueryOracleScriptResponse, error)
	// Request queries request info for given request id.
	Request(context.Context, *QueryRequestRequest) (*QueryRequestResponse, error)
	// PendingRequests queries list of pending request IDs assigned to given
	// validator.
	PendingRequests(context.Context, *QueryPendingRequestsRequest) (*QueryPendingRequestsResponse, error)
	// Validator queries properties of given validator address.
	Validator(context.Context, *QueryValidatorRequest) (*QueryValidatorResponse, error)
	// IsReporter queries grant of account on this validator.
	IsReporter(context.Context, *QueryIsReporterRequest) (*QueryIsReporterResponse, error)
	// Reporters queries all reporters associated with given validator address.
	Reporters(context.Context, *QueryReportersRequest) (*QueryReportersResponse, error)
	// ActiveValidators queries all active oracle validators.
	ActiveValidators(context.Context, *QueryActiveValidatorsRequest) (*QueryActiveValidatorsResponse, error)
	// Params queries parameters used for runnning bandchain network.
	Params(context.Context, *QueryParamsRequest) (*QueryParamsResponse, error)
	// RequestSearch queries the latest request that match search criteria.
	RequestSearch(context.Context, *QueryRequestSearchRequest) (*QueryRequestSearchResponse, error)
	// RequestPrice queries the latest price on standard price reference oracle
	// script.
	RequestPrice(context.Context, *QueryRequestPriceRequest) (*QueryRequestPriceResponse, error)
	// RequestVerification verifies a request to make sure that
	// all information that will be used to report the data is valid
	RequestVerification(context.Context, *QueryRequestVerificationRequest) (*QueryRequestVerificationResponse, error)
}

QueryServer is the server API for Query service.

type QueryValidatorRequest

type QueryValidatorRequest struct {
	// ValidatorAddress is address of a validator
	ValidatorAddress string `protobuf:"bytes,1,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
}

QueryValidatorRequest is request type for the Query/Validator RPC method.

func (*QueryValidatorRequest) Descriptor

func (*QueryValidatorRequest) Descriptor() ([]byte, []int)

func (*QueryValidatorRequest) GetValidatorAddress

func (m *QueryValidatorRequest) GetValidatorAddress() string

func (*QueryValidatorRequest) Marshal

func (m *QueryValidatorRequest) Marshal() (dAtA []byte, err error)

func (*QueryValidatorRequest) MarshalTo

func (m *QueryValidatorRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryValidatorRequest) MarshalToSizedBuffer

func (m *QueryValidatorRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryValidatorRequest) ProtoMessage

func (*QueryValidatorRequest) ProtoMessage()

func (*QueryValidatorRequest) Reset

func (m *QueryValidatorRequest) Reset()

func (*QueryValidatorRequest) Size

func (m *QueryValidatorRequest) Size() (n int)

func (*QueryValidatorRequest) String

func (m *QueryValidatorRequest) String() string

func (*QueryValidatorRequest) Unmarshal

func (m *QueryValidatorRequest) Unmarshal(dAtA []byte) error

func (*QueryValidatorRequest) XXX_DiscardUnknown

func (m *QueryValidatorRequest) XXX_DiscardUnknown()

func (*QueryValidatorRequest) XXX_Marshal

func (m *QueryValidatorRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryValidatorRequest) XXX_Merge

func (m *QueryValidatorRequest) XXX_Merge(src proto.Message)

func (*QueryValidatorRequest) XXX_Size

func (m *QueryValidatorRequest) XXX_Size() int

func (*QueryValidatorRequest) XXX_Unmarshal

func (m *QueryValidatorRequest) XXX_Unmarshal(b []byte) error

type QueryValidatorResponse

type QueryValidatorResponse struct {
	// Status is status of a validator e.g. active/inactive
	Status *ValidatorStatus `protobuf:"bytes,1,opt,name=status,proto3" json:"status,omitempty"`
}

QueryValidatorResponse is response type for the Query/Validator RPC method.

func (*QueryValidatorResponse) Descriptor

func (*QueryValidatorResponse) Descriptor() ([]byte, []int)

func (*QueryValidatorResponse) GetStatus

func (m *QueryValidatorResponse) GetStatus() *ValidatorStatus

func (*QueryValidatorResponse) Marshal

func (m *QueryValidatorResponse) Marshal() (dAtA []byte, err error)

func (*QueryValidatorResponse) MarshalTo

func (m *QueryValidatorResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryValidatorResponse) MarshalToSizedBuffer

func (m *QueryValidatorResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryValidatorResponse) ProtoMessage

func (*QueryValidatorResponse) ProtoMessage()

func (*QueryValidatorResponse) Reset

func (m *QueryValidatorResponse) Reset()

func (*QueryValidatorResponse) Size

func (m *QueryValidatorResponse) Size() (n int)

func (*QueryValidatorResponse) String

func (m *QueryValidatorResponse) String() string

func (*QueryValidatorResponse) Unmarshal

func (m *QueryValidatorResponse) Unmarshal(dAtA []byte) error

func (*QueryValidatorResponse) XXX_DiscardUnknown

func (m *QueryValidatorResponse) XXX_DiscardUnknown()

func (*QueryValidatorResponse) XXX_Marshal

func (m *QueryValidatorResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryValidatorResponse) XXX_Merge

func (m *QueryValidatorResponse) XXX_Merge(src proto.Message)

func (*QueryValidatorResponse) XXX_Size

func (m *QueryValidatorResponse) XXX_Size() int

func (*QueryValidatorResponse) XXX_Unmarshal

func (m *QueryValidatorResponse) XXX_Unmarshal(b []byte) error

type RawReport

type RawReport struct {
	// ExternalID is an ID of the raw request
	ExternalID ExternalID `protobuf:"varint,1,opt,name=external_id,json=externalId,proto3,casttype=ExternalID" json:"external_id,omitempty"`
	// ExitCode is status code provided by validators to specify error, if any.
	// Exit code is usually filled by the exit code returned from execution of
	// specified data source script. With code 0 means there is no error.
	ExitCode uint32 `protobuf:"varint,2,opt,name=exit_code,json=exitCode,proto3" json:"exit_code,omitempty"`
	// Data is raw result provided by validators.
	// It is usually filled by the result from execution of specified data source
	// script.
	Data []byte `protobuf:"bytes,3,opt,name=data,proto3" json:"data,omitempty"`
}

RawRequest is the data structure for storing raw reporter in the storage.

func NewRawReport

func NewRawReport(
	ExternalID ExternalID,
	ExitCode uint32,
	Data []byte,
) RawReport

func (*RawReport) Descriptor

func (*RawReport) Descriptor() ([]byte, []int)

func (*RawReport) Equal

func (this *RawReport) Equal(that interface{}) bool

func (*RawReport) GetData

func (m *RawReport) GetData() []byte

func (*RawReport) GetExitCode

func (m *RawReport) GetExitCode() uint32

func (*RawReport) GetExternalID

func (m *RawReport) GetExternalID() ExternalID

func (*RawReport) Marshal

func (m *RawReport) Marshal() (dAtA []byte, err error)

func (*RawReport) MarshalTo

func (m *RawReport) MarshalTo(dAtA []byte) (int, error)

func (*RawReport) MarshalToSizedBuffer

func (m *RawReport) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*RawReport) ProtoMessage

func (*RawReport) ProtoMessage()

func (*RawReport) Reset

func (m *RawReport) Reset()

func (*RawReport) Size

func (m *RawReport) Size() (n int)

func (*RawReport) String

func (m *RawReport) String() string

func (*RawReport) Unmarshal

func (m *RawReport) Unmarshal(dAtA []byte) error

func (*RawReport) XXX_DiscardUnknown

func (m *RawReport) XXX_DiscardUnknown()

func (*RawReport) XXX_Marshal

func (m *RawReport) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*RawReport) XXX_Merge

func (m *RawReport) XXX_Merge(src proto.Message)

func (*RawReport) XXX_Size

func (m *RawReport) XXX_Size() int

func (*RawReport) XXX_Unmarshal

func (m *RawReport) XXX_Unmarshal(b []byte) error

type RawRequest

type RawRequest struct {
	// ExternalID is an ID of the raw request
	ExternalID ExternalID `protobuf:"varint,1,opt,name=external_id,json=externalId,proto3,casttype=ExternalID" json:"external_id,omitempty"`
	// DataSourceID is an ID of data source script that relates to the raw request
	DataSourceID DataSourceID `protobuf:"varint,2,opt,name=data_source_id,json=dataSourceId,proto3,casttype=DataSourceID" json:"data_source_id,omitempty"`
	// Calldata is the data used as argument params for executing data source
	// script
	Calldata []byte `protobuf:"bytes,3,opt,name=calldata,proto3" json:"calldata,omitempty"`
}

RawRequest is the data structure for storing raw requests in the storage.

func NewRawRequest

func NewRawRequest(
	ExternalID ExternalID,
	DataSourceID DataSourceID,
	Calldata []byte,
) RawRequest

func (*RawRequest) Descriptor

func (*RawRequest) Descriptor() ([]byte, []int)

func (*RawRequest) Equal

func (this *RawRequest) Equal(that interface{}) bool

func (*RawRequest) GetCalldata

func (m *RawRequest) GetCalldata() []byte

func (*RawRequest) GetDataSourceID

func (m *RawRequest) GetDataSourceID() DataSourceID

func (*RawRequest) GetExternalID

func (m *RawRequest) GetExternalID() ExternalID

func (*RawRequest) Marshal

func (m *RawRequest) Marshal() (dAtA []byte, err error)

func (*RawRequest) MarshalTo

func (m *RawRequest) MarshalTo(dAtA []byte) (int, error)

func (*RawRequest) MarshalToSizedBuffer

func (m *RawRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*RawRequest) ProtoMessage

func (*RawRequest) ProtoMessage()

func (*RawRequest) Reset

func (m *RawRequest) Reset()

func (*RawRequest) Size

func (m *RawRequest) Size() (n int)

func (*RawRequest) String

func (m *RawRequest) String() string

func (*RawRequest) Unmarshal

func (m *RawRequest) Unmarshal(dAtA []byte) error

func (*RawRequest) XXX_DiscardUnknown

func (m *RawRequest) XXX_DiscardUnknown()

func (*RawRequest) XXX_Marshal

func (m *RawRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*RawRequest) XXX_Merge

func (m *RawRequest) XXX_Merge(src proto.Message)

func (*RawRequest) XXX_Size

func (m *RawRequest) XXX_Size() int

func (*RawRequest) XXX_Unmarshal

func (m *RawRequest) XXX_Unmarshal(b []byte) error

type Report

type Report struct {
	// Validator is a validator address who submit the report
	Validator string `protobuf:"bytes,1,opt,name=validator,proto3" json:"validator,omitempty"`
	// InBeforeResolve indicates whether the report is submitted before the
	// request resolved
	InBeforeResolve bool `protobuf:"varint,2,opt,name=in_before_resolve,json=inBeforeResolve,proto3" json:"in_before_resolve,omitempty"`
	// RawReports is list of raw reports provided by the validator.
	// Each raw report has different external ID
	RawReports []RawReport `protobuf:"bytes,3,rep,name=raw_reports,json=rawReports,proto3" json:"raw_reports"`
}

Report is the data structure for storing reports in the storage.

func NewReport

func NewReport(
	Validator sdk.ValAddress,
	InBeforeResolve bool,
	RawReports []RawReport,
) Report

func (*Report) Descriptor

func (*Report) Descriptor() ([]byte, []int)

func (*Report) Equal

func (this *Report) Equal(that interface{}) bool

func (*Report) GetInBeforeResolve

func (m *Report) GetInBeforeResolve() bool

func (*Report) GetRawReports

func (m *Report) GetRawReports() []RawReport

func (*Report) GetValidator

func (m *Report) GetValidator() string

func (*Report) Marshal

func (m *Report) Marshal() (dAtA []byte, err error)

func (*Report) MarshalTo

func (m *Report) MarshalTo(dAtA []byte) (int, error)

func (*Report) MarshalToSizedBuffer

func (m *Report) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*Report) ProtoMessage

func (*Report) ProtoMessage()

func (*Report) Reset

func (m *Report) Reset()

func (*Report) Size

func (m *Report) Size() (n int)

func (*Report) String

func (m *Report) String() string

func (*Report) Unmarshal

func (m *Report) Unmarshal(dAtA []byte) error

func (*Report) XXX_DiscardUnknown

func (m *Report) XXX_DiscardUnknown()

func (*Report) XXX_Marshal

func (m *Report) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Report) XXX_Merge

func (m *Report) XXX_Merge(src proto.Message)

func (*Report) XXX_Size

func (m *Report) XXX_Size() int

func (*Report) XXX_Unmarshal

func (m *Report) XXX_Unmarshal(b []byte) error

type Request

type Request struct {
	// OracleScriptID is ID of an oracle script
	OracleScriptID OracleScriptID `` /* 130-byte string literal not displayed */
	// Calldata is the data used as argument params for the oracle script
	Calldata []byte `protobuf:"bytes,2,opt,name=calldata,proto3" json:"calldata,omitempty"`
	// RequestedValidators is a list of validator addresses that are assigned for
	// fulfilling the request
	RequestedValidators []string `protobuf:"bytes,3,rep,name=requested_validators,json=requestedValidators,proto3" json:"requested_validators,omitempty"`
	// MinCount is minimum number of validators required for fulfilling the
	// request
	MinCount uint64 `protobuf:"varint,4,opt,name=min_count,json=minCount,proto3" json:"min_count,omitempty"`
	// RequestHeight is block height that the request has been created
	RequestHeight int64 `protobuf:"varint,5,opt,name=request_height,json=requestHeight,proto3" json:"request_height,omitempty"`
	// RequestTime is timestamp of the chain's block which contains the request
	RequestTime int64 `protobuf:"varint,6,opt,name=request_time,json=requestTime,proto3" json:"request_time,omitempty"`
	// ClientID is arbitrary id provided by requester.
	// It is used by client-side for referencing the request
	ClientID string `protobuf:"bytes,7,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"`
	// RawRequests is a list of raw requests specified by execution of oracle
	// script
	RawRequests []RawRequest `protobuf:"bytes,8,rep,name=raw_requests,json=rawRequests,proto3" json:"raw_requests"`
	// IBCChannel is an IBC channel info of the other chain, which contains a
	// channel and a port to allow bandchain connect to that chain. This field
	// allows other chain be able to request data from bandchain via IBC.
	IBCChannel *IBCChannel `protobuf:"bytes,9,opt,name=ibc_channel,json=ibcChannel,proto3" json:"ibc_channel,omitempty"`
	// ExecuteGas is amount of gas to reserve for executing
	ExecuteGas uint64 `protobuf:"varint,10,opt,name=execute_gas,json=executeGas,proto3" json:"execute_gas,omitempty"`
}

Request is the data structure for storing requests in the storage.

func NewRequest

func NewRequest(
	oracleScriptID OracleScriptID,
	calldata []byte,
	requestedValidators []sdk.ValAddress,
	minCount uint64,
	requestHeight int64,
	requestTime time.Time,
	clientID string,
	rawRequests []RawRequest,
	ibcChannel *IBCChannel,
	executeGas uint64,
) Request

func (*Request) Descriptor

func (*Request) Descriptor() ([]byte, []int)

func (*Request) Equal

func (this *Request) Equal(that interface{}) bool

func (*Request) GetCalldata

func (m *Request) GetCalldata() []byte

func (*Request) GetClientID

func (m *Request) GetClientID() string

func (*Request) GetExecuteGas

func (m *Request) GetExecuteGas() uint64

func (*Request) GetIBCChannel

func (m *Request) GetIBCChannel() *IBCChannel

func (*Request) GetMinCount

func (m *Request) GetMinCount() uint64

func (*Request) GetOracleScriptID

func (m *Request) GetOracleScriptID() OracleScriptID

func (*Request) GetRawRequests

func (m *Request) GetRawRequests() []RawRequest

func (*Request) GetRequestHeight

func (m *Request) GetRequestHeight() int64

func (*Request) GetRequestTime

func (m *Request) GetRequestTime() int64

func (*Request) GetRequestedValidators

func (m *Request) GetRequestedValidators() []string

func (*Request) Marshal

func (m *Request) Marshal() (dAtA []byte, err error)

func (*Request) MarshalTo

func (m *Request) MarshalTo(dAtA []byte) (int, error)

func (*Request) MarshalToSizedBuffer

func (m *Request) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*Request) ProtoMessage

func (*Request) ProtoMessage()

func (*Request) Reset

func (m *Request) Reset()

func (*Request) Size

func (m *Request) Size() (n int)

func (*Request) String

func (m *Request) String() string

func (*Request) Unmarshal

func (m *Request) Unmarshal(dAtA []byte) error

func (*Request) XXX_DiscardUnknown

func (m *Request) XXX_DiscardUnknown()

func (*Request) XXX_Marshal

func (m *Request) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Request) XXX_Merge

func (m *Request) XXX_Merge(src proto.Message)

func (*Request) XXX_Size

func (m *Request) XXX_Size() int

func (*Request) XXX_Unmarshal

func (m *Request) XXX_Unmarshal(b []byte) error

type RequestID

type RequestID uint64

RequestID is the type-safe unique identifier type for data requests.

type RequestSpec

type RequestSpec interface {
	GetOracleScriptID() OracleScriptID
	GetCalldata() []byte
	GetAskCount() uint64
	GetMinCount() uint64
	GetClientID() string
	GetPrepareGas() uint64
	GetExecuteGas() uint64
	GetFeeLimit() sdk.Coins
}

RequestSpec captures the essence of what it means to be a request-making object.

type RequestVerification

type RequestVerification struct {
	// ChainID is the ID of targeted chain
	ChainID string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// Validator is an validator address
	Validator string `protobuf:"bytes,2,opt,name=validator,proto3" json:"validator,omitempty"`
	// RequestID is the targeted request ID
	RequestID RequestID `protobuf:"varint,3,opt,name=request_id,json=requestId,proto3,casttype=RequestID" json:"request_id,omitempty"`
	// ExternalID is the oracle's external ID of data source
	ExternalID ExternalID `protobuf:"varint,4,opt,name=external_id,json=externalId,proto3,casttype=ExternalID" json:"external_id,omitempty"`
	// DataSourceID is the ID of data source
	DataSourceID DataSourceID `protobuf:"varint,5,opt,name=data_source_id,json=dataSourceId,proto3,casttype=DataSourceID" json:"data_source_id,omitempty"`
}

RequestVerification is a message that is constructed and signed by a reporter to be used as a part of verification of oracle request.

func NewRequestVerification

func NewRequestVerification(
	chainID string,
	validator sdk.ValAddress,
	requestID RequestID,
	externalID ExternalID,
	dataSourceID DataSourceID,
) RequestVerification

func (*RequestVerification) Descriptor

func (*RequestVerification) Descriptor() ([]byte, []int)

func (*RequestVerification) Equal

func (this *RequestVerification) Equal(that interface{}) bool

func (*RequestVerification) GetChainID

func (m *RequestVerification) GetChainID() string

func (*RequestVerification) GetDataSourceID added in v2.3.4

func (m *RequestVerification) GetDataSourceID() DataSourceID

func (*RequestVerification) GetExternalID

func (m *RequestVerification) GetExternalID() ExternalID

func (*RequestVerification) GetRequestID

func (m *RequestVerification) GetRequestID() RequestID

func (RequestVerification) GetSignBytes

func (msg RequestVerification) GetSignBytes() []byte

func (*RequestVerification) GetValidator

func (m *RequestVerification) GetValidator() string

func (*RequestVerification) Marshal

func (m *RequestVerification) Marshal() (dAtA []byte, err error)

func (*RequestVerification) MarshalTo

func (m *RequestVerification) MarshalTo(dAtA []byte) (int, error)

func (*RequestVerification) MarshalToSizedBuffer

func (m *RequestVerification) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*RequestVerification) ProtoMessage

func (*RequestVerification) ProtoMessage()

func (*RequestVerification) Reset

func (m *RequestVerification) Reset()

func (*RequestVerification) Size

func (m *RequestVerification) Size() (n int)

func (*RequestVerification) String

func (m *RequestVerification) String() string

func (*RequestVerification) Unmarshal

func (m *RequestVerification) Unmarshal(dAtA []byte) error

func (*RequestVerification) XXX_DiscardUnknown

func (m *RequestVerification) XXX_DiscardUnknown()

func (*RequestVerification) XXX_Marshal

func (m *RequestVerification) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*RequestVerification) XXX_Merge

func (m *RequestVerification) XXX_Merge(src proto.Message)

func (*RequestVerification) XXX_Size

func (m *RequestVerification) XXX_Size() int

func (*RequestVerification) XXX_Unmarshal

func (m *RequestVerification) XXX_Unmarshal(b []byte) error

type ResolveStatus

type ResolveStatus int32

ResolveStatus encodes the status of an oracle request.

const (
	// Open - the request is not yet resolved.
	RESOLVE_STATUS_OPEN ResolveStatus = 0
	// Success - the request has been resolved successfully with no errors.
	RESOLVE_STATUS_SUCCESS ResolveStatus = 1
	// Failure - an error occured during the request's resolve call.
	RESOLVE_STATUS_FAILURE ResolveStatus = 2
	// Expired - the request does not get enough reports from validator within the
	// timeframe.
	RESOLVE_STATUS_EXPIRED ResolveStatus = 3
)

func (ResolveStatus) EnumDescriptor

func (ResolveStatus) EnumDescriptor() ([]byte, []int)

func (ResolveStatus) String

func (x ResolveStatus) String() string

type Result

type Result struct {
	// ClientID is the unique identifier of this oracle request, as specified by
	// the client. This same unique ID will be sent back to the requester with the
	// oracle response.
	ClientID string `protobuf:"bytes,1,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"`
	// OracleScriptID is the unique identifier of the oracle script to be
	// executed.
	OracleScriptID OracleScriptID `` /* 130-byte string literal not displayed */
	// Calldata is the calldata bytes available for oracle executor to read.
	Calldata []byte `protobuf:"bytes,3,opt,name=calldata,proto3" json:"calldata,omitempty"`
	// AskCount is the number of validators that are requested to respond to this
	// oracle request. Higher value means more security, at a higher gas cost.
	AskCount uint64 `protobuf:"varint,4,opt,name=ask_count,json=askCount,proto3" json:"ask_count,omitempty"`
	// MinCount is the minimum number of validators necessary for the request to
	// proceed to the execution phase. Higher value means more security, at the
	// cost of liveness.
	MinCount uint64 `protobuf:"varint,5,opt,name=min_count,json=minCount,proto3" json:"min_count,omitempty"`
	// RequestID is BandChain's unique identifier for this oracle request.
	RequestID RequestID `protobuf:"varint,6,opt,name=request_id,json=requestId,proto3,casttype=RequestID" json:"request_id,omitempty"`
	// AnsCount is the number of validators among to the asked validators that
	// actually responded to this oracle request prior to this oracle request
	// being resolved.
	AnsCount uint64 `protobuf:"varint,7,opt,name=ans_count,json=ansCount,proto3" json:"ans_count,omitempty"`
	// RequestTime is the UNIX epoch time at which the request was sent to
	// BandChain.
	RequestTime int64 `protobuf:"varint,8,opt,name=request_time,json=requestTime,proto3" json:"request_time,omitempty"`
	// ResolveTime is the UNIX epoch time at which the request was resolved to the
	// final result.
	ResolveTime int64 `protobuf:"varint,9,opt,name=resolve_time,json=resolveTime,proto3" json:"resolve_time,omitempty"`
	// ResolveStatus is the status of this oracle request, which can be OK,
	// FAILURE, or EXPIRED.
	ResolveStatus ResolveStatus `` /* 131-byte string literal not displayed */
	// Result is the final aggregated value only available if status if OK.
	Result []byte `protobuf:"bytes,11,opt,name=result,proto3" json:"result,omitempty"`
}

Result encodes a result of request and store in chain

func NewResult

func NewResult(
	clientId string,
	oid OracleScriptID,
	calldata []byte,
	askCount, minCount uint64,
	requestId RequestID,
	ansCount uint64,
	requestTime, resolveTime int64,
	resolveStatus ResolveStatus,
	result []byte,
) Result

NewResult creates a new Result instance.

func (*Result) Descriptor

func (*Result) Descriptor() ([]byte, []int)

func (*Result) Equal

func (this *Result) Equal(that interface{}) bool

func (*Result) GetAnsCount

func (m *Result) GetAnsCount() uint64

func (*Result) GetAskCount

func (m *Result) GetAskCount() uint64

func (*Result) GetCalldata

func (m *Result) GetCalldata() []byte

func (*Result) GetClientID

func (m *Result) GetClientID() string

func (*Result) GetMinCount

func (m *Result) GetMinCount() uint64

func (*Result) GetOracleScriptID

func (m *Result) GetOracleScriptID() OracleScriptID

func (*Result) GetRequestID

func (m *Result) GetRequestID() RequestID

func (*Result) GetRequestTime

func (m *Result) GetRequestTime() int64

func (*Result) GetResolveStatus

func (m *Result) GetResolveStatus() ResolveStatus

func (*Result) GetResolveTime

func (m *Result) GetResolveTime() int64

func (*Result) GetResult

func (m *Result) GetResult() []byte

func (*Result) Marshal

func (m *Result) Marshal() (dAtA []byte, err error)

func (*Result) MarshalTo

func (m *Result) MarshalTo(dAtA []byte) (int, error)

func (*Result) MarshalToSizedBuffer

func (m *Result) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*Result) ProtoMessage

func (*Result) ProtoMessage()

func (*Result) Reset

func (m *Result) Reset()

func (*Result) Size

func (m *Result) Size() (n int)

func (*Result) String

func (m *Result) String() string

func (*Result) Unmarshal

func (m *Result) Unmarshal(dAtA []byte) error

func (*Result) XXX_DiscardUnknown

func (m *Result) XXX_DiscardUnknown()

func (*Result) XXX_Marshal

func (m *Result) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Result) XXX_Merge

func (m *Result) XXX_Merge(src proto.Message)

func (*Result) XXX_Size

func (m *Result) XXX_Size() int

func (*Result) XXX_Unmarshal

func (m *Result) XXX_Unmarshal(b []byte) error

type StakingKeeper

type StakingKeeper interface {
	ValidatorByConsAddr(sdk.Context, sdk.ConsAddress) stakingtypes.ValidatorI
	IterateBondedValidatorsByPower(
		ctx sdk.Context,
		fn func(index int64, validator stakingtypes.ValidatorI) (stop bool),
	)
	Validator(ctx sdk.Context, address sdk.ValAddress) stakingtypes.ValidatorI
}

StakingKeeper defines the expected staking keeper.

type UnimplementedMsgServer

type UnimplementedMsgServer struct {
}

UnimplementedMsgServer can be embedded to have forward compatible implementations.

func (*UnimplementedMsgServer) Activate

func (*UnimplementedMsgServer) CreateDataSource

func (*UnimplementedMsgServer) CreateOracleScript

func (*UnimplementedMsgServer) EditDataSource

func (*UnimplementedMsgServer) EditOracleScript

func (*UnimplementedMsgServer) ReportData

func (*UnimplementedMsgServer) RequestData

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) ActiveValidators

func (*UnimplementedQueryServer) Counts

func (*UnimplementedQueryServer) Data

func (*UnimplementedQueryServer) DataSource

func (*UnimplementedQueryServer) IsReporter added in v2.2.0

func (*UnimplementedQueryServer) OracleScript

func (*UnimplementedQueryServer) Params

func (*UnimplementedQueryServer) PendingRequests

func (*UnimplementedQueryServer) Reporters

func (*UnimplementedQueryServer) Request

func (*UnimplementedQueryServer) RequestPrice

func (*UnimplementedQueryServer) RequestSearch

func (*UnimplementedQueryServer) RequestVerification

func (*UnimplementedQueryServer) Validator

type ValidatorStatus

type ValidatorStatus struct {
	// IsActive is a boolean indicating active status of validator.
	// The validator will be deactivated when they are unable to send reports
	// to fulfill oracle request before the request expired.
	IsActive bool `protobuf:"varint,1,opt,name=is_active,json=isActive,proto3" json:"is_active,omitempty"`
	// Since is a block timestamp when validator has been activated/deactivated
	Since time.Time `protobuf:"bytes,2,opt,name=since,proto3,stdtime" json:"since"`
}

ValidatorStatus maintains whether a validator is an active oracle provider.

func NewValidatorStatus

func NewValidatorStatus(
	IsActive bool,
	Since time.Time,
) ValidatorStatus

func (*ValidatorStatus) Descriptor

func (*ValidatorStatus) Descriptor() ([]byte, []int)

func (*ValidatorStatus) Equal

func (this *ValidatorStatus) Equal(that interface{}) bool

func (*ValidatorStatus) GetIsActive

func (m *ValidatorStatus) GetIsActive() bool

func (*ValidatorStatus) GetSince

func (m *ValidatorStatus) GetSince() time.Time

func (*ValidatorStatus) Marshal

func (m *ValidatorStatus) Marshal() (dAtA []byte, err error)

func (*ValidatorStatus) MarshalTo

func (m *ValidatorStatus) MarshalTo(dAtA []byte) (int, error)

func (*ValidatorStatus) MarshalToSizedBuffer

func (m *ValidatorStatus) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*ValidatorStatus) ProtoMessage

func (*ValidatorStatus) ProtoMessage()

func (*ValidatorStatus) Reset

func (m *ValidatorStatus) Reset()

func (*ValidatorStatus) Size

func (m *ValidatorStatus) Size() (n int)

func (*ValidatorStatus) String

func (m *ValidatorStatus) String() string

func (*ValidatorStatus) Unmarshal

func (m *ValidatorStatus) Unmarshal(dAtA []byte) error

func (*ValidatorStatus) XXX_DiscardUnknown

func (m *ValidatorStatus) XXX_DiscardUnknown()

func (*ValidatorStatus) XXX_Marshal

func (m *ValidatorStatus) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*ValidatorStatus) XXX_Merge

func (m *ValidatorStatus) XXX_Merge(src proto.Message)

func (*ValidatorStatus) XXX_Size

func (m *ValidatorStatus) XXX_Size() int

func (*ValidatorStatus) XXX_Unmarshal

func (m *ValidatorStatus) XXX_Unmarshal(b []byte) error

Jump to

Keyboard shortcuts

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