types

package
v5.1.3 Latest Latest
Warning

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

Go to latest
Published: Feb 21, 2025 License: Apache-2.0 Imports: 41 Imported by: 0

Documentation

Overview

Package types is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

Index

Constants

View Source
const (
	// ModuleName defines the module name
	ModuleName = "interchainqueries"

	// StoreKey defines the primary module store key
	StoreKey = ModuleName

	// RouterKey is the message route for slashing
	RouterKey = ModuleName

	// QuerierRoute defines the module's query routing key
	QuerierRoute = ModuleName

	// MemStoreKey defines the in-memory store key
	MemStoreKey = "mem_interchainqueries"
)
View Source
const (
	// EventTypeNeutronMessage defines the event type used by the Interchain Queries module events.
	EventTypeNeutronMessage = "neutron"

	// AttributeKeyQueryID represents the key for event attribute delivering the query ID of a
	// registered interchain query.
	AttributeKeyQueryID = "query_id"

	// AttributeKeyOwner represents the key for event attribute delivering the address of the
	// registrator of an interchain query.
	AttributeKeyOwner = "owner"

	// AttributeKeyConnectionID represents the key for event attribute delivering the connection ID
	// of an interchain query.
	AttributeKeyConnectionID = "connection_id"

	// AttributeKeyQueryType represents the key for event attribute delivering the query type
	// identifier (e.g. 'kv' or 'tx')
	AttributeKeyQueryType = "type"

	// AttributeKeyKVQuery represents the keys of the storage we want to get from remote chain for event attribute delivering the keys
	// of an interchain query.
	AttributeKeyKVQuery = "kv_key"

	// AttributeTransactionsFilterQuery represents the transactions filter for event attribute delivering the filter
	// of an interchain query.
	AttributeTransactionsFilterQuery = "tx_filter"

	// AttributeValueCategory represents the value for the 'module' event attribute.
	AttributeValueCategory = ModuleName

	// AttributeValueQueryUpdated represents the value for the 'action' event attribute.
	AttributeValueQueryUpdated = "query_updated"

	// AttributeValueQueryRemoved represents the value for the 'action' event attribute.
	AttributeValueQueryRemoved = "query_removed"
)
View Source
const ConsensusVersion = 3

Variables

View Source
var (
	ErrInvalidQueryID             = errors.Register(ModuleName, 1100, "invalid query id")
	ErrEmptyResult                = errors.Register(ModuleName, 1101, "empty result")
	ErrInvalidClientID            = errors.Register(ModuleName, 1102, "invalid client id")
	ErrInvalidUpdatePeriod        = errors.Register(ModuleName, 1103, "invalid update period")
	ErrInvalidConnectionID        = errors.Register(ModuleName, 1104, "invalid connection id")
	ErrInvalidQueryType           = errors.Register(ModuleName, 1105, "invalid query type")
	ErrInvalidTransactionsFilter  = errors.Register(ModuleName, 1106, "invalid transactions filter")
	ErrInvalidSubmittedResult     = errors.Register(ModuleName, 1107, "invalid result")
	ErrProtoMarshal               = errors.Register(ModuleName, 1108, "failed to marshal protobuf bytes")
	ErrProtoUnmarshal             = errors.Register(ModuleName, 1109, "failed to unmarshal protobuf bytes")
	ErrInvalidType                = errors.Register(ModuleName, 1110, "invalid type")
	ErrInternal                   = errors.Register(ModuleName, 1111, "internal error")
	ErrInvalidProof               = errors.Register(ModuleName, 1112, "merkle proof is invalid")
	ErrInvalidHeader              = errors.Register(ModuleName, 1113, "header is invalid")
	ErrInvalidHeight              = errors.Register(ModuleName, 1114, "height is invalid")
	ErrNoQueryResult              = errors.Register(ModuleName, 1115, "no query result")
	ErrNotContract                = errors.Register(ModuleName, 1116, "not a contract")
	ErrEmptyKeys                  = errors.Register(ModuleName, 1117, "keys are empty")
	ErrEmptyKeyPath               = errors.Register(ModuleName, 1118, "key path is empty")
	ErrEmptyKeyID                 = errors.Register(ModuleName, 1119, "key id is empty")
	ErrTooManyKVQueryKeys         = errors.Register(ModuleName, 1120, "too many keys")
	ErrUnexpectedQueryTypeGenesis = errors.Register(ModuleName, 1121, "unexpected query type")
)

x/interchainqueries module sentinel errors

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 (
	// RegisteredQueryKey is the store key for queries registered in the module.
	RegisteredQueryKey = []byte{prefixRegisteredQuery}
	// RegisteredQueryResultKey is the store key for KV query results.
	RegisteredQueryResultKey = []byte{prefixRegisteredQueryResult}
	// SubmittedTxKey is the store key for submitted transaction hashes.
	SubmittedTxKey = []byte{prefixSubmittedTx}
	// TxQueryToRemoveKey is the store key for TX queries marked to be removed.
	TxQueryToRemoveKey = []byte{prefixTxQueryToRemove}
	// ParamsKey is the store key for the module params
	ParamsKey = []byte{prefixParamsKey}
	// LastRegisteredQueryIDKey is the store key for last registered query ID.
	LastRegisteredQueryIDKey = []byte{0x64}
)
View Source
var (
	KeyQuerySubmitTimeout         = []byte("QuerySubmitTimeout")
	DefaultQuerySubmitTimeout     = uint64(1036800) // One month, with block_time = 2.5s
	KeyQueryDeposit               = []byte("QueryDeposit")
	DefaultQueryDeposit           = sdk.NewCoins(sdk.NewCoin(params.DefaultDenom, math.NewInt(int64(1_000_000))))
	KeyTxQueryRemovalLimit        = []byte("TxQueryRemovalLimit")
	DefaultTxQueryRemovalLimit    = uint64(10_000)
	DefaultMaxKvQueryKeysCount    = uint64(32)
	DefaultMaxTransactionsFilters = uint64(32)
)
View Source
var (
	ErrInvalidLengthParams        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowParams          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupParams = fmt.Errorf("proto: unexpected end of group")
)
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")
)

Functions

func GetRegisteredQueryByIDKey

func GetRegisteredQueryByIDKey(id uint64) []byte

GetRegisteredQueryByIDKey builds a store key to access a registered query by query ID.

func GetRegisteredQueryResultByIDKey

func GetRegisteredQueryResultByIDKey(id uint64) []byte

GetRegisteredQueryResultByIDKey builds a store key to access a KV query result by query ID.

func GetSubmittedTransactionIDForQueryKey

func GetSubmittedTransactionIDForQueryKey(queryID uint64, txHash []byte) []byte

GetSubmittedTransactionIDForQueryKey builds a store key to access a submitted transaction hash by query ID and hash.

func GetSubmittedTransactionIDForQueryKeyPrefix

func GetSubmittedTransactionIDForQueryKeyPrefix(queryID uint64) []byte

GetSubmittedTransactionIDForQueryKeyPrefix builds a store key prefix to access TX query hashes by ID.

func GetTxQueryToRemoveByIDKey

func GetTxQueryToRemoveByIDKey(id uint64) []byte

GetTxQueryToRemoveByIDKey builds a store key to access a TX query marked to be removed.

func ParamKeyTable

func ParamKeyTable() paramtypes.KeyTable

ParamKeyTable the param key table for launch module

func RegisterCodec

func RegisterCodec(cdc *codec.LegacyAmino)

func RegisterInterfaces

func RegisterInterfaces(registry cdctypes.InterfaceRegistry)

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 to stop working. Consider using RegisterQueryHandlerFromEndpoint instead.

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

func ValidateTransactionsFilter

func ValidateTransactionsFilter(s string, maxTransactionsFilters uint64) error

ValidateTransactionsFilter checks if the passed string is a valid TransactionsFilter value.

Types

type AccountKeeper

type AccountKeeper interface {
	GetAccount(ctx context.Context, addr sdk.AccAddress) sdk.AccountI
}

AccountKeeper defines the expected account keeper used for simulations (noalias)

type BankKeeper

type BankKeeper interface {
	SpendableCoins(ctx context.Context, addr sdk.AccAddress) sdk.Coins
	SendCoinsFromModuleToAccount(ctx context.Context, senderModule string, recipientAddr sdk.AccAddress, amt sdk.Coins) error
	SendCoinsFromAccountToModule(ctx context.Context, senderAddr sdk.AccAddress, recipientModule string, amt sdk.Coins) error
}

BankKeeper defines the expected interface needed to retrieve account balances.

type Block

type Block struct {
	// The header of the block next to the block the transaction is included in. It is needed to know
	// block X+1 header to verify response of transaction for block X since LastResultsHash is root
	// hash of all results of the txs from the previous block.
	NextBlockHeader *types.Any `protobuf:"bytes,1,opt,name=next_block_header,json=nextBlockHeader,proto3" json:"next_block_header,omitempty"`
	// The header of the block the transaction is included in. It is needed to know block header to
	// verify inclusion of the transaction.
	Header *types.Any `protobuf:"bytes,2,opt,name=header,proto3" json:"header,omitempty"`
	// The transaction matched by the Interchain Query's transaction filter.
	Tx *TxValue `protobuf:"bytes,3,opt,name=tx,proto3" json:"tx,omitempty"`
}

A single verifiable result of an Interchain Query of TX type.

func (*Block) Descriptor

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

func (*Block) GetHeader

func (m *Block) GetHeader() *types.Any

func (*Block) GetNextBlockHeader

func (m *Block) GetNextBlockHeader() *types.Any

func (*Block) GetTx

func (m *Block) GetTx() *TxValue

func (*Block) Marshal

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

func (*Block) MarshalTo

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

func (*Block) MarshalToSizedBuffer

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

func (*Block) ProtoMessage

func (*Block) ProtoMessage()

func (*Block) Reset

func (m *Block) Reset()

func (*Block) Size

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

func (*Block) String

func (m *Block) String() string

func (*Block) Unmarshal

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

func (*Block) XXX_DiscardUnknown

func (m *Block) XXX_DiscardUnknown()

func (*Block) XXX_Marshal

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

func (*Block) XXX_Merge

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

func (*Block) XXX_Size

func (m *Block) XXX_Size() int

func (*Block) XXX_Unmarshal

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

type ContractManagerKeeper

type ContractManagerKeeper interface {
	HasContractInfo(ctx context.Context, contractAddress sdk.AccAddress) bool
	SudoKVQueryResult(ctx context.Context, contractAddress sdk.AccAddress, queryID uint64) ([]byte, error)
	SudoTxQueryResult(ctx context.Context, contractAddress sdk.AccAddress, queryID uint64, height ibcclienttypes.Height, data []byte) ([]byte, error)
}

type GenesisState

type GenesisState struct {
	// The parameters of the module.
	Params Params `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
	// A list of registered Interchain Queries.
	RegisteredQueries []*RegisteredQuery `protobuf:"bytes,2,rep,name=registered_queries,json=registeredQueries,proto3" json:"registered_queries,omitempty"`
}

The interchainqueries module's genesis state model.

func DefaultGenesis

func DefaultGenesis() *GenesisState

DefaultGenesis returns the default Capability genesis state

func (*GenesisState) Descriptor

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

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() Params

func (*GenesisState) GetRegisteredQueries

func (m *GenesisState) GetRegisteredQueries() []*RegisteredQuery

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 (gs 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 HeaderVerifier

type HeaderVerifier interface {
	VerifyHeaders(ctx sdk.Context, cleintkeeper clientkeeper.Keeper, clientID string, header, nextHeader exported.ClientMessage) error
	UnpackHeader(anyHeader *codectypes.Any) (exported.ClientMessage, error)
}

type InterchainQueryType

type InterchainQueryType string
const (
	InterchainQueryTypeKV InterchainQueryType = "kv"
	InterchainQueryTypeTX InterchainQueryType = "tx"
)

func (InterchainQueryType) IsKV

func (icqt InterchainQueryType) IsKV() bool

func (InterchainQueryType) IsTX

func (icqt InterchainQueryType) IsTX() bool

func (InterchainQueryType) IsValid

func (icqt InterchainQueryType) IsValid() bool

type KVKey

type KVKey struct {
	// The substore name used in an Interchain Query. Typically, this corresponds to the keeper's
	// storeKey, usually the module's name, such as "bank", "staking", etc.
	Path string `protobuf:"bytes,1,opt,name=path,proto3" json:"path,omitempty"`
	// A bytes field representing the key for specific data in the module's storage.
	Key []byte `protobuf:"bytes,2,opt,name=key,proto3" json:"key,omitempty"`
}

Represents a path to an IAVL storage node.

func (*KVKey) Descriptor

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

func (*KVKey) GetKey

func (m *KVKey) GetKey() []byte

func (*KVKey) GetPath

func (m *KVKey) GetPath() string

func (*KVKey) Marshal

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

func (*KVKey) MarshalTo

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

func (*KVKey) MarshalToSizedBuffer

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

func (*KVKey) ProtoMessage

func (*KVKey) ProtoMessage()

func (*KVKey) Reset

func (m *KVKey) Reset()

func (*KVKey) Size

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

func (*KVKey) String

func (m *KVKey) String() string

func (KVKey) ToString

func (kv KVKey) ToString() string

func (*KVKey) Unmarshal

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

func (*KVKey) XXX_DiscardUnknown

func (m *KVKey) XXX_DiscardUnknown()

func (*KVKey) XXX_Marshal

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

func (*KVKey) XXX_Merge

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

func (*KVKey) XXX_Size

func (m *KVKey) XXX_Size() int

func (*KVKey) XXX_Unmarshal

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

type KVKeys

type KVKeys []*KVKey

func (KVKeys) String

func (keys KVKeys) String() string

type MsgClient

type MsgClient interface {
	// Registers a new Interchain Query in the `interchainqueries` module. This message should only
	// be issued by a smart contract. The calling contract is automatically charged a query
	// registration deposit, based on the module's query deposit parameter. The deposit is refunded
	// when the query is removed. Ensure the contract's account has sufficient assets at the time of
	// message execution.
	//
	// The response includes the ID assigned to the registered query. Use a reply handler to process
	// this response and utilize the query ID.
	RegisterInterchainQuery(ctx context.Context, in *MsgRegisterInterchainQuery, opts ...grpc.CallOption) (*MsgRegisterInterchainQueryResponse, error)
	// Submits the result of an Interchain Query execution to the chain. Handling this message may
	// involve forwarding the result to the smart contract that owns the query for processing, which
	// could require significant gas usage.
	SubmitQueryResult(ctx context.Context, in *MsgSubmitQueryResult, opts ...grpc.CallOption) (*MsgSubmitQueryResultResponse, error)
	// Removes a specific Interchain Query and its results from the module. The query can only be
	// removed by its owner during the query's submit timeout. After the timeout, anyone can remove
	// it. Upon successful removal, the query deposit is refunded to the caller.
	RemoveInterchainQuery(ctx context.Context, in *MsgRemoveInterchainQueryRequest, opts ...grpc.CallOption) (*MsgRemoveInterchainQueryResponse, error)
	// Updates the parameters of a registered Interchain Query. This action can only be performed by
	// the query's owner.
	UpdateInterchainQuery(ctx context.Context, in *MsgUpdateInterchainQueryRequest, opts ...grpc.CallOption) (*MsgUpdateInterchainQueryResponse, error)
	// Updates the parameters of the `interchainqueries` module. This action can only be performed
	// by the module's authority.
	UpdateParams(ctx context.Context, in *MsgUpdateParams, opts ...grpc.CallOption) (*MsgUpdateParamsResponse, 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 MsgRegisterInterchainQuery

type MsgRegisterInterchainQuery struct {
	// The query type identifier: `kv` or `tx`.
	QueryType string `protobuf:"bytes,1,opt,name=query_type,json=queryType,proto3" json:"query_type,omitempty"`
	// The KV-storage keys for which we want to get values from remote chain. Only applicable for the
	// KV Interchain Queries. Max amount of keys is limited by the module's `max_kv_query_keys_count`
	// parameters.
	Keys []*KVKey `protobuf:"bytes,2,rep,name=keys,proto3" json:"keys,omitempty"`
	// A stringified list of filters for remote transactions search. Only applicable for the TX
	// Interchain Queries. Example: "[{\"field\":\"tx.height\",\"op\":\"Gte\",\"value\":2644737}]".
	// Supported operators: "eq", "lt", "gt", "lte", "gte". Max amount of filter conditions is
	// limited by the module's `max_transactions_filters` parameters.
	TransactionsFilter string `protobuf:"bytes,3,opt,name=transactions_filter,json=transactionsFilter,proto3" json:"transactions_filter,omitempty"`
	// The IBC connection ID to the remote chain (the source of querying data). Is used for getting
	// ConsensusState from the respective IBC client to verify query result proofs.
	ConnectionId string `protobuf:"bytes,4,opt,name=connection_id,json=connectionId,proto3" json:"connection_id,omitempty"`
	// Parameter that defines the minimal delay between consecutive query executions (i.e. the
	// minimal delay between query results update).
	UpdatePeriod uint64 `protobuf:"varint,5,opt,name=update_period,json=updatePeriod,proto3" json:"update_period,omitempty"`
	// The signer of the message.
	Sender string `protobuf:"bytes,6,opt,name=sender,proto3" json:"sender,omitempty"`
}

Request type for the Msg/RegisterInterchainQuery RPC method.

func (*MsgRegisterInterchainQuery) Descriptor

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

func (*MsgRegisterInterchainQuery) GetConnectionId

func (m *MsgRegisterInterchainQuery) GetConnectionId() string

func (*MsgRegisterInterchainQuery) GetKeys

func (m *MsgRegisterInterchainQuery) GetKeys() []*KVKey

func (*MsgRegisterInterchainQuery) GetQueryType

func (m *MsgRegisterInterchainQuery) GetQueryType() string

func (*MsgRegisterInterchainQuery) GetSender

func (m *MsgRegisterInterchainQuery) GetSender() string

func (MsgRegisterInterchainQuery) GetSignBytes

func (msg MsgRegisterInterchainQuery) GetSignBytes() []byte

func (MsgRegisterInterchainQuery) GetSigners

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

func (*MsgRegisterInterchainQuery) GetTransactionsFilter

func (m *MsgRegisterInterchainQuery) GetTransactionsFilter() string

func (*MsgRegisterInterchainQuery) GetUpdatePeriod

func (m *MsgRegisterInterchainQuery) GetUpdatePeriod() uint64

func (*MsgRegisterInterchainQuery) Marshal

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

func (*MsgRegisterInterchainQuery) MarshalTo

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

func (*MsgRegisterInterchainQuery) MarshalToSizedBuffer

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

func (*MsgRegisterInterchainQuery) ProtoMessage

func (*MsgRegisterInterchainQuery) ProtoMessage()

func (*MsgRegisterInterchainQuery) Reset

func (m *MsgRegisterInterchainQuery) Reset()

func (MsgRegisterInterchainQuery) Route

func (msg MsgRegisterInterchainQuery) Route() string

func (*MsgRegisterInterchainQuery) Size

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

func (*MsgRegisterInterchainQuery) String

func (m *MsgRegisterInterchainQuery) String() string

func (MsgRegisterInterchainQuery) Type

func (*MsgRegisterInterchainQuery) Unmarshal

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

func (MsgRegisterInterchainQuery) Validate

func (msg MsgRegisterInterchainQuery) Validate(params Params) error

func (*MsgRegisterInterchainQuery) XXX_DiscardUnknown

func (m *MsgRegisterInterchainQuery) XXX_DiscardUnknown()

func (*MsgRegisterInterchainQuery) XXX_Marshal

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

func (*MsgRegisterInterchainQuery) XXX_Merge

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

func (*MsgRegisterInterchainQuery) XXX_Size

func (m *MsgRegisterInterchainQuery) XXX_Size() int

func (*MsgRegisterInterchainQuery) XXX_Unmarshal

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

type MsgRegisterInterchainQueryResponse

type MsgRegisterInterchainQueryResponse struct {
	// The ID assigned to the registered Interchain Query by the module.
	Id uint64 `protobuf:"varint,1,opt,name=id,proto3" json:"id,omitempty"`
}

Response type for the Msg/RegisterInterchainQuery RPC method.

func (*MsgRegisterInterchainQueryResponse) Descriptor

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

func (*MsgRegisterInterchainQueryResponse) GetId

func (*MsgRegisterInterchainQueryResponse) Marshal

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

func (*MsgRegisterInterchainQueryResponse) MarshalTo

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

func (*MsgRegisterInterchainQueryResponse) MarshalToSizedBuffer

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

func (*MsgRegisterInterchainQueryResponse) ProtoMessage

func (*MsgRegisterInterchainQueryResponse) ProtoMessage()

func (*MsgRegisterInterchainQueryResponse) Reset

func (*MsgRegisterInterchainQueryResponse) Size

func (*MsgRegisterInterchainQueryResponse) String

func (*MsgRegisterInterchainQueryResponse) Unmarshal

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

func (*MsgRegisterInterchainQueryResponse) XXX_DiscardUnknown

func (m *MsgRegisterInterchainQueryResponse) XXX_DiscardUnknown()

func (*MsgRegisterInterchainQueryResponse) XXX_Marshal

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

func (*MsgRegisterInterchainQueryResponse) XXX_Merge

func (*MsgRegisterInterchainQueryResponse) XXX_Size

func (*MsgRegisterInterchainQueryResponse) XXX_Unmarshal

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

type MsgRemoveInterchainQueryRequest

type MsgRemoveInterchainQueryRequest struct {
	// The ID of the query to remove.
	QueryId uint64 `protobuf:"varint,1,opt,name=query_id,json=queryId,proto3" json:"query_id,omitempty"`
	// The signer of the message.
	Sender string `protobuf:"bytes,2,opt,name=sender,proto3" json:"sender,omitempty"`
}

Request type for the Msg/RemoveInterchainQuery RPC method.

func NewMsgRemoveInterchainQuery

func NewMsgRemoveInterchainQuery(sender string, queryID uint64) MsgRemoveInterchainQueryRequest

func (*MsgRemoveInterchainQueryRequest) Descriptor

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

func (*MsgRemoveInterchainQueryRequest) GetQueryId

func (m *MsgRemoveInterchainQueryRequest) GetQueryId() uint64

func (*MsgRemoveInterchainQueryRequest) GetSender

func (m *MsgRemoveInterchainQueryRequest) GetSender() string

func (MsgRemoveInterchainQueryRequest) GetSignBytes

func (msg MsgRemoveInterchainQueryRequest) GetSignBytes() []byte

func (MsgRemoveInterchainQueryRequest) GetSigners

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

func (*MsgRemoveInterchainQueryRequest) Marshal

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

func (*MsgRemoveInterchainQueryRequest) MarshalTo

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

func (*MsgRemoveInterchainQueryRequest) MarshalToSizedBuffer

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

func (*MsgRemoveInterchainQueryRequest) ProtoMessage

func (*MsgRemoveInterchainQueryRequest) ProtoMessage()

func (*MsgRemoveInterchainQueryRequest) Reset

func (MsgRemoveInterchainQueryRequest) Route

func (*MsgRemoveInterchainQueryRequest) Size

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

func (*MsgRemoveInterchainQueryRequest) String

func (MsgRemoveInterchainQueryRequest) Type

func (*MsgRemoveInterchainQueryRequest) Unmarshal

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

func (MsgRemoveInterchainQueryRequest) Validate

func (msg MsgRemoveInterchainQueryRequest) Validate() error

func (*MsgRemoveInterchainQueryRequest) XXX_DiscardUnknown

func (m *MsgRemoveInterchainQueryRequest) XXX_DiscardUnknown()

func (*MsgRemoveInterchainQueryRequest) XXX_Marshal

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

func (*MsgRemoveInterchainQueryRequest) XXX_Merge

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

func (*MsgRemoveInterchainQueryRequest) XXX_Size

func (m *MsgRemoveInterchainQueryRequest) XXX_Size() int

func (*MsgRemoveInterchainQueryRequest) XXX_Unmarshal

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

type MsgRemoveInterchainQueryResponse

type MsgRemoveInterchainQueryResponse struct {
}

Response type for the Msg/RemoveInterchainQuery RPC method.

func (*MsgRemoveInterchainQueryResponse) Descriptor

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

func (*MsgRemoveInterchainQueryResponse) Marshal

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

func (*MsgRemoveInterchainQueryResponse) MarshalTo

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

func (*MsgRemoveInterchainQueryResponse) MarshalToSizedBuffer

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

func (*MsgRemoveInterchainQueryResponse) ProtoMessage

func (*MsgRemoveInterchainQueryResponse) ProtoMessage()

func (*MsgRemoveInterchainQueryResponse) Reset

func (*MsgRemoveInterchainQueryResponse) Size

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

func (*MsgRemoveInterchainQueryResponse) String

func (*MsgRemoveInterchainQueryResponse) Unmarshal

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

func (*MsgRemoveInterchainQueryResponse) XXX_DiscardUnknown

func (m *MsgRemoveInterchainQueryResponse) XXX_DiscardUnknown()

func (*MsgRemoveInterchainQueryResponse) XXX_Marshal

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

func (*MsgRemoveInterchainQueryResponse) XXX_Merge

func (*MsgRemoveInterchainQueryResponse) XXX_Size

func (m *MsgRemoveInterchainQueryResponse) XXX_Size() int

func (*MsgRemoveInterchainQueryResponse) XXX_Unmarshal

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

type MsgServer

type MsgServer interface {
	// Registers a new Interchain Query in the `interchainqueries` module. This message should only
	// be issued by a smart contract. The calling contract is automatically charged a query
	// registration deposit, based on the module's query deposit parameter. The deposit is refunded
	// when the query is removed. Ensure the contract's account has sufficient assets at the time of
	// message execution.
	//
	// The response includes the ID assigned to the registered query. Use a reply handler to process
	// this response and utilize the query ID.
	RegisterInterchainQuery(context.Context, *MsgRegisterInterchainQuery) (*MsgRegisterInterchainQueryResponse, error)
	// Submits the result of an Interchain Query execution to the chain. Handling this message may
	// involve forwarding the result to the smart contract that owns the query for processing, which
	// could require significant gas usage.
	SubmitQueryResult(context.Context, *MsgSubmitQueryResult) (*MsgSubmitQueryResultResponse, error)
	// Removes a specific Interchain Query and its results from the module. The query can only be
	// removed by its owner during the query's submit timeout. After the timeout, anyone can remove
	// it. Upon successful removal, the query deposit is refunded to the caller.
	RemoveInterchainQuery(context.Context, *MsgRemoveInterchainQueryRequest) (*MsgRemoveInterchainQueryResponse, error)
	// Updates the parameters of a registered Interchain Query. This action can only be performed by
	// the query's owner.
	UpdateInterchainQuery(context.Context, *MsgUpdateInterchainQueryRequest) (*MsgUpdateInterchainQueryResponse, error)
	// Updates the parameters of the `interchainqueries` module. This action can only be performed
	// by the module's authority.
	UpdateParams(context.Context, *MsgUpdateParams) (*MsgUpdateParamsResponse, error)
}

MsgServer is the server API for Msg service.

type MsgSubmitQueryResult

type MsgSubmitQueryResult struct {
	// The ID of the Interchain Query.
	QueryId uint64 `protobuf:"varint,1,opt,name=query_id,json=queryId,proto3" json:"query_id,omitempty"`
	// The signer of the message.
	Sender string `protobuf:"bytes,2,opt,name=sender,proto3" json:"sender,omitempty"`
	// The IBC client ID that corresponds to the IBC connection to the remote chain (where the
	// query result is coming from).
	// Deprecated: populating this field does not make any affect
	ClientId string `protobuf:"bytes,3,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"` // Deprecated: Do not use.
	// The result of the Interchain Query execution.
	Result *QueryResult `protobuf:"bytes,4,opt,name=result,proto3" json:"result,omitempty"`
}

Request type for the Msg/SubmitQueryResult RPC method.

func (*MsgSubmitQueryResult) Descriptor

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

func (*MsgSubmitQueryResult) GetClientId deprecated

func (m *MsgSubmitQueryResult) GetClientId() string

Deprecated: Do not use.

func (*MsgSubmitQueryResult) GetQueryId

func (m *MsgSubmitQueryResult) GetQueryId() uint64

func (*MsgSubmitQueryResult) GetResult

func (m *MsgSubmitQueryResult) GetResult() *QueryResult

func (*MsgSubmitQueryResult) GetSender

func (m *MsgSubmitQueryResult) GetSender() string

func (MsgSubmitQueryResult) GetSignBytes

func (msg MsgSubmitQueryResult) GetSignBytes() []byte

func (MsgSubmitQueryResult) GetSigners

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

func (*MsgSubmitQueryResult) Marshal

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

func (*MsgSubmitQueryResult) MarshalTo

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

func (*MsgSubmitQueryResult) MarshalToSizedBuffer

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

func (*MsgSubmitQueryResult) ProtoMessage

func (*MsgSubmitQueryResult) ProtoMessage()

func (*MsgSubmitQueryResult) Reset

func (m *MsgSubmitQueryResult) Reset()

func (MsgSubmitQueryResult) Route

func (msg MsgSubmitQueryResult) Route() string

func (*MsgSubmitQueryResult) Size

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

func (*MsgSubmitQueryResult) String

func (m *MsgSubmitQueryResult) String() string

func (MsgSubmitQueryResult) Type

func (msg MsgSubmitQueryResult) Type() string

func (*MsgSubmitQueryResult) Unmarshal

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

func (MsgSubmitQueryResult) UnpackInterfaces

func (msg MsgSubmitQueryResult) UnpackInterfaces(unpacker codectypes.AnyUnpacker) error

UnpackInterfaces implements UnpackInterfacesMessage.UnpackInterfaces

func (MsgSubmitQueryResult) Validate

func (msg MsgSubmitQueryResult) Validate() error

func (*MsgSubmitQueryResult) XXX_DiscardUnknown

func (m *MsgSubmitQueryResult) XXX_DiscardUnknown()

func (*MsgSubmitQueryResult) XXX_Marshal

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

func (*MsgSubmitQueryResult) XXX_Merge

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

func (*MsgSubmitQueryResult) XXX_Size

func (m *MsgSubmitQueryResult) XXX_Size() int

func (*MsgSubmitQueryResult) XXX_Unmarshal

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

type MsgSubmitQueryResultResponse

type MsgSubmitQueryResultResponse struct {
}

Response type for the Msg/SubmitQueryResult RPC method.

func (*MsgSubmitQueryResultResponse) Descriptor

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

func (*MsgSubmitQueryResultResponse) Marshal

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

func (*MsgSubmitQueryResultResponse) MarshalTo

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

func (*MsgSubmitQueryResultResponse) MarshalToSizedBuffer

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

func (*MsgSubmitQueryResultResponse) ProtoMessage

func (*MsgSubmitQueryResultResponse) ProtoMessage()

func (*MsgSubmitQueryResultResponse) Reset

func (m *MsgSubmitQueryResultResponse) Reset()

func (*MsgSubmitQueryResultResponse) Size

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

func (*MsgSubmitQueryResultResponse) String

func (*MsgSubmitQueryResultResponse) Unmarshal

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

func (*MsgSubmitQueryResultResponse) XXX_DiscardUnknown

func (m *MsgSubmitQueryResultResponse) XXX_DiscardUnknown()

func (*MsgSubmitQueryResultResponse) XXX_Marshal

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

func (*MsgSubmitQueryResultResponse) XXX_Merge

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

func (*MsgSubmitQueryResultResponse) XXX_Size

func (m *MsgSubmitQueryResultResponse) XXX_Size() int

func (*MsgSubmitQueryResultResponse) XXX_Unmarshal

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

type MsgUpdateInterchainQueryRequest

type MsgUpdateInterchainQueryRequest struct {
	// The ID of the query to update.
	QueryId uint64 `protobuf:"varint,1,opt,name=query_id,json=queryId,proto3" json:"query_id,omitempty"`
	// A new list of KV-storage keys for which to get values from the remote chain. Only applicable
	// for a KV Interchain Query. Max amount of keys is limited by the module's `max_kv_query_keys_count`
	// parameters.
	NewKeys []*KVKey `protobuf:"bytes,2,rep,name=new_keys,json=newKeys,proto3" json:"new_keys,omitempty"`
	// A new minimal delay between consecutive query executions.
	NewUpdatePeriod uint64 `protobuf:"varint,3,opt,name=new_update_period,json=newUpdatePeriod,proto3" json:"new_update_period,omitempty"`
	// A new list of filters for remote transactions search. Only applicable for a TX Interchain
	// Query. Example: "[{\"field\":\"tx.height\",\"op\":\"Gte\",\"value\":2644737}]".
	// Supported operators: "eq", "lt", "gt", "lte", "gte". Max amount of filter conditions is
	// limited by the module's `max_transactions_filters` parameters.
	NewTransactionsFilter string `` /* 126-byte string literal not displayed */
	// The signer of the message.
	Sender string `protobuf:"bytes,5,opt,name=sender,proto3" json:"sender,omitempty"`
}

Request type for the Msg/UpdateInterchainQuery RPC method.

func (*MsgUpdateInterchainQueryRequest) Descriptor

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

func (*MsgUpdateInterchainQueryRequest) GetNewKeys

func (m *MsgUpdateInterchainQueryRequest) GetNewKeys() []*KVKey

func (*MsgUpdateInterchainQueryRequest) GetNewTransactionsFilter

func (m *MsgUpdateInterchainQueryRequest) GetNewTransactionsFilter() string

func (*MsgUpdateInterchainQueryRequest) GetNewUpdatePeriod

func (m *MsgUpdateInterchainQueryRequest) GetNewUpdatePeriod() uint64

func (*MsgUpdateInterchainQueryRequest) GetQueryId

func (m *MsgUpdateInterchainQueryRequest) GetQueryId() uint64

func (*MsgUpdateInterchainQueryRequest) GetSender

func (m *MsgUpdateInterchainQueryRequest) GetSender() string

func (MsgUpdateInterchainQueryRequest) GetSignBytes

func (msg MsgUpdateInterchainQueryRequest) GetSignBytes() []byte

func (MsgUpdateInterchainQueryRequest) GetSigners

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

func (*MsgUpdateInterchainQueryRequest) Marshal

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

func (*MsgUpdateInterchainQueryRequest) MarshalTo

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

func (*MsgUpdateInterchainQueryRequest) MarshalToSizedBuffer

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

func (*MsgUpdateInterchainQueryRequest) ProtoMessage

func (*MsgUpdateInterchainQueryRequest) ProtoMessage()

func (*MsgUpdateInterchainQueryRequest) Reset

func (*MsgUpdateInterchainQueryRequest) Size

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

func (*MsgUpdateInterchainQueryRequest) String

func (*MsgUpdateInterchainQueryRequest) Unmarshal

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

func (MsgUpdateInterchainQueryRequest) Validate

func (msg MsgUpdateInterchainQueryRequest) Validate(params Params) error

func (*MsgUpdateInterchainQueryRequest) XXX_DiscardUnknown

func (m *MsgUpdateInterchainQueryRequest) XXX_DiscardUnknown()

func (*MsgUpdateInterchainQueryRequest) XXX_Marshal

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

func (*MsgUpdateInterchainQueryRequest) XXX_Merge

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

func (*MsgUpdateInterchainQueryRequest) XXX_Size

func (m *MsgUpdateInterchainQueryRequest) XXX_Size() int

func (*MsgUpdateInterchainQueryRequest) XXX_Unmarshal

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

type MsgUpdateInterchainQueryResponse

type MsgUpdateInterchainQueryResponse struct {
}

Response type for the Msg/UpdateInterchainQuery RPC method.

func (*MsgUpdateInterchainQueryResponse) Descriptor

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

func (*MsgUpdateInterchainQueryResponse) Marshal

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

func (*MsgUpdateInterchainQueryResponse) MarshalTo

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

func (*MsgUpdateInterchainQueryResponse) MarshalToSizedBuffer

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

func (*MsgUpdateInterchainQueryResponse) ProtoMessage

func (*MsgUpdateInterchainQueryResponse) ProtoMessage()

func (*MsgUpdateInterchainQueryResponse) Reset

func (*MsgUpdateInterchainQueryResponse) Size

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

func (*MsgUpdateInterchainQueryResponse) String

func (*MsgUpdateInterchainQueryResponse) Unmarshal

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

func (*MsgUpdateInterchainQueryResponse) XXX_DiscardUnknown

func (m *MsgUpdateInterchainQueryResponse) XXX_DiscardUnknown()

func (*MsgUpdateInterchainQueryResponse) XXX_Marshal

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

func (*MsgUpdateInterchainQueryResponse) XXX_Merge

func (*MsgUpdateInterchainQueryResponse) XXX_Size

func (m *MsgUpdateInterchainQueryResponse) XXX_Size() int

func (*MsgUpdateInterchainQueryResponse) XXX_Unmarshal

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

type MsgUpdateParams

type MsgUpdateParams struct {
	// The address of the authority of the module.
	Authority string `protobuf:"bytes,1,opt,name=authority,proto3" json:"authority,omitempty"`
	// The new parameters of the module. All parameters must be supplied.
	Params Params `protobuf:"bytes,2,opt,name=params,proto3" json:"params"`
}

Request type for the Msg/UpdateParams RPC method.

func (*MsgUpdateParams) Descriptor

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

func (*MsgUpdateParams) GetAuthority

func (m *MsgUpdateParams) GetAuthority() string

func (*MsgUpdateParams) GetParams

func (m *MsgUpdateParams) GetParams() Params

func (*MsgUpdateParams) GetSignBytes

func (msg *MsgUpdateParams) GetSignBytes() []byte

func (*MsgUpdateParams) GetSigners

func (msg *MsgUpdateParams) GetSigners() []sdk.AccAddress

func (*MsgUpdateParams) Marshal

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

func (*MsgUpdateParams) MarshalTo

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

func (*MsgUpdateParams) MarshalToSizedBuffer

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

func (*MsgUpdateParams) ProtoMessage

func (*MsgUpdateParams) ProtoMessage()

func (*MsgUpdateParams) Reset

func (m *MsgUpdateParams) Reset()

func (*MsgUpdateParams) Route

func (msg *MsgUpdateParams) Route() string

func (*MsgUpdateParams) Size

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

func (*MsgUpdateParams) String

func (m *MsgUpdateParams) String() string

func (*MsgUpdateParams) Type

func (msg *MsgUpdateParams) Type() string

func (*MsgUpdateParams) Unmarshal

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

func (*MsgUpdateParams) Validate

func (msg *MsgUpdateParams) Validate() error

func (*MsgUpdateParams) XXX_DiscardUnknown

func (m *MsgUpdateParams) XXX_DiscardUnknown()

func (*MsgUpdateParams) XXX_Marshal

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

func (*MsgUpdateParams) XXX_Merge

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

func (*MsgUpdateParams) XXX_Size

func (m *MsgUpdateParams) XXX_Size() int

func (*MsgUpdateParams) XXX_Unmarshal

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

type MsgUpdateParamsResponse

type MsgUpdateParamsResponse struct {
}

Response type for the Msg/UpdateParams RPC method.

func (*MsgUpdateParamsResponse) Descriptor

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

func (*MsgUpdateParamsResponse) Marshal

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

func (*MsgUpdateParamsResponse) MarshalTo

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

func (*MsgUpdateParamsResponse) MarshalToSizedBuffer

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

func (*MsgUpdateParamsResponse) ProtoMessage

func (*MsgUpdateParamsResponse) ProtoMessage()

func (*MsgUpdateParamsResponse) Reset

func (m *MsgUpdateParamsResponse) Reset()

func (*MsgUpdateParamsResponse) Size

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

func (*MsgUpdateParamsResponse) String

func (m *MsgUpdateParamsResponse) String() string

func (*MsgUpdateParamsResponse) Unmarshal

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

func (*MsgUpdateParamsResponse) XXX_DiscardUnknown

func (m *MsgUpdateParamsResponse) XXX_DiscardUnknown()

func (*MsgUpdateParamsResponse) XXX_Marshal

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

func (*MsgUpdateParamsResponse) XXX_Merge

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

func (*MsgUpdateParamsResponse) XXX_Size

func (m *MsgUpdateParamsResponse) XXX_Size() int

func (*MsgUpdateParamsResponse) XXX_Unmarshal

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

type Params

type Params struct {
	// The duration, measured in blocks, that must pass since the query's registration or its last
	// result submission before the query becomes eligible for removal by anyone. Is used to set
	// `submit_timeout` on Interchain Query registration.
	QuerySubmitTimeout uint64 `protobuf:"varint,1,opt,name=query_submit_timeout,json=querySubmitTimeout,proto3" json:"query_submit_timeout,omitempty"`
	// Amount of coins required to be provided as deposit on Interchain Query registration.
	QueryDeposit github_com_cosmos_cosmos_sdk_types.Coins `` /* 141-byte string literal not displayed */
	// Amount of tx hashes to be removed during a single EndBlock. Can vary to balance between
	// network cleaning speed and EndBlock duration. A zero value means no limit.
	TxQueryRemovalLimit uint64 `protobuf:"varint,3,opt,name=tx_query_removal_limit,json=txQueryRemovalLimit,proto3" json:"tx_query_removal_limit,omitempty"`
	// Maximum amount of keys in a registered key value query
	MaxKvQueryKeysCount uint64 `protobuf:"varint,4,opt,name=max_kv_query_keys_count,json=maxKvQueryKeysCount,proto3" json:"max_kv_query_keys_count,omitempty"`
	// max_transactions_filters defines maximum allowed amount of tx filters in msgRegisterInterchainQuery
	MaxTransactionsFilters uint64 `` /* 130-byte string literal not displayed */
}

The parameters for the module.

func DefaultParams

func DefaultParams() Params

DefaultParams returns a default set of parameters

func NewParams

func NewParams(querySubmitTimeout uint64, queryDeposit sdk.Coins, txQueryRemovalLimit, maxKvQueryKeysCount, maxTransactionsFilters uint64) Params

NewParams creates a new Params instance

func (*Params) Descriptor

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

func (*Params) GetMaxKvQueryKeysCount

func (m *Params) GetMaxKvQueryKeysCount() uint64

func (*Params) GetMaxTransactionsFilters

func (m *Params) GetMaxTransactionsFilters() uint64

func (*Params) GetQueryDeposit

func (m *Params) GetQueryDeposit() github_com_cosmos_cosmos_sdk_types.Coins

func (*Params) GetQuerySubmitTimeout

func (m *Params) GetQuerySubmitTimeout() uint64

func (*Params) GetTxQueryRemovalLimit

func (m *Params) GetTxQueryRemovalLimit() 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 get the params.ParamSet

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 implements the Stringer interface.

func (*Params) Unmarshal

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

func (Params) Validate

func (p Params) Validate() error

Validate validates the set of params

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 QueryClient

type QueryClient interface {
	// Fetches the current parameters of the interchainqueries module.
	Params(ctx context.Context, in *QueryParamsRequest, opts ...grpc.CallOption) (*QueryParamsResponse, error)
	// Retrieves all registered Interchain Queries in the module, with optional filtering by owner
	// and/or connection ID.
	RegisteredQueries(ctx context.Context, in *QueryRegisteredQueriesRequest, opts ...grpc.CallOption) (*QueryRegisteredQueriesResponse, error)
	// Fetches details of a registered Interchain Query using its ID.
	RegisteredQuery(ctx context.Context, in *QueryRegisteredQueryRequest, opts ...grpc.CallOption) (*QueryRegisteredQueryResponse, error)
	// Retrieves the most recent successfully submitted result of an Interchain Query. This is only
	// applicable for KV Interchain Queries.
	QueryResult(ctx context.Context, in *QueryRegisteredQueryResultRequest, opts ...grpc.CallOption) (*QueryRegisteredQueryResultResponse, error)
	// Retrieves the most recent height of a remote chain as known by the IBC client associated with
	// a given connection ID.
	LastRemoteHeight(ctx context.Context, in *QueryLastRemoteHeight, opts ...grpc.CallOption) (*QueryLastRemoteHeightResponse, 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 QueryLastRemoteHeight

type QueryLastRemoteHeight struct {
	// Connection ID of an IBC connection to a remote chain. Determines the IBC client used in query
	// handling.
	ConnectionId string `protobuf:"bytes,1,opt,name=connection_id,json=connectionId,proto3" json:"connection_id,omitempty"`
}

Request type for the Query/LastRemoteHeight RPC method.

func (*QueryLastRemoteHeight) Descriptor

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

func (*QueryLastRemoteHeight) GetConnectionId

func (m *QueryLastRemoteHeight) GetConnectionId() string

func (*QueryLastRemoteHeight) Marshal

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

func (*QueryLastRemoteHeight) MarshalTo

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

func (*QueryLastRemoteHeight) MarshalToSizedBuffer

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

func (*QueryLastRemoteHeight) ProtoMessage

func (*QueryLastRemoteHeight) ProtoMessage()

func (*QueryLastRemoteHeight) Reset

func (m *QueryLastRemoteHeight) Reset()

func (*QueryLastRemoteHeight) Size

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

func (*QueryLastRemoteHeight) String

func (m *QueryLastRemoteHeight) String() string

func (*QueryLastRemoteHeight) Unmarshal

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

func (*QueryLastRemoteHeight) XXX_DiscardUnknown

func (m *QueryLastRemoteHeight) XXX_DiscardUnknown()

func (*QueryLastRemoteHeight) XXX_Marshal

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

func (*QueryLastRemoteHeight) XXX_Merge

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

func (*QueryLastRemoteHeight) XXX_Size

func (m *QueryLastRemoteHeight) XXX_Size() int

func (*QueryLastRemoteHeight) XXX_Unmarshal

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

type QueryLastRemoteHeightResponse

type QueryLastRemoteHeightResponse struct {
	// The height of the chain that the IBC client is currently on.
	Height uint64 `protobuf:"varint,1,opt,name=height,proto3" json:"height,omitempty"`
	// The revision of the chain that the IBC client is currently on.
	Revision uint64 `protobuf:"varint,2,opt,name=revision,proto3" json:"revision,omitempty"`
}

Response type for the Query/LastRemoteHeight RPC method.

func (*QueryLastRemoteHeightResponse) Descriptor

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

func (*QueryLastRemoteHeightResponse) GetHeight

func (m *QueryLastRemoteHeightResponse) GetHeight() uint64

func (*QueryLastRemoteHeightResponse) GetRevision added in v5.1.0

func (m *QueryLastRemoteHeightResponse) GetRevision() uint64

func (*QueryLastRemoteHeightResponse) Marshal

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

func (*QueryLastRemoteHeightResponse) MarshalTo

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

func (*QueryLastRemoteHeightResponse) MarshalToSizedBuffer

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

func (*QueryLastRemoteHeightResponse) ProtoMessage

func (*QueryLastRemoteHeightResponse) ProtoMessage()

func (*QueryLastRemoteHeightResponse) Reset

func (m *QueryLastRemoteHeightResponse) Reset()

func (*QueryLastRemoteHeightResponse) Size

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

func (*QueryLastRemoteHeightResponse) String

func (*QueryLastRemoteHeightResponse) Unmarshal

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

func (*QueryLastRemoteHeightResponse) XXX_DiscardUnknown

func (m *QueryLastRemoteHeightResponse) XXX_DiscardUnknown()

func (*QueryLastRemoteHeightResponse) XXX_Marshal

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

func (*QueryLastRemoteHeightResponse) XXX_Merge

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

func (*QueryLastRemoteHeightResponse) XXX_Size

func (m *QueryLastRemoteHeightResponse) XXX_Size() int

func (*QueryLastRemoteHeightResponse) XXX_Unmarshal

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

type QueryParamsRequest

type QueryParamsRequest struct {
}

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 {
	// Contains all parameters of the module.
	Params Params `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
}

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 QueryRegisteredQueriesRequest

type QueryRegisteredQueriesRequest struct {
	// A list of owners of Interchain Queries. Query response will contain only Interchain Queries
	// that are owned by one of the owners in the list. If none, Interchain Queries are not filtered
	// out by the owner field.
	Owners []string `protobuf:"bytes,1,rep,name=owners,proto3" json:"owners,omitempty"`
	// IBC connection ID. Query response will contain only Interchain Queries that have the same IBC
	// connection ID parameter. If none, Interchain Queries are not filtered out by the connection ID
	// field.
	ConnectionId string `protobuf:"bytes,2,opt,name=connection_id,json=connectionId,proto3" json:"connection_id,omitempty"`
	// Pagination parameters for the request. Use values from previous response in the next request
	// in consecutive requests with paginated responses.
	Pagination *query.PageRequest `protobuf:"bytes,3,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

Request type for the Query/RegisteredQueries RPC method.

func (*QueryRegisteredQueriesRequest) Descriptor

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

func (*QueryRegisteredQueriesRequest) GetConnectionId

func (m *QueryRegisteredQueriesRequest) GetConnectionId() string

func (*QueryRegisteredQueriesRequest) GetOwners

func (m *QueryRegisteredQueriesRequest) GetOwners() []string

func (*QueryRegisteredQueriesRequest) GetPagination

func (m *QueryRegisteredQueriesRequest) GetPagination() *query.PageRequest

func (*QueryRegisteredQueriesRequest) Marshal

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

func (*QueryRegisteredQueriesRequest) MarshalTo

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

func (*QueryRegisteredQueriesRequest) MarshalToSizedBuffer

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

func (*QueryRegisteredQueriesRequest) ProtoMessage

func (*QueryRegisteredQueriesRequest) ProtoMessage()

func (*QueryRegisteredQueriesRequest) Reset

func (m *QueryRegisteredQueriesRequest) Reset()

func (*QueryRegisteredQueriesRequest) Size

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

func (*QueryRegisteredQueriesRequest) String

func (*QueryRegisteredQueriesRequest) Unmarshal

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

func (*QueryRegisteredQueriesRequest) XXX_DiscardUnknown

func (m *QueryRegisteredQueriesRequest) XXX_DiscardUnknown()

func (*QueryRegisteredQueriesRequest) XXX_Marshal

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

func (*QueryRegisteredQueriesRequest) XXX_Merge

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

func (*QueryRegisteredQueriesRequest) XXX_Size

func (m *QueryRegisteredQueriesRequest) XXX_Size() int

func (*QueryRegisteredQueriesRequest) XXX_Unmarshal

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

type QueryRegisteredQueriesResponse

type QueryRegisteredQueriesResponse struct {
	// A list of registered Interchain Queries.
	RegisteredQueries []RegisteredQuery `protobuf:"bytes,1,rep,name=registered_queries,json=registeredQueries,proto3" json:"registered_queries"`
	// Current page information. Use values from previous response in the next request in consecutive
	// requests with paginated responses.
	Pagination *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

Response type for the Query/RegisteredQueries RPC method.

func (*QueryRegisteredQueriesResponse) Descriptor

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

func (*QueryRegisteredQueriesResponse) GetPagination

func (*QueryRegisteredQueriesResponse) GetRegisteredQueries

func (m *QueryRegisteredQueriesResponse) GetRegisteredQueries() []RegisteredQuery

func (*QueryRegisteredQueriesResponse) Marshal

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

func (*QueryRegisteredQueriesResponse) MarshalTo

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

func (*QueryRegisteredQueriesResponse) MarshalToSizedBuffer

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

func (*QueryRegisteredQueriesResponse) ProtoMessage

func (*QueryRegisteredQueriesResponse) ProtoMessage()

func (*QueryRegisteredQueriesResponse) Reset

func (m *QueryRegisteredQueriesResponse) Reset()

func (*QueryRegisteredQueriesResponse) Size

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

func (*QueryRegisteredQueriesResponse) String

func (*QueryRegisteredQueriesResponse) Unmarshal

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

func (*QueryRegisteredQueriesResponse) XXX_DiscardUnknown

func (m *QueryRegisteredQueriesResponse) XXX_DiscardUnknown()

func (*QueryRegisteredQueriesResponse) XXX_Marshal

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

func (*QueryRegisteredQueriesResponse) XXX_Merge

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

func (*QueryRegisteredQueriesResponse) XXX_Size

func (m *QueryRegisteredQueriesResponse) XXX_Size() int

func (*QueryRegisteredQueriesResponse) XXX_Unmarshal

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

type QueryRegisteredQueryRequest

type QueryRegisteredQueryRequest struct {
	// ID of an Interchain Query.
	QueryId uint64 `protobuf:"varint,1,opt,name=query_id,json=queryId,proto3" json:"query_id,omitempty"`
}

Request type for the Query/RegisteredQuery RPC method.

func (*QueryRegisteredQueryRequest) Descriptor

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

func (*QueryRegisteredQueryRequest) GetQueryId

func (m *QueryRegisteredQueryRequest) GetQueryId() uint64

func (*QueryRegisteredQueryRequest) Marshal

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

func (*QueryRegisteredQueryRequest) MarshalTo

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

func (*QueryRegisteredQueryRequest) MarshalToSizedBuffer

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

func (*QueryRegisteredQueryRequest) ProtoMessage

func (*QueryRegisteredQueryRequest) ProtoMessage()

func (*QueryRegisteredQueryRequest) Reset

func (m *QueryRegisteredQueryRequest) Reset()

func (*QueryRegisteredQueryRequest) Size

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

func (*QueryRegisteredQueryRequest) String

func (m *QueryRegisteredQueryRequest) String() string

func (*QueryRegisteredQueryRequest) Unmarshal

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

func (*QueryRegisteredQueryRequest) XXX_DiscardUnknown

func (m *QueryRegisteredQueryRequest) XXX_DiscardUnknown()

func (*QueryRegisteredQueryRequest) XXX_Marshal

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

func (*QueryRegisteredQueryRequest) XXX_Merge

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

func (*QueryRegisteredQueryRequest) XXX_Size

func (m *QueryRegisteredQueryRequest) XXX_Size() int

func (*QueryRegisteredQueryRequest) XXX_Unmarshal

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

type QueryRegisteredQueryResponse

type QueryRegisteredQueryResponse struct {
	// A registered Interchain Query.
	RegisteredQuery *RegisteredQuery `protobuf:"bytes,1,opt,name=registered_query,json=registeredQuery,proto3" json:"registered_query,omitempty"`
}

Response type for the Query/RegisteredQuery RPC method.

func (*QueryRegisteredQueryResponse) Descriptor

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

func (*QueryRegisteredQueryResponse) GetRegisteredQuery

func (m *QueryRegisteredQueryResponse) GetRegisteredQuery() *RegisteredQuery

func (*QueryRegisteredQueryResponse) Marshal

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

func (*QueryRegisteredQueryResponse) MarshalTo

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

func (*QueryRegisteredQueryResponse) MarshalToSizedBuffer

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

func (*QueryRegisteredQueryResponse) ProtoMessage

func (*QueryRegisteredQueryResponse) ProtoMessage()

func (*QueryRegisteredQueryResponse) Reset

func (m *QueryRegisteredQueryResponse) Reset()

func (*QueryRegisteredQueryResponse) Size

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

func (*QueryRegisteredQueryResponse) String

func (*QueryRegisteredQueryResponse) Unmarshal

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

func (*QueryRegisteredQueryResponse) XXX_DiscardUnknown

func (m *QueryRegisteredQueryResponse) XXX_DiscardUnknown()

func (*QueryRegisteredQueryResponse) XXX_Marshal

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

func (*QueryRegisteredQueryResponse) XXX_Merge

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

func (*QueryRegisteredQueryResponse) XXX_Size

func (m *QueryRegisteredQueryResponse) XXX_Size() int

func (*QueryRegisteredQueryResponse) XXX_Unmarshal

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

type QueryRegisteredQueryResultRequest

type QueryRegisteredQueryResultRequest struct {
	// ID of an Interchain Query.
	QueryId uint64 `protobuf:"varint,1,opt,name=query_id,json=queryId,proto3" json:"query_id,omitempty"`
}

Request type for the Query/QueryResult RPC method.

func (*QueryRegisteredQueryResultRequest) Descriptor

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

func (*QueryRegisteredQueryResultRequest) GetQueryId

func (m *QueryRegisteredQueryResultRequest) GetQueryId() uint64

func (*QueryRegisteredQueryResultRequest) Marshal

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

func (*QueryRegisteredQueryResultRequest) MarshalTo

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

func (*QueryRegisteredQueryResultRequest) MarshalToSizedBuffer

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

func (*QueryRegisteredQueryResultRequest) ProtoMessage

func (*QueryRegisteredQueryResultRequest) ProtoMessage()

func (*QueryRegisteredQueryResultRequest) Reset

func (*QueryRegisteredQueryResultRequest) Size

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

func (*QueryRegisteredQueryResultRequest) String

func (*QueryRegisteredQueryResultRequest) Unmarshal

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

func (*QueryRegisteredQueryResultRequest) XXX_DiscardUnknown

func (m *QueryRegisteredQueryResultRequest) XXX_DiscardUnknown()

func (*QueryRegisteredQueryResultRequest) XXX_Marshal

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

func (*QueryRegisteredQueryResultRequest) XXX_Merge

func (*QueryRegisteredQueryResultRequest) XXX_Size

func (m *QueryRegisteredQueryResultRequest) XXX_Size() int

func (*QueryRegisteredQueryResultRequest) XXX_Unmarshal

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

type QueryRegisteredQueryResultResponse

type QueryRegisteredQueryResultResponse struct {
	// The last successfully submitted result of an Interchain Query.
	Result *QueryResult `protobuf:"bytes,1,opt,name=result,proto3" json:"result,omitempty"`
}

Response type for the Query/QueryResult RPC method.

func (*QueryRegisteredQueryResultResponse) Descriptor

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

func (*QueryRegisteredQueryResultResponse) GetResult

func (*QueryRegisteredQueryResultResponse) Marshal

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

func (*QueryRegisteredQueryResultResponse) MarshalTo

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

func (*QueryRegisteredQueryResultResponse) MarshalToSizedBuffer

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

func (*QueryRegisteredQueryResultResponse) ProtoMessage

func (*QueryRegisteredQueryResultResponse) ProtoMessage()

func (*QueryRegisteredQueryResultResponse) Reset

func (*QueryRegisteredQueryResultResponse) Size

func (*QueryRegisteredQueryResultResponse) String

func (*QueryRegisteredQueryResultResponse) Unmarshal

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

func (*QueryRegisteredQueryResultResponse) XXX_DiscardUnknown

func (m *QueryRegisteredQueryResultResponse) XXX_DiscardUnknown()

func (*QueryRegisteredQueryResultResponse) XXX_Marshal

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

func (*QueryRegisteredQueryResultResponse) XXX_Merge

func (*QueryRegisteredQueryResultResponse) XXX_Size

func (*QueryRegisteredQueryResultResponse) XXX_Unmarshal

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

type QueryResult

type QueryResult struct {
	// A list of a KV Interchain Query execution results. Each result contains query parameters, a
	// response value and a proof.
	KvResults []*StorageValue `protobuf:"bytes,1,rep,name=kv_results,json=kvResults,proto3" json:"kv_results,omitempty"`
	// A TX Interchain Query execution result. Contains metainformation about the blocks of the query
	// execution height. Only populated when submitting an Interchain Query result for verification
	// and emptied when saving the result on chain.
	Block *Block `protobuf:"bytes,2,opt,name=block,proto3" json:"block,omitempty"`
	// The height of the chain at the moment of the Interchain Query execution.
	Height uint64 `protobuf:"varint,3,opt,name=height,proto3" json:"height,omitempty"`
	// The revision number of the chain at the moment of the Interchain Query execution.
	Revision uint64 `protobuf:"varint,4,opt,name=revision,proto3" json:"revision,omitempty"`
	// Whether to send the query result to the owner contract as a sudo message. Only applicable for
	// KV type of Interchain Queries.
	AllowKvCallbacks bool `protobuf:"varint,5,opt,name=allow_kv_callbacks,json=allowKvCallbacks,proto3" json:"allow_kv_callbacks,omitempty"`
}

Contains different information about a single Interchain Query execution result. Currently, this structure is used both in query result submission via an ICQ Relayer and as a query result storage for read/write operations to interchainqueries module, but the structure fields are populated in a bit different ways. When submitting a query result, all fields are populated and provided to the interchainqueries module in order to verify the result against the IBC client's state. But in order to lighten the chain state, the interchainqueries module removes the block field and proofs from the kv_results.

func (*QueryResult) Descriptor

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

func (*QueryResult) GetAllowKvCallbacks

func (m *QueryResult) GetAllowKvCallbacks() bool

func (*QueryResult) GetBlock

func (m *QueryResult) GetBlock() *Block

func (*QueryResult) GetHeight

func (m *QueryResult) GetHeight() uint64

func (*QueryResult) GetKvResults

func (m *QueryResult) GetKvResults() []*StorageValue

func (*QueryResult) GetRevision

func (m *QueryResult) GetRevision() uint64

func (*QueryResult) Marshal

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

func (*QueryResult) MarshalTo

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

func (*QueryResult) MarshalToSizedBuffer

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

func (*QueryResult) ProtoMessage

func (*QueryResult) ProtoMessage()

func (*QueryResult) Reset

func (m *QueryResult) Reset()

func (*QueryResult) Size

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

func (*QueryResult) String

func (m *QueryResult) String() string

func (*QueryResult) Unmarshal

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

func (*QueryResult) XXX_DiscardUnknown

func (m *QueryResult) XXX_DiscardUnknown()

func (*QueryResult) XXX_Marshal

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

func (*QueryResult) XXX_Merge

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

func (*QueryResult) XXX_Size

func (m *QueryResult) XXX_Size() int

func (*QueryResult) XXX_Unmarshal

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

type QueryServer

type QueryServer interface {
	// Fetches the current parameters of the interchainqueries module.
	Params(context.Context, *QueryParamsRequest) (*QueryParamsResponse, error)
	// Retrieves all registered Interchain Queries in the module, with optional filtering by owner
	// and/or connection ID.
	RegisteredQueries(context.Context, *QueryRegisteredQueriesRequest) (*QueryRegisteredQueriesResponse, error)
	// Fetches details of a registered Interchain Query using its ID.
	RegisteredQuery(context.Context, *QueryRegisteredQueryRequest) (*QueryRegisteredQueryResponse, error)
	// Retrieves the most recent successfully submitted result of an Interchain Query. This is only
	// applicable for KV Interchain Queries.
	QueryResult(context.Context, *QueryRegisteredQueryResultRequest) (*QueryRegisteredQueryResultResponse, error)
	// Retrieves the most recent height of a remote chain as known by the IBC client associated with
	// a given connection ID.
	LastRemoteHeight(context.Context, *QueryLastRemoteHeight) (*QueryLastRemoteHeightResponse, error)
}

QueryServer is the server API for Query service.

type RegisteredQuery

type RegisteredQuery struct {
	// The unique id of the registered query.
	Id uint64 `protobuf:"varint,1,opt,name=id,proto3" json:"id,omitempty"`
	// The address of the contract that registered the query.
	Owner string `protobuf:"bytes,2,opt,name=owner,proto3" json:"owner,omitempty"`
	// The query type identifier: `kv` or `tx`.
	QueryType string `protobuf:"bytes,3,opt,name=query_type,json=queryType,proto3" json:"query_type,omitempty"`
	// The KV-storage keys for which to get values from the remote chain. Only applicable for the
	// KV Interchain Queries. Max amount of keys is limited by the module's `max_kv_query_keys_count`
	// parameters.
	Keys []*KVKey `protobuf:"bytes,4,rep,name=keys,proto3" json:"keys,omitempty"`
	// A stringified list of filters for remote transactions search. Only applicable for the TX
	// Interchain Queries. Example: "[{\"field\":\"tx.height\",\"op\":\"Gte\",\"value\":2644737}]".
	// Supported operators: "eq", "lt", "gt", "lte", "gte". Max amount of filter conditions is limited
	// by the module's `max_transactions_filters` parameters.
	TransactionsFilter string `protobuf:"bytes,5,opt,name=transactions_filter,json=transactionsFilter,proto3" json:"transactions_filter,omitempty"`
	// The IBC connection ID to the remote chain (the source of querying data). Is used for getting
	// ConsensusState from the respective IBC client to verify query result proofs.
	ConnectionId string `protobuf:"bytes,6,opt,name=connection_id,json=connectionId,proto3" json:"connection_id,omitempty"`
	// Parameter that defines the minimal delay between consecutive query executions (i.e. the
	// minimal delay between query results update).
	UpdatePeriod uint64 `protobuf:"varint,7,opt,name=update_period,json=updatePeriod,proto3" json:"update_period,omitempty"`
	// The local chain block height of the last query results update.
	LastSubmittedResultLocalHeight uint64 `` /* 158-byte string literal not displayed */
	// The remote chain block height that corresponds to the last query result update.
	LastSubmittedResultRemoteHeight *types.Height `` /* 160-byte string literal not displayed */
	// Amount of coins paid for the Interchain Query registration. The deposit is paid back to the
	// remover. The remover can be either the query owner (during the submit timeout) or anybody.
	Deposit github_com_cosmos_cosmos_sdk_types.Coins `protobuf:"bytes,10,rep,name=deposit,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"deposit"`
	// The duration, measured in blocks, that must pass since the query's registration or its last
	// result submission before the query becomes eligible for removal by anyone.
	SubmitTimeout uint64 `protobuf:"varint,11,opt,name=submit_timeout,json=submitTimeout,proto3" json:"submit_timeout,omitempty"`
	// The local chain block height of the Interchain Query registration.
	RegisteredAtHeight uint64 `protobuf:"varint,12,opt,name=registered_at_height,json=registeredAtHeight,proto3" json:"registered_at_height,omitempty"`
}

Information about an Interchain Query registered in the interchainqueries module.

func (*RegisteredQuery) Descriptor

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

func (*RegisteredQuery) GetConnectionId

func (m *RegisteredQuery) GetConnectionId() string

func (*RegisteredQuery) GetDeposit

func (*RegisteredQuery) GetId

func (m *RegisteredQuery) GetId() uint64

func (*RegisteredQuery) GetKeys

func (m *RegisteredQuery) GetKeys() []*KVKey

func (*RegisteredQuery) GetLastSubmittedResultLocalHeight

func (m *RegisteredQuery) GetLastSubmittedResultLocalHeight() uint64

func (*RegisteredQuery) GetLastSubmittedResultRemoteHeight

func (m *RegisteredQuery) GetLastSubmittedResultRemoteHeight() *types.Height

func (*RegisteredQuery) GetOwner

func (m *RegisteredQuery) GetOwner() string

func (*RegisteredQuery) GetOwnerAddress

func (q *RegisteredQuery) GetOwnerAddress() (creator sdk.AccAddress, err error)

func (*RegisteredQuery) GetQueryType

func (m *RegisteredQuery) GetQueryType() string

func (*RegisteredQuery) GetRegisteredAtHeight

func (m *RegisteredQuery) GetRegisteredAtHeight() uint64

func (*RegisteredQuery) GetSubmitTimeout

func (m *RegisteredQuery) GetSubmitTimeout() uint64

func (*RegisteredQuery) GetTransactionsFilter

func (m *RegisteredQuery) GetTransactionsFilter() string

func (*RegisteredQuery) GetUpdatePeriod

func (m *RegisteredQuery) GetUpdatePeriod() uint64

func (*RegisteredQuery) Marshal

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

func (*RegisteredQuery) MarshalTo

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

func (*RegisteredQuery) MarshalToSizedBuffer

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

func (*RegisteredQuery) ProtoMessage

func (*RegisteredQuery) ProtoMessage()

func (*RegisteredQuery) Reset

func (m *RegisteredQuery) Reset()

func (*RegisteredQuery) Size

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

func (*RegisteredQuery) String

func (m *RegisteredQuery) String() string

func (*RegisteredQuery) Unmarshal

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

func (*RegisteredQuery) ValidateRemoval

func (q *RegisteredQuery) ValidateRemoval(ctx sdk.Context, caller string) error

ValidateRemoval checks whether the caller is authorized to remove the query in current circumstances. Valid cases are: 1. owner removes query at any time; 2. anyone removes query if there's been q.SubmitTimeout blocks since last result submission height and query registration height.

func (*RegisteredQuery) XXX_DiscardUnknown

func (m *RegisteredQuery) XXX_DiscardUnknown()

func (*RegisteredQuery) XXX_Marshal

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

func (*RegisteredQuery) XXX_Merge

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

func (*RegisteredQuery) XXX_Size

func (m *RegisteredQuery) XXX_Size() int

func (*RegisteredQuery) XXX_Unmarshal

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

type StorageValue

type StorageValue struct {
	// The substore name used in the read operation. Typically, this corresponds to the keeper's
	// storeKey, usually the module's name, such as "bank", "staking", etc.
	StoragePrefix string `protobuf:"bytes,1,opt,name=storage_prefix,json=storagePrefix,proto3" json:"storage_prefix,omitempty"`
	// A bytes field representing the key of the data read from the module's storage.
	Key []byte `protobuf:"bytes,2,opt,name=key,proto3" json:"key,omitempty"`
	// A bytes field containing the value associated with the key in the store.
	Value []byte `protobuf:"bytes,3,opt,name=value,proto3" json:"value,omitempty"`
	// The Merkle Proof which proves existence/nonexistence of key-value pair in IAVL storage. Is
	// used to verify
	// the pair against the respective remote chain's header.
	Proof *crypto.ProofOps `protobuf:"bytes,4,opt,name=Proof,proto3" json:"Proof,omitempty"`
}

A verifiable result of performing a single KVKey read.

func (*StorageValue) Descriptor

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

func (*StorageValue) GetKey

func (m *StorageValue) GetKey() []byte

func (*StorageValue) GetProof

func (m *StorageValue) GetProof() *crypto.ProofOps

func (*StorageValue) GetStoragePrefix

func (m *StorageValue) GetStoragePrefix() string

func (*StorageValue) GetValue

func (m *StorageValue) GetValue() []byte

func (*StorageValue) Marshal

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

func (*StorageValue) MarshalTo

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

func (*StorageValue) MarshalToSizedBuffer

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

func (*StorageValue) ProtoMessage

func (*StorageValue) ProtoMessage()

func (*StorageValue) Reset

func (m *StorageValue) Reset()

func (*StorageValue) Size

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

func (*StorageValue) String

func (m *StorageValue) String() string

func (*StorageValue) Unmarshal

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

func (*StorageValue) XXX_DiscardUnknown

func (m *StorageValue) XXX_DiscardUnknown()

func (*StorageValue) XXX_Marshal

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

func (*StorageValue) XXX_Merge

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

func (*StorageValue) XXX_Size

func (m *StorageValue) XXX_Size() int

func (*StorageValue) XXX_Unmarshal

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

type Transaction

type Transaction struct {
	Id     uint64 `protobuf:"varint,1,opt,name=id,proto3" json:"id,omitempty"`
	Height uint64 `protobuf:"varint,2,opt,name=height,proto3" json:"height,omitempty"`
	Data   []byte `protobuf:"bytes,3,opt,name=data,proto3" json:"data,omitempty"`
}

func (*Transaction) Descriptor

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

func (*Transaction) GetData

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

func (*Transaction) GetHeight

func (m *Transaction) GetHeight() uint64

func (*Transaction) GetId

func (m *Transaction) GetId() uint64

func (*Transaction) Marshal

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

func (*Transaction) MarshalTo

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

func (*Transaction) MarshalToSizedBuffer

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

func (*Transaction) ProtoMessage

func (*Transaction) ProtoMessage()

func (*Transaction) Reset

func (m *Transaction) Reset()

func (*Transaction) Size

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

func (*Transaction) String

func (m *Transaction) String() string

func (*Transaction) Unmarshal

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

func (*Transaction) XXX_DiscardUnknown

func (m *Transaction) XXX_DiscardUnknown()

func (*Transaction) XXX_Marshal

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

func (*Transaction) XXX_Merge

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

func (*Transaction) XXX_Size

func (m *Transaction) XXX_Size() int

func (*Transaction) XXX_Unmarshal

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

type TransactionVerifier

type TransactionVerifier interface {
	VerifyTransaction(
		header *tendermintLightClientTypes.Header,
		nextHeader *tendermintLightClientTypes.Header,
		tx *TxValue,
	) error
}

type TransactionsFilter

type TransactionsFilter []TransactionsFilterItem

TransactionsFilter represents the model of transactions filter parameter used in interchain queries of type TX.

type TransactionsFilterItem

type TransactionsFilterItem struct {
	// Field is the field used in condition, e.g. tx.height or transfer.recipient.
	Field string `json:"field"`
	// Op is the operation for filtering, one of the following: eq, gt, gte, lt, lte.
	Op string `json:"op"`
	// Value is the value for comparison.
	Value interface{} `json:"value"`
}

TransactionsFilterItem is a single condition for filtering transactions in search.

type TxValue

type TxValue struct {
	// The result of the transaction execution.
	Response *types1.ExecTxResult `protobuf:"bytes,1,opt,name=response,proto3" json:"response,omitempty"`
	// The Merkle Proof which proves existence of response in the block next to the block the
	// transaction is included in.
	DeliveryProof *crypto.Proof `protobuf:"bytes,2,opt,name=delivery_proof,json=deliveryProof,proto3" json:"delivery_proof,omitempty"`
	// The Merkle Proof which proves inclusion of the transaction in the block.
	InclusionProof *crypto.Proof `protobuf:"bytes,3,opt,name=inclusion_proof,json=inclusionProof,proto3" json:"inclusion_proof,omitempty"`
	// The arbitrary data typed body of the transaction.
	Data []byte `protobuf:"bytes,4,opt,name=data,proto3" json:"data,omitempty"`
}

Contains transaction body, response, and proofs of inclusion and delivery.

func (*TxValue) Descriptor

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

func (*TxValue) GetData

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

func (*TxValue) GetDeliveryProof

func (m *TxValue) GetDeliveryProof() *crypto.Proof

func (*TxValue) GetInclusionProof

func (m *TxValue) GetInclusionProof() *crypto.Proof

func (*TxValue) GetResponse

func (m *TxValue) GetResponse() *types1.ExecTxResult

func (*TxValue) Marshal

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

func (*TxValue) MarshalTo

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

func (*TxValue) MarshalToSizedBuffer

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

func (*TxValue) ProtoMessage

func (*TxValue) ProtoMessage()

func (*TxValue) Reset

func (m *TxValue) Reset()

func (*TxValue) Size

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

func (*TxValue) String

func (m *TxValue) String() string

func (*TxValue) Unmarshal

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

func (*TxValue) XXX_DiscardUnknown

func (m *TxValue) XXX_DiscardUnknown()

func (*TxValue) XXX_Marshal

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

func (*TxValue) XXX_Merge

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

func (*TxValue) XXX_Size

func (m *TxValue) XXX_Size() int

func (*TxValue) XXX_Unmarshal

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

type UnimplementedMsgServer

type UnimplementedMsgServer struct {
}

UnimplementedMsgServer can be embedded to have forward compatible implementations.

func (*UnimplementedMsgServer) RegisterInterchainQuery

func (*UnimplementedMsgServer) RemoveInterchainQuery

func (*UnimplementedMsgServer) SubmitQueryResult

func (*UnimplementedMsgServer) UpdateInterchainQuery

func (*UnimplementedMsgServer) UpdateParams

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) LastRemoteHeight

func (*UnimplementedQueryServer) Params

func (*UnimplementedQueryServer) RegisteredQueries

func (*UnimplementedQueryServer) RegisteredQuery

Jump to

Keyboard shortcuts

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