types

package
v0.0.0-...-4334f35 Latest Latest
Warning

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

Go to latest
Published: Oct 13, 2023 License: Apache-2.0 Imports: 46 Imported by: 3

Documentation

Overview

Package types is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

Index

Constants

View Source
const (
	// BatchTxCheckpointABIJSON checks the ETH ABI for compatability of the OutgoingBatchTx message
	BatchTxCheckpointABIJSON = `` /* 839-byte string literal not displayed */

	// SignerSetTxCheckpointABIJSON checks the ETH ABI for compatability of the signer set update message
	SignerSetTxCheckpointABIJSON = `` /* 589-byte string literal not displayed */

	// ContractCallTxABIJSON checks the ETH ABI for compatability of the logic call message
	ContractCallTxABIJSON = `` /* 1153-byte string literal not displayed */

)
View Source
const (
	EventTypeObservation              = "observation"
	EventTypeOutgoingBatch            = "outgoing_batch"
	EventTypeMultisigUpdateRequest    = "multisig_update_request"
	EventTypeOutgoingBatchCanceled    = "outgoing_batch_canceled"
	EventTypeContractCallTxCanceled   = "outgoing_logic_call_canceled"
	EventTypeBridgeWithdrawalReceived = "withdrawal_received"
	EventTypeBridgeDepositReceived    = "deposit_received"
	EventTypeBridgeWithdrawCanceled   = "withdraw_canceled"

	AttributeKeyEthereumEventVoteRecordID     = "ethereum_event_vote_record_id"
	AttributeKeyBatchConfirmKey               = "batch_confirm_key"
	AttributeKeyEthereumSignatureKey          = "ethereum_signature_key"
	AttributeKeyOutgoingBatchID               = "batch_id"
	AttributeKeyOutgoingTXID                  = "outgoing_tx_id"
	AttributeKeyEthereumEventType             = "ethereum_event_type"
	AttributeKeyContract                      = "bridge_contract"
	AttributeKeyNonce                         = "nonce"
	AttributeKeySignerSetNonce                = "signerset_nonce"
	AttributeKeyBatchNonce                    = "batch_nonce"
	AttributeKeyBridgeChainID                 = "bridge_chain_id"
	AttributeKeySetOrchestratorAddr           = "set_orchestrator_address"
	AttributeKeySetEthereumAddr               = "set_ethereum_address"
	AttributeKeyValidatorAddr                 = "validator_address"
	AttributeKeyContractCallInvalidationScope = "contract_call_invalidation_scope"
	AttributeKeyContractCallInvalidationNonce = "contract_call_invalidation_nonce"
	AttributeKeyContractCallPayload           = "contract_call_payload"
	AttributeKeyContractCallTokens            = "contract_call_tokens"
	AttributeKeyContractCallFees              = "contract_call_fees"
	AttributeKeyEthTxTimeout                  = "eth_tx_timeout"
)
View Source
const (
	// todo: implement oracle constants as params
	DefaultParamspace     = ModuleName
	EventVoteRecordPeriod = 24 * time.Hour // TODO: value????
)

DefaultParamspace defines the default auth module parameter subspace

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

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

	// RouterKey is the module name router key
	RouterKey = ModuleName

	// QuerierRoute to be used for querierer msgs
	QuerierRoute = ModuleName
)
View Source
const (

	// Key Delegation
	ValidatorExternalAddressKey
	OrchestratorValidatorAddressKey
	ExternalOrchestratorAddressKey

	// Core types
	ExternalSignatureKey
	ExternalEventVoteRecordKey
	OutgoingTxKey
	SendToExternalKey

	// Latest nonce indexes
	LastEventNonceByValidatorKey
	LastObservedEventNonceKey
	LatestSignerSetTxNonceKey
	LastSlashedOutgoingTxBlockKey
	LastSlashedSignerSetTxNonceKey
	LastOutgoingBatchNonceKey

	OutgoingSequence

	// LastSendToExternalIDKey indexes the lastTxPoolID
	LastSendToExternalIDKey

	// LastExternalBlockHeightKey indexes the latest Ethereum block height
	LastExternalBlockHeightKey

	TokenInfosKey

	// LastUnBondingBlockHeightKey indexes the last validator unbonding block height
	LastUnBondingBlockHeightKey

	LastObservedSignerSetKey

	TxStatusKey

	TxFeeRecordKey
)
View Source
const (
	SignerSetTxPrefixByte
	BatchTxPrefixByte
	ContractCallTxPrefixByte
)
View Source
const (
	// ProposalTypeColdStorageTransfer defines the type for a ColdStorageTransferProposal
	ProposalTypeColdStorageTransfer = "ColdStorageTransfer"
	ProposalTypeTokenInfosChange    = "TokenInfosChange"
)

Variables

View Source
var (
	ErrInvalid           = sdkerrors.Register(ModuleName, 3, "invalid")
	ErrSupplyOverflow    = sdkerrors.Register(ModuleName, 4, "malicious ERC20 with invalid supply sent over bridge")
	ErrDelegateKeys      = sdkerrors.Register(ModuleName, 5, "failed to delegate keys")
	ErrEmptyEthSig       = sdkerrors.Register(ModuleName, 6, "empty Ethereum signature")
	ErrInvalidERC20Event = sdkerrors.Register(ModuleName, 7, "invalid ERC20 deployed event")
)
View Source
var (
	// ParamsStoreKeyGravityID stores the mhub2 id
	ParamsStoreKeyGravityID = []byte("GravityID")

	// ParamsStoreKeyContractHash stores the contract hash
	ParamsStoreKeyContractHash = []byte("ContractHash")

	// ParamsStoreKeyBridgeContractAddress stores the contract address
	ParamsStoreKeyBridgeContractAddress = []byte("BridgeContractAddress")

	// ParamsStoreKeyBridgeContractChainID stores the bridge chain id
	ParamsStoreKeyBridgeContractChainID = []byte("BridgeChainID")

	// ParamsStoreKeySignedSignerSetTxsWindow stores the signed blocks window
	ParamsStoreKeySignedSignerSetTxsWindow = []byte("SignedSignerSetTxWindow")

	// ParamsStoreKeySignedBatchesWindow stores the signed blocks window
	ParamsStoreKeySignedBatchesWindow = []byte("SignedBatchesWindow")

	// ParamsStoreKeyEthereumSignaturesWindow stores the signed blocks window
	ParamsStoreKeyEthereumSignaturesWindow = []byte("EthereumSignaturesWindow")

	// ParamsStoreKeyTargetEthTxTimeout stores the target ethereum transaction timeout
	ParamsStoreKeyTargetEthTxTimeout = []byte("TargetEthTxTimeout")

	// ParamsStoreKeyAverageBlockTime stores the signed blocks window
	ParamsStoreKeyAverageBlockTime = []byte("AverageBlockTime")

	// ParamsStoreKeyAverageEthereumBlockTime stores the signed blocks window
	ParamsStoreKeyAverageEthereumBlockTime = []byte("AverageEthereumBlockTime")

	ParamsStoreKeyAverageBscBlockTime = []byte("AverageBscBlockTime")

	// ParamsStoreSlashFractionSignerSetTx stores the slash fraction valset
	ParamsStoreSlashFractionSignerSetTx = []byte("SlashFractionSignerSetTx")

	// ParamsStoreSlashFractionBatch stores the slash fraction Batch
	ParamsStoreSlashFractionBatch = []byte("SlashFractionBatch")

	// ParamsStoreSlashFractionEthereumSignature stores the slash fraction ethereum siganture
	ParamsStoreSlashFractionEthereumSignature = []byte("SlashFractionEthereumSignature")

	// ParamsStoreSlashFractionConflictingEthereumSignature stores the slash fraction ConflictingEthereumSignature
	ParamsStoreSlashFractionConflictingEthereumSignature = []byte("SlashFractionConflictingEthereumSignature")

	//  ParamStoreUnbondSlashingSignerSetTxsWindow stores unbond slashing valset window
	ParamStoreUnbondSlashingSignerSetTxsWindow = []byte("UnbondSlashingSignerSetTxsWindow")

	ParamChains            = []byte("Chains")
	ParamOutgoingTxTimeout = []byte("OutgoingTxTimeout")
)
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 (
	ErrInvalidLengthMhub2        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowMhub2          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupMhub2 = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthMsgs        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowMsgs          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupMsgs = 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 (

	// ModuleCdc references the global x/bank module codec. Note, the codec should
	// ONLY be used in certain instances of tests and for JSON encoding as Amino is
	// still used for that purpose.
	//
	// The actual codec used for serialization should be provided to x/staking and
	// defined at the application level.
	ModuleCdc = codec.NewAminoCodec(amino)
)
View Source
var TempAddress = sdk.AccAddress{1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1, 1}
View Source
var TxStatusType_name = map[int32]string{
	0: "TX_STATUS_NOT_FOUND",
	1: "TX_STATUS_DEPOSIT_RECEIVED",
	2: "TX_STATUS_BATCH_CREATED",
	3: "TX_STATUS_BATCH_EXECUTED",
	4: "TX_STATUS_REFUNDED",
}
View Source
var TxStatusType_value = map[string]int32{
	"TX_STATUS_NOT_FOUND":        0,
	"TX_STATUS_DEPOSIT_RECEIVED": 1,
	"TX_STATUS_BATCH_CREATED":    2,
	"TX_STATUS_BATCH_EXECUTED":   3,
	"TX_STATUS_REFUNDED":         4,
}

Functions

func EthereumAddrLessThan

func EthereumAddrLessThan(e, o string) bool

EthereumAddrLessThan migrates the Ethereum address less than function

func EventVoteRecordPowerThreshold

func EventVoteRecordPowerThreshold(totalPower sdk.Int) sdk.Int

func GetTxFeeRecordKey

func GetTxFeeRecordKey(inTxHash string) []byte

func GetTxStatusKey

func GetTxStatusKey(inTxHash string) []byte

func MakeBatchTxKey

func MakeBatchTxKey(chainId ChainID, externalTokenId string, nonce uint64) []byte

func MakeContractCallTxKey

func MakeContractCallTxKey(chainId ChainID, invalscope []byte, invalnonce uint64) []byte

func MakeExternalEventVoteRecordKey

func MakeExternalEventVoteRecordKey(chainId ChainID, eventNonce uint64, claimHash []byte) []byte

MakeExternalEventVoteRecordKey returns the following key format prefix nonce claim-details-hash // todo: add chain id [0x5][0 0 0 0 0 0 0 1][fd1af8cec6c67fcf156f1b61fdf91ebc04d05484d007436e75342fc05bbff35a]

func MakeExternalOrchestratorAddressKey

func MakeExternalOrchestratorAddressKey(chainId ChainID, eth common.Address) []byte

MakeExternalOrchestratorAddressKey returns the following key format prefix cosmos-validator [0x0][cosmosvaloper1ahx7f8wyertuus9r20284ej0asrs085case3kn]

func MakeExternalSignatureKey

func MakeExternalSignatureKey(chainId ChainID, storeIndex []byte, validator sdk.ValAddress) []byte

MakeExternalSignatureKey returns the following key format prefix nonce validator-address // todo: add chain id [0x0][0 0 0 0 0 0 0 1][cosmos1ahx7f8wyertuus9r20284ej0asrs085case3kn]

func MakeLastEventNonceByValidatorKey

func MakeLastEventNonceByValidatorKey(chainId ChainID, validator sdk.ValAddress) []byte

MakeLastEventNonceByValidatorKey indexes lateset event nonce by validator MakeLastEventNonceByValidatorKey returns the following key format prefix cosmos-validator [0x0][cosmos1ahx7f8wyertuus9r20284ej0asrs085case3kn]

func MakeOrchestratorValidatorAddressKey

func MakeOrchestratorValidatorAddressKey(chainId ChainID, orc sdk.AccAddress) []byte

MakeOrchestratorValidatorAddressKey returns the following key format prefix [0xe8][cosmos1ahx7f8wyertuus9r20284ej0asrs085case3kn]

func MakeOutgoingTxKey

func MakeOutgoingTxKey(chainId ChainID, storeIndex []byte) []byte

MakeOutgoingTxKey returns the store index passed with a prefix

func MakeSendToExternalKey

func MakeSendToExternalKey(chainId ChainID, id uint64, fee ExternalToken) []byte

MakeSendToExternalKey returns the following key format prefix token_id fee_amount id [0x9][000][1000000000][0 0 0 0 0 0 0 1]

func MakeSignerSetTxKey

func MakeSignerSetTxKey(chainId ChainID, nonce uint64) []byte

func MakeValidatorExternalAddressKey

func MakeValidatorExternalAddressKey(chainId ChainID, validator sdk.ValAddress) []byte

MakeValidatorExternalAddressKey returns the following key format prefix cosmos-validator [0x0][cosmosvaloper1ahx7f8wyertuus9r20284ej0asrs085case3kn]

func NewEthereumSignature

func NewEthereumSignature(hash []byte, privateKey *ecdsa.PrivateKey) ([]byte, error)

NewEthereumSignature creates a new signuature over a given byte array

func PackConfirmation

func PackConfirmation(confirmation ExternalTxConfirmation) (*types.Any, error)

func PackEvent

func PackEvent(event ExternalEvent) (*types.Any, error)

func PackOutgoingTx

func PackOutgoingTx(outgoing OutgoingTx) (*types.Any, error)

func ParamKeyTable

func ParamKeyTable() paramtypes.KeyTable

ParamKeyTable for auth module

func RegisterInterfaces

func RegisterInterfaces(registry types.InterfaceRegistry)

RegisterInterfaces registers the interfaces for the proto stuff

func RegisterLegacyAminoCodec

func RegisterLegacyAminoCodec(cdc *codec.LegacyAmino)

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

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

func ValidateEthereumSignature

func ValidateEthereumSignature(hash []byte, signature []byte, ethAddress common.Address) error

ValidateEthereumSignature takes a message, an associated signature and public key and returns an error if the signature isn't valid

Types

type AccountKeeper

type AccountKeeper interface {
	GetSequence(ctx sdk.Context, addr sdk.AccAddress) (uint64, error)
	GetModuleAddress(string) sdk.AccAddress
}

AccountKeeper defines the interface contract required for account functionality.

type BankKeeper

type BankKeeper interface {
	GetSupply(ctx sdk.Context, denom string) sdk.Coin
	SendCoinsFromModuleToAccount(ctx sdk.Context, senderModule string, recipientAddr sdk.AccAddress, amt sdk.Coins) error
	SendCoinsFromModuleToModule(ctx sdk.Context, senderModule, recipientModule string, amt sdk.Coins) error
	SendCoinsFromAccountToModule(ctx sdk.Context, senderAddr sdk.AccAddress, recipientModule string, amt sdk.Coins) error
	MintCoins(ctx sdk.Context, name string, amt sdk.Coins) error
	BurnCoins(ctx sdk.Context, name string, amt sdk.Coins) error
	GetAllBalances(ctx sdk.Context, addr sdk.AccAddress) sdk.Coins
	GetDenomMetaData(ctx sdk.Context, denom string) (bank.Metadata, bool)
}

BankKeeper defines the expected bank keeper methods

type BatchExecutedEvent

type BatchExecutedEvent struct {
	ExternalCoinId string                                 `protobuf:"bytes,1,opt,name=external_coin_id,json=externalCoinId,proto3" json:"external_coin_id,omitempty"`
	EventNonce     uint64                                 `protobuf:"varint,2,opt,name=event_nonce,json=eventNonce,proto3" json:"event_nonce,omitempty"`
	ExternalHeight uint64                                 `protobuf:"varint,3,opt,name=external_height,json=externalHeight,proto3" json:"external_height,omitempty"`
	BatchNonce     uint64                                 `protobuf:"varint,4,opt,name=batch_nonce,json=batchNonce,proto3" json:"batch_nonce,omitempty"`
	TxHash         string                                 `protobuf:"bytes,5,opt,name=tx_hash,json=txHash,proto3" json:"tx_hash,omitempty"`
	FeePaid        github_com_cosmos_cosmos_sdk_types.Int `protobuf:"bytes,6,opt,name=fee_paid,json=feePaid,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Int" json:"fee_paid"`
	FeePayer       string                                 `protobuf:"bytes,7,opt,name=fee_payer,json=feePayer,proto3" json:"fee_payer,omitempty"`
}

BatchExecutedEvent claims that a batch of BatchTxExecuted operations on the bridge contract was executed successfully

func (*BatchExecutedEvent) Descriptor

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

func (*BatchExecutedEvent) GetBatchNonce

func (m *BatchExecutedEvent) GetBatchNonce() uint64

func (*BatchExecutedEvent) GetEventNonce

func (m *BatchExecutedEvent) GetEventNonce() uint64

func (*BatchExecutedEvent) GetExternalCoinId

func (m *BatchExecutedEvent) GetExternalCoinId() string

func (*BatchExecutedEvent) GetExternalHeight

func (m *BatchExecutedEvent) GetExternalHeight() uint64

func (*BatchExecutedEvent) GetFeePayer

func (m *BatchExecutedEvent) GetFeePayer() string

func (*BatchExecutedEvent) GetTxHash

func (m *BatchExecutedEvent) GetTxHash() string

func (*BatchExecutedEvent) Hash

func (bee *BatchExecutedEvent) Hash() tmbytes.HexBytes

func (*BatchExecutedEvent) Marshal

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

func (*BatchExecutedEvent) MarshalTo

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

func (*BatchExecutedEvent) MarshalToSizedBuffer

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

func (*BatchExecutedEvent) ProtoMessage

func (*BatchExecutedEvent) ProtoMessage()

func (*BatchExecutedEvent) Reset

func (m *BatchExecutedEvent) Reset()

func (*BatchExecutedEvent) Size

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

func (*BatchExecutedEvent) String

func (m *BatchExecutedEvent) String() string

func (*BatchExecutedEvent) Unmarshal

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

func (*BatchExecutedEvent) Validate

func (bee *BatchExecutedEvent) Validate(chainId ChainID) error

func (*BatchExecutedEvent) XXX_DiscardUnknown

func (m *BatchExecutedEvent) XXX_DiscardUnknown()

func (*BatchExecutedEvent) XXX_Marshal

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

func (*BatchExecutedEvent) XXX_Merge

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

func (*BatchExecutedEvent) XXX_Size

func (m *BatchExecutedEvent) XXX_Size() int

func (*BatchExecutedEvent) XXX_Unmarshal

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

type BatchTx

type BatchTx struct {
	BatchNonce      uint64            `protobuf:"varint,1,opt,name=batch_nonce,json=batchNonce,proto3" json:"batch_nonce,omitempty"`
	Timeout         uint64            `protobuf:"varint,2,opt,name=timeout,proto3" json:"timeout,omitempty"`
	Transactions    []*SendToExternal `protobuf:"bytes,3,rep,name=transactions,proto3" json:"transactions,omitempty"`
	ExternalTokenId string            `protobuf:"bytes,4,opt,name=external_token_id,json=externalTokenId,proto3" json:"external_token_id,omitempty"`
	Height          uint64            `protobuf:"varint,5,opt,name=height,proto3" json:"height,omitempty"`
	Sequence        uint64            `protobuf:"varint,6,opt,name=sequence,proto3" json:"sequence,omitempty"`
}

BatchTx represents a batch of transactions going from Cosmos to External Chain. Batch txs are are identified by a unique hash and the token contract that is shared by all the SendToExternal

func (*BatchTx) Descriptor

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

func (*BatchTx) GetBatchNonce

func (m *BatchTx) GetBatchNonce() uint64

func (BatchTx) GetCheckpoint

func (b BatchTx) GetCheckpoint(gravityID []byte) []byte

GetCheckpoint gets the checkpoint signature from the given outgoing tx batch

func (*BatchTx) GetCosmosHeight

func (btx *BatchTx) GetCosmosHeight() uint64

func (*BatchTx) GetExternalTokenId

func (m *BatchTx) GetExternalTokenId() string

func (BatchTx) GetFees

func (b BatchTx) GetFees() sdk.Int

GetFees returns the total fees contained within a given batch

func (*BatchTx) GetHeight

func (m *BatchTx) GetHeight() uint64

func (*BatchTx) GetSequence

func (m *BatchTx) GetSequence() uint64

func (*BatchTx) GetStoreIndex

func (btx *BatchTx) GetStoreIndex(chainId ChainID) []byte

func (*BatchTx) GetTimeout

func (m *BatchTx) GetTimeout() uint64

func (*BatchTx) GetTransactions

func (m *BatchTx) GetTransactions() []*SendToExternal

func (*BatchTx) Marshal

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

func (*BatchTx) MarshalTo

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

func (*BatchTx) MarshalToSizedBuffer

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

func (*BatchTx) ProtoMessage

func (*BatchTx) ProtoMessage()

func (*BatchTx) Reset

func (m *BatchTx) Reset()

func (*BatchTx) SetSequence

func (btx *BatchTx) SetSequence(seq uint64)

func (*BatchTx) Size

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

func (*BatchTx) String

func (m *BatchTx) String() string

func (*BatchTx) Unmarshal

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

func (*BatchTx) XXX_DiscardUnknown

func (m *BatchTx) XXX_DiscardUnknown()

func (*BatchTx) XXX_Marshal

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

func (*BatchTx) XXX_Merge

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

func (*BatchTx) XXX_Size

func (m *BatchTx) XXX_Size() int

func (*BatchTx) XXX_Unmarshal

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

type BatchTxConfirmation

type BatchTxConfirmation struct {
	ExternalTokenId string `protobuf:"bytes,1,opt,name=external_token_id,json=externalTokenId,proto3" json:"external_token_id,omitempty"`
	BatchNonce      uint64 `protobuf:"varint,2,opt,name=batch_nonce,json=batchNonce,proto3" json:"batch_nonce,omitempty"`
	ExternalSigner  string `protobuf:"bytes,3,opt,name=external_signer,json=externalSigner,proto3" json:"external_signer,omitempty"`
	Signature       []byte `protobuf:"bytes,4,opt,name=signature,proto3" json:"signature,omitempty"`
}

BatchTxConfirmation is a signature on behalf of a validator for a BatchTx.

func (*BatchTxConfirmation) Descriptor

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

func (*BatchTxConfirmation) GetBatchNonce

func (m *BatchTxConfirmation) GetBatchNonce() uint64

func (*BatchTxConfirmation) GetExternalSigner

func (m *BatchTxConfirmation) GetExternalSigner() string

func (*BatchTxConfirmation) GetExternalTokenId

func (m *BatchTxConfirmation) GetExternalTokenId() string

func (*BatchTxConfirmation) GetSignature

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

func (*BatchTxConfirmation) GetSigner

func (u *BatchTxConfirmation) GetSigner() common.Address

func (*BatchTxConfirmation) GetStoreIndex

func (btx *BatchTxConfirmation) GetStoreIndex(chainId ChainID) []byte

func (*BatchTxConfirmation) Marshal

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

func (*BatchTxConfirmation) MarshalTo

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

func (*BatchTxConfirmation) MarshalToSizedBuffer

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

func (*BatchTxConfirmation) ProtoMessage

func (*BatchTxConfirmation) ProtoMessage()

func (*BatchTxConfirmation) Reset

func (m *BatchTxConfirmation) Reset()

func (*BatchTxConfirmation) Size

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

func (*BatchTxConfirmation) String

func (m *BatchTxConfirmation) String() string

func (*BatchTxConfirmation) Unmarshal

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

func (*BatchTxConfirmation) Validate

func (u *BatchTxConfirmation) Validate() error

func (*BatchTxConfirmation) XXX_DiscardUnknown

func (m *BatchTxConfirmation) XXX_DiscardUnknown()

func (*BatchTxConfirmation) XXX_Marshal

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

func (*BatchTxConfirmation) XXX_Merge

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

func (*BatchTxConfirmation) XXX_Size

func (m *BatchTxConfirmation) XXX_Size() int

func (*BatchTxConfirmation) XXX_Unmarshal

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

type BatchTxConfirmationsRequest

type BatchTxConfirmationsRequest struct {
	BatchNonce      uint64 `protobuf:"varint,1,opt,name=batch_nonce,json=batchNonce,proto3" json:"batch_nonce,omitempty"`
	ExternalTokenId string `protobuf:"bytes,2,opt,name=external_token_id,json=externalTokenId,proto3" json:"external_token_id,omitempty"`
	ChainId         string `protobuf:"bytes,3,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*BatchTxConfirmationsRequest) Descriptor

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

func (*BatchTxConfirmationsRequest) GetBatchNonce

func (m *BatchTxConfirmationsRequest) GetBatchNonce() uint64

func (*BatchTxConfirmationsRequest) GetChainId

func (m *BatchTxConfirmationsRequest) GetChainId() string

func (*BatchTxConfirmationsRequest) GetExternalTokenId

func (m *BatchTxConfirmationsRequest) GetExternalTokenId() string

func (*BatchTxConfirmationsRequest) Marshal

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

func (*BatchTxConfirmationsRequest) MarshalTo

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

func (*BatchTxConfirmationsRequest) MarshalToSizedBuffer

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

func (*BatchTxConfirmationsRequest) ProtoMessage

func (*BatchTxConfirmationsRequest) ProtoMessage()

func (*BatchTxConfirmationsRequest) Reset

func (m *BatchTxConfirmationsRequest) Reset()

func (*BatchTxConfirmationsRequest) Size

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

func (*BatchTxConfirmationsRequest) String

func (m *BatchTxConfirmationsRequest) String() string

func (*BatchTxConfirmationsRequest) Unmarshal

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

func (*BatchTxConfirmationsRequest) XXX_DiscardUnknown

func (m *BatchTxConfirmationsRequest) XXX_DiscardUnknown()

func (*BatchTxConfirmationsRequest) XXX_Marshal

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

func (*BatchTxConfirmationsRequest) XXX_Merge

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

func (*BatchTxConfirmationsRequest) XXX_Size

func (m *BatchTxConfirmationsRequest) XXX_Size() int

func (*BatchTxConfirmationsRequest) XXX_Unmarshal

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

type BatchTxConfirmationsResponse

type BatchTxConfirmationsResponse struct {
	Signatures []*BatchTxConfirmation `protobuf:"bytes,1,rep,name=signatures,proto3" json:"signatures,omitempty"`
}

func (*BatchTxConfirmationsResponse) Descriptor

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

func (*BatchTxConfirmationsResponse) GetSignatures

func (m *BatchTxConfirmationsResponse) GetSignatures() []*BatchTxConfirmation

func (*BatchTxConfirmationsResponse) Marshal

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

func (*BatchTxConfirmationsResponse) MarshalTo

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

func (*BatchTxConfirmationsResponse) MarshalToSizedBuffer

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

func (*BatchTxConfirmationsResponse) ProtoMessage

func (*BatchTxConfirmationsResponse) ProtoMessage()

func (*BatchTxConfirmationsResponse) Reset

func (m *BatchTxConfirmationsResponse) Reset()

func (*BatchTxConfirmationsResponse) Size

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

func (*BatchTxConfirmationsResponse) String

func (*BatchTxConfirmationsResponse) Unmarshal

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

func (*BatchTxConfirmationsResponse) XXX_DiscardUnknown

func (m *BatchTxConfirmationsResponse) XXX_DiscardUnknown()

func (*BatchTxConfirmationsResponse) XXX_Marshal

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

func (*BatchTxConfirmationsResponse) XXX_Merge

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

func (*BatchTxConfirmationsResponse) XXX_Size

func (m *BatchTxConfirmationsResponse) XXX_Size() int

func (*BatchTxConfirmationsResponse) XXX_Unmarshal

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

type BatchTxFeesRequest

type BatchTxFeesRequest struct {
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*BatchTxFeesRequest) Descriptor

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

func (*BatchTxFeesRequest) GetChainId

func (m *BatchTxFeesRequest) GetChainId() string

func (*BatchTxFeesRequest) Marshal

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

func (*BatchTxFeesRequest) MarshalTo

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

func (*BatchTxFeesRequest) MarshalToSizedBuffer

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

func (*BatchTxFeesRequest) ProtoMessage

func (*BatchTxFeesRequest) ProtoMessage()

func (*BatchTxFeesRequest) Reset

func (m *BatchTxFeesRequest) Reset()

func (*BatchTxFeesRequest) Size

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

func (*BatchTxFeesRequest) String

func (m *BatchTxFeesRequest) String() string

func (*BatchTxFeesRequest) Unmarshal

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

func (*BatchTxFeesRequest) XXX_DiscardUnknown

func (m *BatchTxFeesRequest) XXX_DiscardUnknown()

func (*BatchTxFeesRequest) XXX_Marshal

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

func (*BatchTxFeesRequest) XXX_Merge

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

func (*BatchTxFeesRequest) XXX_Size

func (m *BatchTxFeesRequest) XXX_Size() int

func (*BatchTxFeesRequest) XXX_Unmarshal

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

type BatchTxFeesResponse

type BatchTxFeesResponse struct {
	Fees github_com_cosmos_cosmos_sdk_types.Coins `protobuf:"bytes,1,rep,name=fees,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"fees"`
}

func (*BatchTxFeesResponse) Descriptor

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

func (*BatchTxFeesResponse) GetFees

func (*BatchTxFeesResponse) Marshal

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

func (*BatchTxFeesResponse) MarshalTo

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

func (*BatchTxFeesResponse) MarshalToSizedBuffer

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

func (*BatchTxFeesResponse) ProtoMessage

func (*BatchTxFeesResponse) ProtoMessage()

func (*BatchTxFeesResponse) Reset

func (m *BatchTxFeesResponse) Reset()

func (*BatchTxFeesResponse) Size

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

func (*BatchTxFeesResponse) String

func (m *BatchTxFeesResponse) String() string

func (*BatchTxFeesResponse) Unmarshal

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

func (*BatchTxFeesResponse) XXX_DiscardUnknown

func (m *BatchTxFeesResponse) XXX_DiscardUnknown()

func (*BatchTxFeesResponse) XXX_Marshal

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

func (*BatchTxFeesResponse) XXX_Merge

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

func (*BatchTxFeesResponse) XXX_Size

func (m *BatchTxFeesResponse) XXX_Size() int

func (*BatchTxFeesResponse) XXX_Unmarshal

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

type BatchTxRequest

type BatchTxRequest struct {
	ExternalTokenId string `protobuf:"bytes,1,opt,name=external_token_id,json=externalTokenId,proto3" json:"external_token_id,omitempty"`
	BatchNonce      uint64 `protobuf:"varint,2,opt,name=batch_nonce,json=batchNonce,proto3" json:"batch_nonce,omitempty"`
	ChainId         string `protobuf:"bytes,3,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

rpc BatchTx

func (*BatchTxRequest) Descriptor

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

func (*BatchTxRequest) GetBatchNonce

func (m *BatchTxRequest) GetBatchNonce() uint64

func (*BatchTxRequest) GetChainId

func (m *BatchTxRequest) GetChainId() string

func (*BatchTxRequest) GetExternalTokenId

func (m *BatchTxRequest) GetExternalTokenId() string

func (*BatchTxRequest) Marshal

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

func (*BatchTxRequest) MarshalTo

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

func (*BatchTxRequest) MarshalToSizedBuffer

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

func (*BatchTxRequest) ProtoMessage

func (*BatchTxRequest) ProtoMessage()

func (*BatchTxRequest) Reset

func (m *BatchTxRequest) Reset()

func (*BatchTxRequest) Size

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

func (*BatchTxRequest) String

func (m *BatchTxRequest) String() string

func (*BatchTxRequest) Unmarshal

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

func (*BatchTxRequest) XXX_DiscardUnknown

func (m *BatchTxRequest) XXX_DiscardUnknown()

func (*BatchTxRequest) XXX_Marshal

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

func (*BatchTxRequest) XXX_Merge

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

func (*BatchTxRequest) XXX_Size

func (m *BatchTxRequest) XXX_Size() int

func (*BatchTxRequest) XXX_Unmarshal

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

type BatchTxResponse

type BatchTxResponse struct {
	Batch *BatchTx `protobuf:"bytes,1,opt,name=batch,proto3" json:"batch,omitempty"`
}

func (*BatchTxResponse) Descriptor

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

func (*BatchTxResponse) GetBatch

func (m *BatchTxResponse) GetBatch() *BatchTx

func (*BatchTxResponse) Marshal

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

func (*BatchTxResponse) MarshalTo

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

func (*BatchTxResponse) MarshalToSizedBuffer

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

func (*BatchTxResponse) ProtoMessage

func (*BatchTxResponse) ProtoMessage()

func (*BatchTxResponse) Reset

func (m *BatchTxResponse) Reset()

func (*BatchTxResponse) Size

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

func (*BatchTxResponse) String

func (m *BatchTxResponse) String() string

func (*BatchTxResponse) Unmarshal

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

func (*BatchTxResponse) XXX_DiscardUnknown

func (m *BatchTxResponse) XXX_DiscardUnknown()

func (*BatchTxResponse) XXX_Marshal

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

func (*BatchTxResponse) XXX_Merge

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

func (*BatchTxResponse) XXX_Size

func (m *BatchTxResponse) XXX_Size() int

func (*BatchTxResponse) XXX_Unmarshal

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

type BatchTxsRequest

type BatchTxsRequest struct {
	Pagination *query.PageRequest `protobuf:"bytes,1,opt,name=pagination,proto3" json:"pagination,omitempty"`
	ChainId    string             `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

rpc BatchTxs

func (*BatchTxsRequest) Descriptor

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

func (*BatchTxsRequest) GetChainId

func (m *BatchTxsRequest) GetChainId() string

func (*BatchTxsRequest) GetPagination

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

func (*BatchTxsRequest) Marshal

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

func (*BatchTxsRequest) MarshalTo

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

func (*BatchTxsRequest) MarshalToSizedBuffer

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

func (*BatchTxsRequest) ProtoMessage

func (*BatchTxsRequest) ProtoMessage()

func (*BatchTxsRequest) Reset

func (m *BatchTxsRequest) Reset()

func (*BatchTxsRequest) Size

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

func (*BatchTxsRequest) String

func (m *BatchTxsRequest) String() string

func (*BatchTxsRequest) Unmarshal

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

func (*BatchTxsRequest) XXX_DiscardUnknown

func (m *BatchTxsRequest) XXX_DiscardUnknown()

func (*BatchTxsRequest) XXX_Marshal

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

func (*BatchTxsRequest) XXX_Merge

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

func (*BatchTxsRequest) XXX_Size

func (m *BatchTxsRequest) XXX_Size() int

func (*BatchTxsRequest) XXX_Unmarshal

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

type BatchTxsResponse

type BatchTxsResponse struct {
	Batches    []*BatchTx          `protobuf:"bytes,1,rep,name=batches,proto3" json:"batches,omitempty"`
	Pagination *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*BatchTxsResponse) Descriptor

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

func (*BatchTxsResponse) GetBatches

func (m *BatchTxsResponse) GetBatches() []*BatchTx

func (*BatchTxsResponse) GetPagination

func (m *BatchTxsResponse) GetPagination() *query.PageResponse

func (*BatchTxsResponse) Marshal

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

func (*BatchTxsResponse) MarshalTo

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

func (*BatchTxsResponse) MarshalToSizedBuffer

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

func (*BatchTxsResponse) ProtoMessage

func (*BatchTxsResponse) ProtoMessage()

func (*BatchTxsResponse) Reset

func (m *BatchTxsResponse) Reset()

func (*BatchTxsResponse) Size

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

func (*BatchTxsResponse) String

func (m *BatchTxsResponse) String() string

func (*BatchTxsResponse) Unmarshal

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

func (*BatchTxsResponse) XXX_DiscardUnknown

func (m *BatchTxsResponse) XXX_DiscardUnknown()

func (*BatchTxsResponse) XXX_Marshal

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

func (*BatchTxsResponse) XXX_Merge

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

func (*BatchTxsResponse) XXX_Size

func (m *BatchTxsResponse) XXX_Size() int

func (*BatchTxsResponse) XXX_Unmarshal

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

type BatchedSendToExternalsRequest

type BatchedSendToExternalsRequest struct {
	SenderAddress string `protobuf:"bytes,1,opt,name=sender_address,json=senderAddress,proto3" json:"sender_address,omitempty"`
	ChainId       string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

NOTE: if there is no sender address, return all

func (*BatchedSendToExternalsRequest) Descriptor

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

func (*BatchedSendToExternalsRequest) GetChainId

func (m *BatchedSendToExternalsRequest) GetChainId() string

func (*BatchedSendToExternalsRequest) GetSenderAddress

func (m *BatchedSendToExternalsRequest) GetSenderAddress() string

func (*BatchedSendToExternalsRequest) Marshal

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

func (*BatchedSendToExternalsRequest) MarshalTo

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

func (*BatchedSendToExternalsRequest) MarshalToSizedBuffer

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

func (*BatchedSendToExternalsRequest) ProtoMessage

func (*BatchedSendToExternalsRequest) ProtoMessage()

func (*BatchedSendToExternalsRequest) Reset

func (m *BatchedSendToExternalsRequest) Reset()

func (*BatchedSendToExternalsRequest) Size

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

func (*BatchedSendToExternalsRequest) String

func (*BatchedSendToExternalsRequest) Unmarshal

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

func (*BatchedSendToExternalsRequest) XXX_DiscardUnknown

func (m *BatchedSendToExternalsRequest) XXX_DiscardUnknown()

func (*BatchedSendToExternalsRequest) XXX_Marshal

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

func (*BatchedSendToExternalsRequest) XXX_Merge

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

func (*BatchedSendToExternalsRequest) XXX_Size

func (m *BatchedSendToExternalsRequest) XXX_Size() int

func (*BatchedSendToExternalsRequest) XXX_Unmarshal

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

type BatchedSendToExternalsResponse

type BatchedSendToExternalsResponse struct {
	SendToExternals []*SendToExternal `protobuf:"bytes,1,rep,name=send_to_externals,json=sendToExternals,proto3" json:"send_to_externals,omitempty"`
	ChainId         string            `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*BatchedSendToExternalsResponse) Descriptor

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

func (*BatchedSendToExternalsResponse) GetChainId

func (m *BatchedSendToExternalsResponse) GetChainId() string

func (*BatchedSendToExternalsResponse) GetSendToExternals

func (m *BatchedSendToExternalsResponse) GetSendToExternals() []*SendToExternal

func (*BatchedSendToExternalsResponse) Marshal

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

func (*BatchedSendToExternalsResponse) MarshalTo

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

func (*BatchedSendToExternalsResponse) MarshalToSizedBuffer

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

func (*BatchedSendToExternalsResponse) ProtoMessage

func (*BatchedSendToExternalsResponse) ProtoMessage()

func (*BatchedSendToExternalsResponse) Reset

func (m *BatchedSendToExternalsResponse) Reset()

func (*BatchedSendToExternalsResponse) Size

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

func (*BatchedSendToExternalsResponse) String

func (*BatchedSendToExternalsResponse) Unmarshal

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

func (*BatchedSendToExternalsResponse) XXX_DiscardUnknown

func (m *BatchedSendToExternalsResponse) XXX_DiscardUnknown()

func (*BatchedSendToExternalsResponse) XXX_Marshal

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

func (*BatchedSendToExternalsResponse) XXX_Merge

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

func (*BatchedSendToExternalsResponse) XXX_Size

func (m *BatchedSendToExternalsResponse) XXX_Size() int

func (*BatchedSendToExternalsResponse) XXX_Unmarshal

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

type ChainID

type ChainID string

func (ChainID) Bytes

func (c ChainID) Bytes() []byte

func (ChainID) String

func (c ChainID) String() string

type Coin

type Coin struct {
}

func (Coin) ID

func (c Coin) ID() []byte

type ColdStorageTransferProposal

type ColdStorageTransferProposal struct {
	ChainId string                                   `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	Amount  github_com_cosmos_cosmos_sdk_types.Coins `protobuf:"bytes,2,rep,name=amount,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"amount"`
}

func NewColdStorageTransferProposal

func NewColdStorageTransferProposal(chainId ChainID, amount sdk.Coins) *ColdStorageTransferProposal

func (*ColdStorageTransferProposal) Descriptor

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

func (*ColdStorageTransferProposal) GetDescription

func (csp *ColdStorageTransferProposal) GetDescription() string

GetDescription returns the description of a community pool spend proposal.

func (*ColdStorageTransferProposal) GetTitle

func (csp *ColdStorageTransferProposal) GetTitle() string

GetTitle returns the title of a community pool spend proposal.

func (*ColdStorageTransferProposal) Marshal

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

func (*ColdStorageTransferProposal) MarshalTo

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

func (*ColdStorageTransferProposal) MarshalToSizedBuffer

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

func (*ColdStorageTransferProposal) ProposalRoute

func (csp *ColdStorageTransferProposal) ProposalRoute() string

GetDescription returns the routing key of a community pool spend proposal.

func (*ColdStorageTransferProposal) ProposalType

func (csp *ColdStorageTransferProposal) ProposalType() string

ProposalType returns the type of a community pool spend proposal.

func (*ColdStorageTransferProposal) ProtoMessage

func (*ColdStorageTransferProposal) ProtoMessage()

func (*ColdStorageTransferProposal) Reset

func (m *ColdStorageTransferProposal) Reset()

func (*ColdStorageTransferProposal) Size

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

func (ColdStorageTransferProposal) String

func (csp ColdStorageTransferProposal) String() string

String implements the Stringer interface.

func (*ColdStorageTransferProposal) Unmarshal

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

func (*ColdStorageTransferProposal) ValidateBasic

func (csp *ColdStorageTransferProposal) ValidateBasic() error

ValidateBasic runs basic stateless validity checks

func (*ColdStorageTransferProposal) XXX_DiscardUnknown

func (m *ColdStorageTransferProposal) XXX_DiscardUnknown()

func (*ColdStorageTransferProposal) XXX_Marshal

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

func (*ColdStorageTransferProposal) XXX_Merge

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

func (*ColdStorageTransferProposal) XXX_Size

func (m *ColdStorageTransferProposal) XXX_Size() int

func (*ColdStorageTransferProposal) XXX_Unmarshal

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

type ContractCallExecutedEvent

type ContractCallExecutedEvent struct {
	EventNonce        uint64                                               `protobuf:"varint,1,opt,name=event_nonce,json=eventNonce,proto3" json:"event_nonce,omitempty"`
	InvalidationScope github_com_tendermint_tendermint_libs_bytes.HexBytes `` /* 174-byte string literal not displayed */
	InvalidationNonce uint64                                               `protobuf:"varint,3,opt,name=invalidation_nonce,json=invalidationNonce,proto3" json:"invalidation_nonce,omitempty"`
	ReturnData        []byte                                               `protobuf:"bytes,4,opt,name=return_data,json=returnData,proto3" json:"return_data,omitempty"`
	ExternalHeight    uint64                                               `protobuf:"varint,5,opt,name=external_height,json=externalHeight,proto3" json:"external_height,omitempty"`
	TxHash            string                                               `protobuf:"bytes,6,opt,name=tx_hash,json=txHash,proto3" json:"tx_hash,omitempty"`
}

NOTE: bytes.HexBytes is supposed to "help" with json encoding/decoding investigate?

func (*ContractCallExecutedEvent) Descriptor

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

func (*ContractCallExecutedEvent) GetEventNonce

func (m *ContractCallExecutedEvent) GetEventNonce() uint64

func (*ContractCallExecutedEvent) GetExternalHeight

func (m *ContractCallExecutedEvent) GetExternalHeight() uint64

func (*ContractCallExecutedEvent) GetInvalidationNonce

func (m *ContractCallExecutedEvent) GetInvalidationNonce() uint64

func (*ContractCallExecutedEvent) GetInvalidationScope

func (*ContractCallExecutedEvent) GetReturnData

func (m *ContractCallExecutedEvent) GetReturnData() []byte

func (*ContractCallExecutedEvent) GetTxHash

func (m *ContractCallExecutedEvent) GetTxHash() string

func (*ContractCallExecutedEvent) Hash

func (*ContractCallExecutedEvent) Marshal

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

func (*ContractCallExecutedEvent) MarshalTo

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

func (*ContractCallExecutedEvent) MarshalToSizedBuffer

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

func (*ContractCallExecutedEvent) ProtoMessage

func (*ContractCallExecutedEvent) ProtoMessage()

func (*ContractCallExecutedEvent) Reset

func (m *ContractCallExecutedEvent) Reset()

func (*ContractCallExecutedEvent) Size

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

func (*ContractCallExecutedEvent) String

func (m *ContractCallExecutedEvent) String() string

func (*ContractCallExecutedEvent) Unmarshal

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

func (*ContractCallExecutedEvent) Validate

func (ccee *ContractCallExecutedEvent) Validate(chainId ChainID) error

func (*ContractCallExecutedEvent) XXX_DiscardUnknown

func (m *ContractCallExecutedEvent) XXX_DiscardUnknown()

func (*ContractCallExecutedEvent) XXX_Marshal

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

func (*ContractCallExecutedEvent) XXX_Merge

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

func (*ContractCallExecutedEvent) XXX_Size

func (m *ContractCallExecutedEvent) XXX_Size() int

func (*ContractCallExecutedEvent) XXX_Unmarshal

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

type ContractCallTx

type ContractCallTx struct {
	InvalidationNonce uint64                                               `protobuf:"varint,1,opt,name=invalidation_nonce,json=invalidationNonce,proto3" json:"invalidation_nonce,omitempty"`
	InvalidationScope github_com_tendermint_tendermint_libs_bytes.HexBytes `` /* 174-byte string literal not displayed */
	Address           string                                               `protobuf:"bytes,3,opt,name=address,proto3" json:"address,omitempty"`
	Payload           []byte                                               `protobuf:"bytes,4,opt,name=payload,proto3" json:"payload,omitempty"`
	Timeout           uint64                                               `protobuf:"varint,5,opt,name=timeout,proto3" json:"timeout,omitempty"`
	Tokens            []ExternalToken                                      `protobuf:"bytes,6,rep,name=tokens,proto3" json:"tokens"`
	Fees              []ExternalToken                                      `protobuf:"bytes,7,rep,name=fees,proto3" json:"fees"`
	Height            uint64                                               `protobuf:"varint,8,opt,name=height,proto3" json:"height,omitempty"`
	Sequence          uint64                                               `protobuf:"varint,9,opt,name=sequence,proto3" json:"sequence,omitempty"`
}

ContractCallTx represents an individual arbitrary logic call transaction from Cosmos to External.

func (*ContractCallTx) Descriptor

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

func (*ContractCallTx) GetAddress

func (m *ContractCallTx) GetAddress() string

func (ContractCallTx) GetCheckpoint

func (c ContractCallTx) GetCheckpoint(gravityID []byte) []byte

GetCheckpoint gets the checkpoint signature from the given outgoing tx batch

func (*ContractCallTx) GetCosmosHeight

func (cctx *ContractCallTx) GetCosmosHeight() uint64

func (*ContractCallTx) GetFees

func (m *ContractCallTx) GetFees() []ExternalToken

func (*ContractCallTx) GetHeight

func (m *ContractCallTx) GetHeight() uint64

func (*ContractCallTx) GetInvalidationNonce

func (m *ContractCallTx) GetInvalidationNonce() uint64

func (*ContractCallTx) GetInvalidationScope

func (*ContractCallTx) GetPayload

func (m *ContractCallTx) GetPayload() []byte

func (*ContractCallTx) GetSequence

func (m *ContractCallTx) GetSequence() uint64

func (*ContractCallTx) GetStoreIndex

func (cctx *ContractCallTx) GetStoreIndex(chainId ChainID) []byte

func (*ContractCallTx) GetTimeout

func (m *ContractCallTx) GetTimeout() uint64

func (*ContractCallTx) GetTokens

func (m *ContractCallTx) GetTokens() []ExternalToken

func (*ContractCallTx) Marshal

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

func (*ContractCallTx) MarshalTo

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

func (*ContractCallTx) MarshalToSizedBuffer

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

func (*ContractCallTx) ProtoMessage

func (*ContractCallTx) ProtoMessage()

func (*ContractCallTx) Reset

func (m *ContractCallTx) Reset()

func (*ContractCallTx) SetSequence

func (cctx *ContractCallTx) SetSequence(seq uint64)

func (*ContractCallTx) Size

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

func (*ContractCallTx) String

func (m *ContractCallTx) String() string

func (*ContractCallTx) Unmarshal

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

func (*ContractCallTx) XXX_DiscardUnknown

func (m *ContractCallTx) XXX_DiscardUnknown()

func (*ContractCallTx) XXX_Marshal

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

func (*ContractCallTx) XXX_Merge

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

func (*ContractCallTx) XXX_Size

func (m *ContractCallTx) XXX_Size() int

func (*ContractCallTx) XXX_Unmarshal

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

type ContractCallTxConfirmation

type ContractCallTxConfirmation struct {
	InvalidationScope []byte `protobuf:"bytes,1,opt,name=invalidation_scope,json=invalidationScope,proto3" json:"invalidation_scope,omitempty"`
	InvalidationNonce uint64 `protobuf:"varint,2,opt,name=invalidation_nonce,json=invalidationNonce,proto3" json:"invalidation_nonce,omitempty"`
	ExternalSigner    string `protobuf:"bytes,3,opt,name=external_signer,json=externalSigner,proto3" json:"external_signer,omitempty"`
	Signature         []byte `protobuf:"bytes,4,opt,name=signature,proto3" json:"signature,omitempty"`
}

ContractCallTxConfirmation is a signature on behalf of a validator for a ContractCallTx.

func (*ContractCallTxConfirmation) Descriptor

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

func (*ContractCallTxConfirmation) GetExternalSigner

func (m *ContractCallTxConfirmation) GetExternalSigner() string

func (*ContractCallTxConfirmation) GetInvalidationNonce

func (m *ContractCallTxConfirmation) GetInvalidationNonce() uint64

func (*ContractCallTxConfirmation) GetInvalidationScope

func (m *ContractCallTxConfirmation) GetInvalidationScope() []byte

func (*ContractCallTxConfirmation) GetSignature

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

func (*ContractCallTxConfirmation) GetSigner

func (u *ContractCallTxConfirmation) GetSigner() common.Address

func (*ContractCallTxConfirmation) GetStoreIndex

func (cctx *ContractCallTxConfirmation) GetStoreIndex(chainId ChainID) []byte

func (*ContractCallTxConfirmation) Marshal

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

func (*ContractCallTxConfirmation) MarshalTo

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

func (*ContractCallTxConfirmation) MarshalToSizedBuffer

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

func (*ContractCallTxConfirmation) ProtoMessage

func (*ContractCallTxConfirmation) ProtoMessage()

func (*ContractCallTxConfirmation) Reset

func (m *ContractCallTxConfirmation) Reset()

func (*ContractCallTxConfirmation) Size

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

func (*ContractCallTxConfirmation) String

func (m *ContractCallTxConfirmation) String() string

func (*ContractCallTxConfirmation) Unmarshal

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

func (*ContractCallTxConfirmation) Validate

func (u *ContractCallTxConfirmation) Validate() error

func (*ContractCallTxConfirmation) XXX_DiscardUnknown

func (m *ContractCallTxConfirmation) XXX_DiscardUnknown()

func (*ContractCallTxConfirmation) XXX_Marshal

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

func (*ContractCallTxConfirmation) XXX_Merge

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

func (*ContractCallTxConfirmation) XXX_Size

func (m *ContractCallTxConfirmation) XXX_Size() int

func (*ContractCallTxConfirmation) XXX_Unmarshal

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

type ContractCallTxConfirmationsRequest

type ContractCallTxConfirmationsRequest struct {
	InvalidationScope []byte `protobuf:"bytes,1,opt,name=invalidation_scope,json=invalidationScope,proto3" json:"invalidation_scope,omitempty"`
	InvalidationNonce uint64 `protobuf:"varint,2,opt,name=invalidation_nonce,json=invalidationNonce,proto3" json:"invalidation_nonce,omitempty"`
	ChainId           string `protobuf:"bytes,3,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*ContractCallTxConfirmationsRequest) Descriptor

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

func (*ContractCallTxConfirmationsRequest) GetChainId

func (*ContractCallTxConfirmationsRequest) GetInvalidationNonce

func (m *ContractCallTxConfirmationsRequest) GetInvalidationNonce() uint64

func (*ContractCallTxConfirmationsRequest) GetInvalidationScope

func (m *ContractCallTxConfirmationsRequest) GetInvalidationScope() []byte

func (*ContractCallTxConfirmationsRequest) Marshal

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

func (*ContractCallTxConfirmationsRequest) MarshalTo

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

func (*ContractCallTxConfirmationsRequest) MarshalToSizedBuffer

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

func (*ContractCallTxConfirmationsRequest) ProtoMessage

func (*ContractCallTxConfirmationsRequest) ProtoMessage()

func (*ContractCallTxConfirmationsRequest) Reset

func (*ContractCallTxConfirmationsRequest) Size

func (*ContractCallTxConfirmationsRequest) String

func (*ContractCallTxConfirmationsRequest) Unmarshal

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

func (*ContractCallTxConfirmationsRequest) XXX_DiscardUnknown

func (m *ContractCallTxConfirmationsRequest) XXX_DiscardUnknown()

func (*ContractCallTxConfirmationsRequest) XXX_Marshal

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

func (*ContractCallTxConfirmationsRequest) XXX_Merge

func (*ContractCallTxConfirmationsRequest) XXX_Size

func (*ContractCallTxConfirmationsRequest) XXX_Unmarshal

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

type ContractCallTxConfirmationsResponse

type ContractCallTxConfirmationsResponse struct {
	Signatures []*ContractCallTxConfirmation `protobuf:"bytes,1,rep,name=signatures,proto3" json:"signatures,omitempty"`
}

func (*ContractCallTxConfirmationsResponse) Descriptor

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

func (*ContractCallTxConfirmationsResponse) GetSignatures

func (*ContractCallTxConfirmationsResponse) Marshal

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

func (*ContractCallTxConfirmationsResponse) MarshalTo

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

func (*ContractCallTxConfirmationsResponse) MarshalToSizedBuffer

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

func (*ContractCallTxConfirmationsResponse) ProtoMessage

func (*ContractCallTxConfirmationsResponse) ProtoMessage()

func (*ContractCallTxConfirmationsResponse) Reset

func (*ContractCallTxConfirmationsResponse) Size

func (*ContractCallTxConfirmationsResponse) String

func (*ContractCallTxConfirmationsResponse) Unmarshal

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

func (*ContractCallTxConfirmationsResponse) XXX_DiscardUnknown

func (m *ContractCallTxConfirmationsResponse) XXX_DiscardUnknown()

func (*ContractCallTxConfirmationsResponse) XXX_Marshal

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

func (*ContractCallTxConfirmationsResponse) XXX_Merge

func (*ContractCallTxConfirmationsResponse) XXX_Size

func (*ContractCallTxConfirmationsResponse) XXX_Unmarshal

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

type ContractCallTxRequest

type ContractCallTxRequest struct {
	InvalidationScope []byte `protobuf:"bytes,1,opt,name=invalidation_scope,json=invalidationScope,proto3" json:"invalidation_scope,omitempty"`
	InvalidationNonce uint64 `protobuf:"varint,2,opt,name=invalidation_nonce,json=invalidationNonce,proto3" json:"invalidation_nonce,omitempty"`
	ChainId           string `protobuf:"bytes,3,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

rpc ContractCallTx

func (*ContractCallTxRequest) Descriptor

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

func (*ContractCallTxRequest) GetChainId

func (m *ContractCallTxRequest) GetChainId() string

func (*ContractCallTxRequest) GetInvalidationNonce

func (m *ContractCallTxRequest) GetInvalidationNonce() uint64

func (*ContractCallTxRequest) GetInvalidationScope

func (m *ContractCallTxRequest) GetInvalidationScope() []byte

func (*ContractCallTxRequest) Marshal

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

func (*ContractCallTxRequest) MarshalTo

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

func (*ContractCallTxRequest) MarshalToSizedBuffer

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

func (*ContractCallTxRequest) ProtoMessage

func (*ContractCallTxRequest) ProtoMessage()

func (*ContractCallTxRequest) Reset

func (m *ContractCallTxRequest) Reset()

func (*ContractCallTxRequest) Size

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

func (*ContractCallTxRequest) String

func (m *ContractCallTxRequest) String() string

func (*ContractCallTxRequest) Unmarshal

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

func (*ContractCallTxRequest) XXX_DiscardUnknown

func (m *ContractCallTxRequest) XXX_DiscardUnknown()

func (*ContractCallTxRequest) XXX_Marshal

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

func (*ContractCallTxRequest) XXX_Merge

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

func (*ContractCallTxRequest) XXX_Size

func (m *ContractCallTxRequest) XXX_Size() int

func (*ContractCallTxRequest) XXX_Unmarshal

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

type ContractCallTxResponse

type ContractCallTxResponse struct {
	LogicCall *ContractCallTx `protobuf:"bytes,1,opt,name=logic_call,json=logicCall,proto3" json:"logic_call,omitempty"`
}

func (*ContractCallTxResponse) Descriptor

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

func (*ContractCallTxResponse) GetLogicCall

func (m *ContractCallTxResponse) GetLogicCall() *ContractCallTx

func (*ContractCallTxResponse) Marshal

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

func (*ContractCallTxResponse) MarshalTo

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

func (*ContractCallTxResponse) MarshalToSizedBuffer

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

func (*ContractCallTxResponse) ProtoMessage

func (*ContractCallTxResponse) ProtoMessage()

func (*ContractCallTxResponse) Reset

func (m *ContractCallTxResponse) Reset()

func (*ContractCallTxResponse) Size

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

func (*ContractCallTxResponse) String

func (m *ContractCallTxResponse) String() string

func (*ContractCallTxResponse) Unmarshal

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

func (*ContractCallTxResponse) XXX_DiscardUnknown

func (m *ContractCallTxResponse) XXX_DiscardUnknown()

func (*ContractCallTxResponse) XXX_Marshal

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

func (*ContractCallTxResponse) XXX_Merge

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

func (*ContractCallTxResponse) XXX_Size

func (m *ContractCallTxResponse) XXX_Size() int

func (*ContractCallTxResponse) XXX_Unmarshal

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

type ContractCallTxsRequest

type ContractCallTxsRequest struct {
	Pagination *query.PageRequest `protobuf:"bytes,1,opt,name=pagination,proto3" json:"pagination,omitempty"`
	ChainId    string             `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

rpc ContractCallTxs

func (*ContractCallTxsRequest) Descriptor

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

func (*ContractCallTxsRequest) GetChainId

func (m *ContractCallTxsRequest) GetChainId() string

func (*ContractCallTxsRequest) GetPagination

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

func (*ContractCallTxsRequest) Marshal

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

func (*ContractCallTxsRequest) MarshalTo

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

func (*ContractCallTxsRequest) MarshalToSizedBuffer

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

func (*ContractCallTxsRequest) ProtoMessage

func (*ContractCallTxsRequest) ProtoMessage()

func (*ContractCallTxsRequest) Reset

func (m *ContractCallTxsRequest) Reset()

func (*ContractCallTxsRequest) Size

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

func (*ContractCallTxsRequest) String

func (m *ContractCallTxsRequest) String() string

func (*ContractCallTxsRequest) Unmarshal

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

func (*ContractCallTxsRequest) XXX_DiscardUnknown

func (m *ContractCallTxsRequest) XXX_DiscardUnknown()

func (*ContractCallTxsRequest) XXX_Marshal

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

func (*ContractCallTxsRequest) XXX_Merge

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

func (*ContractCallTxsRequest) XXX_Size

func (m *ContractCallTxsRequest) XXX_Size() int

func (*ContractCallTxsRequest) XXX_Unmarshal

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

type ContractCallTxsResponse

type ContractCallTxsResponse struct {
	Calls      []*ContractCallTx   `protobuf:"bytes,1,rep,name=calls,proto3" json:"calls,omitempty"`
	Pagination *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*ContractCallTxsResponse) Descriptor

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

func (*ContractCallTxsResponse) GetCalls

func (m *ContractCallTxsResponse) GetCalls() []*ContractCallTx

func (*ContractCallTxsResponse) GetPagination

func (m *ContractCallTxsResponse) GetPagination() *query.PageResponse

func (*ContractCallTxsResponse) Marshal

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

func (*ContractCallTxsResponse) MarshalTo

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

func (*ContractCallTxsResponse) MarshalToSizedBuffer

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

func (*ContractCallTxsResponse) ProtoMessage

func (*ContractCallTxsResponse) ProtoMessage()

func (*ContractCallTxsResponse) Reset

func (m *ContractCallTxsResponse) Reset()

func (*ContractCallTxsResponse) Size

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

func (*ContractCallTxsResponse) String

func (m *ContractCallTxsResponse) String() string

func (*ContractCallTxsResponse) Unmarshal

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

func (*ContractCallTxsResponse) XXX_DiscardUnknown

func (m *ContractCallTxsResponse) XXX_DiscardUnknown()

func (*ContractCallTxsResponse) XXX_Marshal

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

func (*ContractCallTxsResponse) XXX_Merge

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

func (*ContractCallTxsResponse) XXX_Size

func (m *ContractCallTxsResponse) XXX_Size() int

func (*ContractCallTxsResponse) XXX_Unmarshal

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

type DelegateKeysByExternalSignerRequest

type DelegateKeysByExternalSignerRequest struct {
	ExternalSigner string `protobuf:"bytes,1,opt,name=external_signer,json=externalSigner,proto3" json:"external_signer,omitempty"`
	ChainId        string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*DelegateKeysByExternalSignerRequest) Descriptor

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

func (*DelegateKeysByExternalSignerRequest) GetChainId

func (*DelegateKeysByExternalSignerRequest) GetExternalSigner

func (m *DelegateKeysByExternalSignerRequest) GetExternalSigner() string

func (*DelegateKeysByExternalSignerRequest) Marshal

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

func (*DelegateKeysByExternalSignerRequest) MarshalTo

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

func (*DelegateKeysByExternalSignerRequest) MarshalToSizedBuffer

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

func (*DelegateKeysByExternalSignerRequest) ProtoMessage

func (*DelegateKeysByExternalSignerRequest) ProtoMessage()

func (*DelegateKeysByExternalSignerRequest) Reset

func (*DelegateKeysByExternalSignerRequest) Size

func (*DelegateKeysByExternalSignerRequest) String

func (*DelegateKeysByExternalSignerRequest) Unmarshal

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

func (*DelegateKeysByExternalSignerRequest) XXX_DiscardUnknown

func (m *DelegateKeysByExternalSignerRequest) XXX_DiscardUnknown()

func (*DelegateKeysByExternalSignerRequest) XXX_Marshal

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

func (*DelegateKeysByExternalSignerRequest) XXX_Merge

func (*DelegateKeysByExternalSignerRequest) XXX_Size

func (*DelegateKeysByExternalSignerRequest) XXX_Unmarshal

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

type DelegateKeysByExternalSignerResponse

type DelegateKeysByExternalSignerResponse struct {
	ValidatorAddress    string `protobuf:"bytes,1,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
	OrchestratorAddress string `protobuf:"bytes,2,opt,name=orchestrator_address,json=orchestratorAddress,proto3" json:"orchestrator_address,omitempty"`
}

func (*DelegateKeysByExternalSignerResponse) Descriptor

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

func (*DelegateKeysByExternalSignerResponse) GetOrchestratorAddress

func (m *DelegateKeysByExternalSignerResponse) GetOrchestratorAddress() string

func (*DelegateKeysByExternalSignerResponse) GetValidatorAddress

func (m *DelegateKeysByExternalSignerResponse) GetValidatorAddress() string

func (*DelegateKeysByExternalSignerResponse) Marshal

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

func (*DelegateKeysByExternalSignerResponse) MarshalTo

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

func (*DelegateKeysByExternalSignerResponse) MarshalToSizedBuffer

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

func (*DelegateKeysByExternalSignerResponse) ProtoMessage

func (*DelegateKeysByExternalSignerResponse) ProtoMessage()

func (*DelegateKeysByExternalSignerResponse) Reset

func (*DelegateKeysByExternalSignerResponse) Size

func (*DelegateKeysByExternalSignerResponse) String

func (*DelegateKeysByExternalSignerResponse) Unmarshal

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

func (*DelegateKeysByExternalSignerResponse) XXX_DiscardUnknown

func (m *DelegateKeysByExternalSignerResponse) XXX_DiscardUnknown()

func (*DelegateKeysByExternalSignerResponse) XXX_Marshal

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

func (*DelegateKeysByExternalSignerResponse) XXX_Merge

func (*DelegateKeysByExternalSignerResponse) XXX_Size

func (*DelegateKeysByExternalSignerResponse) XXX_Unmarshal

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

type DelegateKeysByOrchestratorRequest

type DelegateKeysByOrchestratorRequest struct {
	OrchestratorAddress string `protobuf:"bytes,1,opt,name=orchestrator_address,json=orchestratorAddress,proto3" json:"orchestrator_address,omitempty"`
	ChainId             string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*DelegateKeysByOrchestratorRequest) Descriptor

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

func (*DelegateKeysByOrchestratorRequest) GetChainId

func (m *DelegateKeysByOrchestratorRequest) GetChainId() string

func (*DelegateKeysByOrchestratorRequest) GetOrchestratorAddress

func (m *DelegateKeysByOrchestratorRequest) GetOrchestratorAddress() string

func (*DelegateKeysByOrchestratorRequest) Marshal

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

func (*DelegateKeysByOrchestratorRequest) MarshalTo

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

func (*DelegateKeysByOrchestratorRequest) MarshalToSizedBuffer

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

func (*DelegateKeysByOrchestratorRequest) ProtoMessage

func (*DelegateKeysByOrchestratorRequest) ProtoMessage()

func (*DelegateKeysByOrchestratorRequest) Reset

func (*DelegateKeysByOrchestratorRequest) Size

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

func (*DelegateKeysByOrchestratorRequest) String

func (*DelegateKeysByOrchestratorRequest) Unmarshal

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

func (*DelegateKeysByOrchestratorRequest) XXX_DiscardUnknown

func (m *DelegateKeysByOrchestratorRequest) XXX_DiscardUnknown()

func (*DelegateKeysByOrchestratorRequest) XXX_Marshal

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

func (*DelegateKeysByOrchestratorRequest) XXX_Merge

func (*DelegateKeysByOrchestratorRequest) XXX_Size

func (m *DelegateKeysByOrchestratorRequest) XXX_Size() int

func (*DelegateKeysByOrchestratorRequest) XXX_Unmarshal

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

type DelegateKeysByOrchestratorResponse

type DelegateKeysByOrchestratorResponse struct {
	ValidatorAddress string `protobuf:"bytes,1,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
	ExternalSigner   string `protobuf:"bytes,2,opt,name=external_signer,json=externalSigner,proto3" json:"external_signer,omitempty"`
}

func (*DelegateKeysByOrchestratorResponse) Descriptor

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

func (*DelegateKeysByOrchestratorResponse) GetExternalSigner

func (m *DelegateKeysByOrchestratorResponse) GetExternalSigner() string

func (*DelegateKeysByOrchestratorResponse) GetValidatorAddress

func (m *DelegateKeysByOrchestratorResponse) GetValidatorAddress() string

func (*DelegateKeysByOrchestratorResponse) Marshal

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

func (*DelegateKeysByOrchestratorResponse) MarshalTo

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

func (*DelegateKeysByOrchestratorResponse) MarshalToSizedBuffer

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

func (*DelegateKeysByOrchestratorResponse) ProtoMessage

func (*DelegateKeysByOrchestratorResponse) ProtoMessage()

func (*DelegateKeysByOrchestratorResponse) Reset

func (*DelegateKeysByOrchestratorResponse) Size

func (*DelegateKeysByOrchestratorResponse) String

func (*DelegateKeysByOrchestratorResponse) Unmarshal

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

func (*DelegateKeysByOrchestratorResponse) XXX_DiscardUnknown

func (m *DelegateKeysByOrchestratorResponse) XXX_DiscardUnknown()

func (*DelegateKeysByOrchestratorResponse) XXX_Marshal

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

func (*DelegateKeysByOrchestratorResponse) XXX_Merge

func (*DelegateKeysByOrchestratorResponse) XXX_Size

func (*DelegateKeysByOrchestratorResponse) XXX_Unmarshal

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

type DelegateKeysByValidatorRequest

type DelegateKeysByValidatorRequest struct {
	ValidatorAddress string `protobuf:"bytes,1,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
	ChainId          string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*DelegateKeysByValidatorRequest) Descriptor

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

func (*DelegateKeysByValidatorRequest) GetChainId

func (m *DelegateKeysByValidatorRequest) GetChainId() string

func (*DelegateKeysByValidatorRequest) GetValidatorAddress

func (m *DelegateKeysByValidatorRequest) GetValidatorAddress() string

func (*DelegateKeysByValidatorRequest) Marshal

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

func (*DelegateKeysByValidatorRequest) MarshalTo

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

func (*DelegateKeysByValidatorRequest) MarshalToSizedBuffer

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

func (*DelegateKeysByValidatorRequest) ProtoMessage

func (*DelegateKeysByValidatorRequest) ProtoMessage()

func (*DelegateKeysByValidatorRequest) Reset

func (m *DelegateKeysByValidatorRequest) Reset()

func (*DelegateKeysByValidatorRequest) Size

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

func (*DelegateKeysByValidatorRequest) String

func (*DelegateKeysByValidatorRequest) Unmarshal

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

func (*DelegateKeysByValidatorRequest) XXX_DiscardUnknown

func (m *DelegateKeysByValidatorRequest) XXX_DiscardUnknown()

func (*DelegateKeysByValidatorRequest) XXX_Marshal

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

func (*DelegateKeysByValidatorRequest) XXX_Merge

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

func (*DelegateKeysByValidatorRequest) XXX_Size

func (m *DelegateKeysByValidatorRequest) XXX_Size() int

func (*DelegateKeysByValidatorRequest) XXX_Unmarshal

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

type DelegateKeysByValidatorResponse

type DelegateKeysByValidatorResponse struct {
	EthAddress          string `protobuf:"bytes,1,opt,name=eth_address,json=ethAddress,proto3" json:"eth_address,omitempty"`
	OrchestratorAddress string `protobuf:"bytes,2,opt,name=orchestrator_address,json=orchestratorAddress,proto3" json:"orchestrator_address,omitempty"`
}

func (*DelegateKeysByValidatorResponse) Descriptor

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

func (*DelegateKeysByValidatorResponse) GetEthAddress

func (m *DelegateKeysByValidatorResponse) GetEthAddress() string

func (*DelegateKeysByValidatorResponse) GetOrchestratorAddress

func (m *DelegateKeysByValidatorResponse) GetOrchestratorAddress() string

func (*DelegateKeysByValidatorResponse) Marshal

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

func (*DelegateKeysByValidatorResponse) MarshalTo

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

func (*DelegateKeysByValidatorResponse) MarshalToSizedBuffer

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

func (*DelegateKeysByValidatorResponse) ProtoMessage

func (*DelegateKeysByValidatorResponse) ProtoMessage()

func (*DelegateKeysByValidatorResponse) Reset

func (*DelegateKeysByValidatorResponse) Size

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

func (*DelegateKeysByValidatorResponse) String

func (*DelegateKeysByValidatorResponse) Unmarshal

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

func (*DelegateKeysByValidatorResponse) XXX_DiscardUnknown

func (m *DelegateKeysByValidatorResponse) XXX_DiscardUnknown()

func (*DelegateKeysByValidatorResponse) XXX_Marshal

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

func (*DelegateKeysByValidatorResponse) XXX_Merge

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

func (*DelegateKeysByValidatorResponse) XXX_Size

func (m *DelegateKeysByValidatorResponse) XXX_Size() int

func (*DelegateKeysByValidatorResponse) XXX_Unmarshal

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

type DelegateKeysRequest

type DelegateKeysRequest struct {
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*DelegateKeysRequest) Descriptor

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

func (*DelegateKeysRequest) GetChainId

func (m *DelegateKeysRequest) GetChainId() string

func (*DelegateKeysRequest) Marshal

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

func (*DelegateKeysRequest) MarshalTo

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

func (*DelegateKeysRequest) MarshalToSizedBuffer

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

func (*DelegateKeysRequest) ProtoMessage

func (*DelegateKeysRequest) ProtoMessage()

func (*DelegateKeysRequest) Reset

func (m *DelegateKeysRequest) Reset()

func (*DelegateKeysRequest) Size

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

func (*DelegateKeysRequest) String

func (m *DelegateKeysRequest) String() string

func (*DelegateKeysRequest) Unmarshal

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

func (*DelegateKeysRequest) XXX_DiscardUnknown

func (m *DelegateKeysRequest) XXX_DiscardUnknown()

func (*DelegateKeysRequest) XXX_Marshal

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

func (*DelegateKeysRequest) XXX_Merge

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

func (*DelegateKeysRequest) XXX_Size

func (m *DelegateKeysRequest) XXX_Size() int

func (*DelegateKeysRequest) XXX_Unmarshal

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

type DelegateKeysResponse

type DelegateKeysResponse struct {
	DelegateKeys []*MsgDelegateKeys `protobuf:"bytes,1,rep,name=delegate_keys,json=delegateKeys,proto3" json:"delegate_keys,omitempty"`
}

func (*DelegateKeysResponse) Descriptor

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

func (*DelegateKeysResponse) GetDelegateKeys

func (m *DelegateKeysResponse) GetDelegateKeys() []*MsgDelegateKeys

func (*DelegateKeysResponse) Marshal

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

func (*DelegateKeysResponse) MarshalTo

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

func (*DelegateKeysResponse) MarshalToSizedBuffer

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

func (*DelegateKeysResponse) ProtoMessage

func (*DelegateKeysResponse) ProtoMessage()

func (*DelegateKeysResponse) Reset

func (m *DelegateKeysResponse) Reset()

func (*DelegateKeysResponse) Size

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

func (*DelegateKeysResponse) String

func (m *DelegateKeysResponse) String() string

func (*DelegateKeysResponse) Unmarshal

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

func (*DelegateKeysResponse) XXX_DiscardUnknown

func (m *DelegateKeysResponse) XXX_DiscardUnknown()

func (*DelegateKeysResponse) XXX_Marshal

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

func (*DelegateKeysResponse) XXX_Merge

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

func (*DelegateKeysResponse) XXX_Size

func (m *DelegateKeysResponse) XXX_Size() int

func (*DelegateKeysResponse) XXX_Unmarshal

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

type DelegateKeysSignMsg

type DelegateKeysSignMsg struct {
	ValidatorAddress string `protobuf:"bytes,1,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
	Nonce            uint64 `protobuf:"varint,2,opt,name=nonce,proto3" json:"nonce,omitempty"`
}

DelegateKeysSignMsg defines the message structure an operator is expected to sign when submitting a MsgDelegateKeys message. The resulting signature should populate the eth_signature field.

func (*DelegateKeysSignMsg) Descriptor

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

func (*DelegateKeysSignMsg) GetNonce

func (m *DelegateKeysSignMsg) GetNonce() uint64

func (*DelegateKeysSignMsg) GetValidatorAddress

func (m *DelegateKeysSignMsg) GetValidatorAddress() string

func (*DelegateKeysSignMsg) Marshal

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

func (*DelegateKeysSignMsg) MarshalTo

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

func (*DelegateKeysSignMsg) MarshalToSizedBuffer

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

func (*DelegateKeysSignMsg) ProtoMessage

func (*DelegateKeysSignMsg) ProtoMessage()

func (*DelegateKeysSignMsg) Reset

func (m *DelegateKeysSignMsg) Reset()

func (*DelegateKeysSignMsg) Size

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

func (*DelegateKeysSignMsg) String

func (m *DelegateKeysSignMsg) String() string

func (*DelegateKeysSignMsg) Unmarshal

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

func (*DelegateKeysSignMsg) XXX_DiscardUnknown

func (m *DelegateKeysSignMsg) XXX_DiscardUnknown()

func (*DelegateKeysSignMsg) XXX_Marshal

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

func (*DelegateKeysSignMsg) XXX_Merge

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

func (*DelegateKeysSignMsg) XXX_Size

func (m *DelegateKeysSignMsg) XXX_Size() int

func (*DelegateKeysSignMsg) XXX_Unmarshal

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

type DenomToExternalIdRequest

type DenomToExternalIdRequest struct {
	Denom   string `protobuf:"bytes,1,opt,name=denom,proto3" json:"denom,omitempty"`
	ChainId string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*DenomToExternalIdRequest) Descriptor

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

func (*DenomToExternalIdRequest) GetChainId

func (m *DenomToExternalIdRequest) GetChainId() string

func (*DenomToExternalIdRequest) GetDenom

func (m *DenomToExternalIdRequest) GetDenom() string

func (*DenomToExternalIdRequest) Marshal

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

func (*DenomToExternalIdRequest) MarshalTo

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

func (*DenomToExternalIdRequest) MarshalToSizedBuffer

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

func (*DenomToExternalIdRequest) ProtoMessage

func (*DenomToExternalIdRequest) ProtoMessage()

func (*DenomToExternalIdRequest) Reset

func (m *DenomToExternalIdRequest) Reset()

func (*DenomToExternalIdRequest) Size

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

func (*DenomToExternalIdRequest) String

func (m *DenomToExternalIdRequest) String() string

func (*DenomToExternalIdRequest) Unmarshal

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

func (*DenomToExternalIdRequest) XXX_DiscardUnknown

func (m *DenomToExternalIdRequest) XXX_DiscardUnknown()

func (*DenomToExternalIdRequest) XXX_Marshal

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

func (*DenomToExternalIdRequest) XXX_Merge

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

func (*DenomToExternalIdRequest) XXX_Size

func (m *DenomToExternalIdRequest) XXX_Size() int

func (*DenomToExternalIdRequest) XXX_Unmarshal

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

type DenomToExternalIdResponse

type DenomToExternalIdResponse struct {
	ExternalId string `protobuf:"bytes,1,opt,name=external_id,json=externalId,proto3" json:"external_id,omitempty"`
}

func (*DenomToExternalIdResponse) Descriptor

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

func (*DenomToExternalIdResponse) GetExternalId

func (m *DenomToExternalIdResponse) GetExternalId() string

func (*DenomToExternalIdResponse) Marshal

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

func (*DenomToExternalIdResponse) MarshalTo

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

func (*DenomToExternalIdResponse) MarshalToSizedBuffer

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

func (*DenomToExternalIdResponse) ProtoMessage

func (*DenomToExternalIdResponse) ProtoMessage()

func (*DenomToExternalIdResponse) Reset

func (m *DenomToExternalIdResponse) Reset()

func (*DenomToExternalIdResponse) Size

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

func (*DenomToExternalIdResponse) String

func (m *DenomToExternalIdResponse) String() string

func (*DenomToExternalIdResponse) Unmarshal

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

func (*DenomToExternalIdResponse) XXX_DiscardUnknown

func (m *DenomToExternalIdResponse) XXX_DiscardUnknown()

func (*DenomToExternalIdResponse) XXX_Marshal

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

func (*DenomToExternalIdResponse) XXX_Merge

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

func (*DenomToExternalIdResponse) XXX_Size

func (m *DenomToExternalIdResponse) XXX_Size() int

func (*DenomToExternalIdResponse) XXX_Unmarshal

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

type DiscountForHolderRequest

type DiscountForHolderRequest struct {
	Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"`
}

func (*DiscountForHolderRequest) Descriptor

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

func (*DiscountForHolderRequest) GetAddress

func (m *DiscountForHolderRequest) GetAddress() string

func (*DiscountForHolderRequest) Marshal

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

func (*DiscountForHolderRequest) MarshalTo

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

func (*DiscountForHolderRequest) MarshalToSizedBuffer

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

func (*DiscountForHolderRequest) ProtoMessage

func (*DiscountForHolderRequest) ProtoMessage()

func (*DiscountForHolderRequest) Reset

func (m *DiscountForHolderRequest) Reset()

func (*DiscountForHolderRequest) Size

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

func (*DiscountForHolderRequest) String

func (m *DiscountForHolderRequest) String() string

func (*DiscountForHolderRequest) Unmarshal

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

func (*DiscountForHolderRequest) XXX_DiscardUnknown

func (m *DiscountForHolderRequest) XXX_DiscardUnknown()

func (*DiscountForHolderRequest) XXX_Marshal

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

func (*DiscountForHolderRequest) XXX_Merge

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

func (*DiscountForHolderRequest) XXX_Size

func (m *DiscountForHolderRequest) XXX_Size() int

func (*DiscountForHolderRequest) XXX_Unmarshal

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

type DiscountForHolderResponse

type DiscountForHolderResponse struct {
	Discount github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,1,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
}

func (*DiscountForHolderResponse) Descriptor

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

func (*DiscountForHolderResponse) Marshal

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

func (*DiscountForHolderResponse) MarshalTo

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

func (*DiscountForHolderResponse) MarshalToSizedBuffer

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

func (*DiscountForHolderResponse) ProtoMessage

func (*DiscountForHolderResponse) ProtoMessage()

func (*DiscountForHolderResponse) Reset

func (m *DiscountForHolderResponse) Reset()

func (*DiscountForHolderResponse) Size

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

func (*DiscountForHolderResponse) String

func (m *DiscountForHolderResponse) String() string

func (*DiscountForHolderResponse) Unmarshal

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

func (*DiscountForHolderResponse) XXX_DiscardUnknown

func (m *DiscountForHolderResponse) XXX_DiscardUnknown()

func (*DiscountForHolderResponse) XXX_Marshal

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

func (*DiscountForHolderResponse) XXX_Merge

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

func (*DiscountForHolderResponse) XXX_Size

func (m *DiscountForHolderResponse) XXX_Size() int

func (*DiscountForHolderResponse) XXX_Unmarshal

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

type ExternalEvent

type ExternalEvent interface {
	proto.Message

	GetEventNonce() uint64
	GetExternalHeight() uint64
	Hash() tmbytes.HexBytes
	Validate(ChainID) error
}

ExternalEvent represents a event from the mhub2 contract on the counterparty ethereum chain

func UnpackEvent

func UnpackEvent(any *types.Any) (ExternalEvent, error)

UnpackEvent unpacks an Any into an ExternalEvent. It returns an error if the event can't be unpacked.

type ExternalEventVoteRecord

type ExternalEventVoteRecord struct {
	Event    *types.Any `protobuf:"bytes,1,opt,name=event,proto3" json:"event,omitempty"`
	Votes    []string   `protobuf:"bytes,2,rep,name=votes,proto3" json:"votes,omitempty"`
	Accepted bool       `protobuf:"varint,3,opt,name=accepted,proto3" json:"accepted,omitempty"`
}

ExternalEventVoteRecord is an event that is pending of confirmation by 2/3 of the signer set. The event is then attested and executed in the state machine once the required threshold is met.

func (*ExternalEventVoteRecord) Descriptor

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

func (*ExternalEventVoteRecord) GetAccepted

func (m *ExternalEventVoteRecord) GetAccepted() bool

func (*ExternalEventVoteRecord) GetEvent

func (m *ExternalEventVoteRecord) GetEvent() *types.Any

func (*ExternalEventVoteRecord) GetVotes

func (m *ExternalEventVoteRecord) GetVotes() []string

func (*ExternalEventVoteRecord) Marshal

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

func (*ExternalEventVoteRecord) MarshalTo

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

func (*ExternalEventVoteRecord) MarshalToSizedBuffer

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

func (*ExternalEventVoteRecord) ProtoMessage

func (*ExternalEventVoteRecord) ProtoMessage()

func (*ExternalEventVoteRecord) Reset

func (m *ExternalEventVoteRecord) Reset()

func (*ExternalEventVoteRecord) Size

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

func (*ExternalEventVoteRecord) String

func (m *ExternalEventVoteRecord) String() string

func (*ExternalEventVoteRecord) Unmarshal

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

func (*ExternalEventVoteRecord) UnpackInterfaces

func (m *ExternalEventVoteRecord) UnpackInterfaces(unpacker types.AnyUnpacker) error

UnpackInterfaces implements UnpackInterfacesMessage.UnpackInterfaces

func (*ExternalEventVoteRecord) XXX_DiscardUnknown

func (m *ExternalEventVoteRecord) XXX_DiscardUnknown()

func (*ExternalEventVoteRecord) XXX_Marshal

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

func (*ExternalEventVoteRecord) XXX_Merge

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

func (*ExternalEventVoteRecord) XXX_Size

func (m *ExternalEventVoteRecord) XXX_Size() int

func (*ExternalEventVoteRecord) XXX_Unmarshal

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

type ExternalIdToDenomRequest

type ExternalIdToDenomRequest struct {
	ExternalId string `protobuf:"bytes,1,opt,name=external_id,json=externalId,proto3" json:"external_id,omitempty"`
	ChainId    string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*ExternalIdToDenomRequest) Descriptor

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

func (*ExternalIdToDenomRequest) GetChainId

func (m *ExternalIdToDenomRequest) GetChainId() string

func (*ExternalIdToDenomRequest) GetExternalId

func (m *ExternalIdToDenomRequest) GetExternalId() string

func (*ExternalIdToDenomRequest) Marshal

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

func (*ExternalIdToDenomRequest) MarshalTo

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

func (*ExternalIdToDenomRequest) MarshalToSizedBuffer

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

func (*ExternalIdToDenomRequest) ProtoMessage

func (*ExternalIdToDenomRequest) ProtoMessage()

func (*ExternalIdToDenomRequest) Reset

func (m *ExternalIdToDenomRequest) Reset()

func (*ExternalIdToDenomRequest) Size

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

func (*ExternalIdToDenomRequest) String

func (m *ExternalIdToDenomRequest) String() string

func (*ExternalIdToDenomRequest) Unmarshal

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

func (*ExternalIdToDenomRequest) XXX_DiscardUnknown

func (m *ExternalIdToDenomRequest) XXX_DiscardUnknown()

func (*ExternalIdToDenomRequest) XXX_Marshal

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

func (*ExternalIdToDenomRequest) XXX_Merge

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

func (*ExternalIdToDenomRequest) XXX_Size

func (m *ExternalIdToDenomRequest) XXX_Size() int

func (*ExternalIdToDenomRequest) XXX_Unmarshal

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

type ExternalIdToDenomResponse

type ExternalIdToDenomResponse struct {
	Denom string `protobuf:"bytes,1,opt,name=denom,proto3" json:"denom,omitempty"`
}

func (*ExternalIdToDenomResponse) Descriptor

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

func (*ExternalIdToDenomResponse) GetDenom

func (m *ExternalIdToDenomResponse) GetDenom() string

func (*ExternalIdToDenomResponse) Marshal

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

func (*ExternalIdToDenomResponse) MarshalTo

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

func (*ExternalIdToDenomResponse) MarshalToSizedBuffer

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

func (*ExternalIdToDenomResponse) ProtoMessage

func (*ExternalIdToDenomResponse) ProtoMessage()

func (*ExternalIdToDenomResponse) Reset

func (m *ExternalIdToDenomResponse) Reset()

func (*ExternalIdToDenomResponse) Size

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

func (*ExternalIdToDenomResponse) String

func (m *ExternalIdToDenomResponse) String() string

func (*ExternalIdToDenomResponse) Unmarshal

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

func (*ExternalIdToDenomResponse) XXX_DiscardUnknown

func (m *ExternalIdToDenomResponse) XXX_DiscardUnknown()

func (*ExternalIdToDenomResponse) XXX_Marshal

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

func (*ExternalIdToDenomResponse) XXX_Merge

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

func (*ExternalIdToDenomResponse) XXX_Size

func (m *ExternalIdToDenomResponse) XXX_Size() int

func (*ExternalIdToDenomResponse) XXX_Unmarshal

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

type ExternalSigner

type ExternalSigner struct {
	Power           uint64 `protobuf:"varint,1,opt,name=power,proto3" json:"power,omitempty"`
	ExternalAddress string `protobuf:"bytes,2,opt,name=external_address,json=externalAddress,proto3" json:"external_address,omitempty"`
}

ExternalSigner represents a cosmos validator with its corresponding bridge operator address and its staking consensus power.

func (*ExternalSigner) Descriptor

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

func (*ExternalSigner) GetExternalAddress

func (m *ExternalSigner) GetExternalAddress() string

func (*ExternalSigner) GetPower

func (m *ExternalSigner) GetPower() uint64

func (*ExternalSigner) Marshal

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

func (*ExternalSigner) MarshalTo

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

func (*ExternalSigner) MarshalToSizedBuffer

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

func (*ExternalSigner) ProtoMessage

func (*ExternalSigner) ProtoMessage()

func (*ExternalSigner) Reset

func (m *ExternalSigner) Reset()

func (*ExternalSigner) Size

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

func (*ExternalSigner) String

func (m *ExternalSigner) String() string

func (*ExternalSigner) Unmarshal

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

func (*ExternalSigner) ValidateBasic

func (b *ExternalSigner) ValidateBasic() error

ValidateBasic performs stateless checks on validity

func (*ExternalSigner) XXX_DiscardUnknown

func (m *ExternalSigner) XXX_DiscardUnknown()

func (*ExternalSigner) XXX_Marshal

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

func (*ExternalSigner) XXX_Merge

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

func (*ExternalSigner) XXX_Size

func (m *ExternalSigner) XXX_Size() int

func (*ExternalSigner) XXX_Unmarshal

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

type ExternalSigners

type ExternalSigners []*ExternalSigner

ExternalSigners is the sorted set of validator data for Ethereum bridge MultiSig set

func (ExternalSigners) GetPowers

func (b ExternalSigners) GetPowers() []uint64

GetPowers returns only the power values for all members

func (ExternalSigners) Hash

func (b ExternalSigners) Hash() []byte

Hash takes the sha256sum of a representation of the signer set

func (ExternalSigners) PowerDiff

func (b ExternalSigners) PowerDiff(c ExternalSigners) float64

PowerDiff returns the difference in power between two bridge validator sets note this is Mhub2 bridge power *not* Cosmos voting power. Cosmos voting power is based on the absolute number of tokens in the staking pool at any given time Mhub2 bridge power is normalized using the equation.

validators cosmos voting power / total cosmos voting power in this block = mhub2 bridge power / u32_max

As an example if someone has 52% of the Cosmos voting power when a validator set is created their Mhub2 bridge voting power is u32_max * .52

Normalized voting power dramatically reduces how often we have to produce new validator set updates. For example if the total on chain voting power increases by 1% due to inflation, we shouldn't have to generate a new validator set, after all the validators retained their relative percentages during inflation and normalized Mhub2 bridge power shows no difference.

func (ExternalSigners) Sort

func (b ExternalSigners) Sort()

Sort sorts the validators by power

func (ExternalSigners) TotalPower

func (b ExternalSigners) TotalPower() (out uint64)

TotalPower returns the total power in the bridge validator set

type ExternalState

type ExternalState struct {
	ChainId                    string                     `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	ExternalEventVoteRecords   []*ExternalEventVoteRecord `` /* 137-byte string literal not displayed */
	DelegateKeys               []*MsgDelegateKeys         `protobuf:"bytes,3,rep,name=delegate_keys,json=delegateKeys,proto3" json:"delegate_keys,omitempty"`
	UnbatchedSendToExternalTxs []*SendToExternal          `` /* 145-byte string literal not displayed */
	LastObservedEventNonce     uint64                     `` /* 132-byte string literal not displayed */
	OutgoingTxs                []*types.Any               `protobuf:"bytes,6,rep,name=outgoing_txs,json=outgoingTxs,proto3" json:"outgoing_txs,omitempty"`
	Confirmations              []*types.Any               `protobuf:"bytes,7,rep,name=confirmations,proto3" json:"confirmations,omitempty"`
	Sequence                   uint64                     `protobuf:"varint,8,opt,name=sequence,proto3" json:"sequence,omitempty"`
	Nonces                     []*Nonce                   `protobuf:"bytes,9,rep,name=nonces,proto3" json:"nonces,omitempty"`
	LastObservedValset         *SignerSetTx               `protobuf:"bytes,10,opt,name=last_observed_valset,json=lastObservedValset,proto3" json:"last_observed_valset,omitempty"`
	LastOutgoingBatchTxNonce   uint64                     `` /* 141-byte string literal not displayed */
	LatestBlockHeight          LatestBlockHeight          `protobuf:"bytes,12,opt,name=latest_block_height,json=latestBlockHeight,proto3" json:"latest_block_height"`
}

func (*ExternalState) Descriptor

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

func (*ExternalState) GetChainId

func (m *ExternalState) GetChainId() string

func (*ExternalState) GetConfirmations

func (m *ExternalState) GetConfirmations() []*types.Any

func (*ExternalState) GetDelegateKeys

func (m *ExternalState) GetDelegateKeys() []*MsgDelegateKeys

func (*ExternalState) GetExternalEventVoteRecords

func (m *ExternalState) GetExternalEventVoteRecords() []*ExternalEventVoteRecord

func (*ExternalState) GetLastObservedEventNonce

func (m *ExternalState) GetLastObservedEventNonce() uint64

func (*ExternalState) GetLastObservedValset

func (m *ExternalState) GetLastObservedValset() *SignerSetTx

func (*ExternalState) GetLastOutgoingBatchTxNonce

func (m *ExternalState) GetLastOutgoingBatchTxNonce() uint64

func (*ExternalState) GetLatestBlockHeight

func (m *ExternalState) GetLatestBlockHeight() LatestBlockHeight

func (*ExternalState) GetNonces

func (m *ExternalState) GetNonces() []*Nonce

func (*ExternalState) GetOutgoingTxs

func (m *ExternalState) GetOutgoingTxs() []*types.Any

func (*ExternalState) GetSequence

func (m *ExternalState) GetSequence() uint64

func (*ExternalState) GetUnbatchedSendToExternalTxs

func (m *ExternalState) GetUnbatchedSendToExternalTxs() []*SendToExternal

func (*ExternalState) Marshal

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

func (*ExternalState) MarshalTo

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

func (*ExternalState) MarshalToSizedBuffer

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

func (*ExternalState) ProtoMessage

func (*ExternalState) ProtoMessage()

func (*ExternalState) Reset

func (m *ExternalState) Reset()

func (*ExternalState) Size

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

func (*ExternalState) String

func (m *ExternalState) String() string

func (*ExternalState) Unmarshal

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

func (*ExternalState) XXX_DiscardUnknown

func (m *ExternalState) XXX_DiscardUnknown()

func (*ExternalState) XXX_Marshal

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

func (*ExternalState) XXX_Merge

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

func (*ExternalState) XXX_Size

func (m *ExternalState) XXX_Size() int

func (*ExternalState) XXX_Unmarshal

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

type ExternalToken

type ExternalToken struct {
	TokenId         uint64                                 `protobuf:"varint,1,opt,name=token_id,json=tokenId,proto3" json:"token_id,omitempty"`
	ExternalTokenId string                                 `protobuf:"bytes,2,opt,name=external_token_id,json=externalTokenId,proto3" json:"external_token_id,omitempty"`
	Amount          github_com_cosmos_cosmos_sdk_types.Int `protobuf:"bytes,3,opt,name=amount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Int" json:"amount"`
}

func NewExternalToken

func NewExternalToken(amount uint64, id uint64, externalId string) ExternalToken

NewExternalToken returns a new instance of an external token

func NewSDKIntExternalToken

func NewSDKIntExternalToken(amount sdk.Int, id uint64, externalId string) ExternalToken

func (*ExternalToken) Descriptor

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

func (*ExternalToken) GetExternalTokenId

func (m *ExternalToken) GetExternalTokenId() string

func (*ExternalToken) GetTokenId

func (m *ExternalToken) GetTokenId() uint64

func (ExternalToken) HubCoin

func (e ExternalToken) HubCoin(denomResolver func(id uint64) (string, error)) sdk.Coin

HubCoin returns the mhub2 representation of the External Token

func (*ExternalToken) Marshal

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

func (*ExternalToken) MarshalTo

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

func (*ExternalToken) MarshalToSizedBuffer

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

func (*ExternalToken) ProtoMessage

func (*ExternalToken) ProtoMessage()

func (*ExternalToken) Reset

func (m *ExternalToken) Reset()

func (*ExternalToken) Size

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

func (*ExternalToken) String

func (m *ExternalToken) String() string

func (*ExternalToken) Unmarshal

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

func (*ExternalToken) XXX_DiscardUnknown

func (m *ExternalToken) XXX_DiscardUnknown()

func (*ExternalToken) XXX_Marshal

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

func (*ExternalToken) XXX_Merge

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

func (*ExternalToken) XXX_Size

func (m *ExternalToken) XXX_Size() int

func (*ExternalToken) XXX_Unmarshal

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

type ExternalTxConfirmation

type ExternalTxConfirmation interface {
	proto.Message

	GetSigner() common.Address
	GetSignature() []byte
	GetStoreIndex(chainId ChainID) []byte
	Validate() error
}

ExternalTxConfirmation represents one validators signature for a given outgoing ethereum transaction

func UnpackConfirmation

func UnpackConfirmation(any *types.Any) (ExternalTxConfirmation, error)

UnpackConfirmation unpacks an Any into a Confirm interface. It returns an error if the confirm can't be unpacked.

type GenesisState

type GenesisState struct {
	Params         *Params          `protobuf:"bytes,1,opt,name=params,proto3" json:"params,omitempty"`
	ExternalStates []*ExternalState `protobuf:"bytes,5,rep,name=external_states,json=externalStates,proto3" json:"external_states,omitempty"`
	TokenInfos     *TokenInfos      `protobuf:"bytes,6,opt,name=token_infos,json=tokenInfos,proto3" json:"token_infos,omitempty"`
}

GenesisState struct TODO: this need to be audited and potentially simplified using the new interfaces

func DefaultGenesisState

func DefaultGenesisState() *GenesisState

DefaultGenesisState returns empty genesis state TODO: set some better defaults here

func GetGenesisStateFromAppState

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

func (*GenesisState) Descriptor

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

func (*GenesisState) GetExternalStates

func (m *GenesisState) GetExternalStates() []*ExternalState

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() *Params

func (*GenesisState) GetTokenInfos

func (m *GenesisState) GetTokenInfos() *TokenInfos

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) UnpackInterfaces

func (gs *GenesisState) UnpackInterfaces(unpacker cdctypes.AnyUnpacker) error

func (GenesisState) ValidateBasic

func (s GenesisState) ValidateBasic() error

ValidateBasic validates genesis state by looping through the params and calling their validation functions

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 IDSet

type IDSet struct {
	Ids []uint64 `protobuf:"varint,1,rep,packed,name=ids,proto3" json:"ids,omitempty"`
}

func (*IDSet) Descriptor

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

func (*IDSet) GetIds

func (m *IDSet) GetIds() []uint64

func (*IDSet) Marshal

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

func (*IDSet) MarshalTo

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

func (*IDSet) MarshalToSizedBuffer

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

func (*IDSet) ProtoMessage

func (*IDSet) ProtoMessage()

func (*IDSet) Reset

func (m *IDSet) Reset()

func (*IDSet) Size

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

func (*IDSet) String

func (m *IDSet) String() string

func (*IDSet) Unmarshal

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

func (*IDSet) XXX_DiscardUnknown

func (m *IDSet) XXX_DiscardUnknown()

func (*IDSet) XXX_Marshal

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

func (*IDSet) XXX_Merge

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

func (*IDSet) XXX_Size

func (m *IDSet) XXX_Size() int

func (*IDSet) XXX_Unmarshal

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

type LastObservedSignerSetTxRequest

type LastObservedSignerSetTxRequest struct {
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*LastObservedSignerSetTxRequest) Descriptor

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

func (*LastObservedSignerSetTxRequest) GetChainId

func (m *LastObservedSignerSetTxRequest) GetChainId() string

func (*LastObservedSignerSetTxRequest) Marshal

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

func (*LastObservedSignerSetTxRequest) MarshalTo

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

func (*LastObservedSignerSetTxRequest) MarshalToSizedBuffer

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

func (*LastObservedSignerSetTxRequest) ProtoMessage

func (*LastObservedSignerSetTxRequest) ProtoMessage()

func (*LastObservedSignerSetTxRequest) Reset

func (m *LastObservedSignerSetTxRequest) Reset()

func (*LastObservedSignerSetTxRequest) Size

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

func (*LastObservedSignerSetTxRequest) String

func (*LastObservedSignerSetTxRequest) Unmarshal

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

func (*LastObservedSignerSetTxRequest) XXX_DiscardUnknown

func (m *LastObservedSignerSetTxRequest) XXX_DiscardUnknown()

func (*LastObservedSignerSetTxRequest) XXX_Marshal

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

func (*LastObservedSignerSetTxRequest) XXX_Merge

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

func (*LastObservedSignerSetTxRequest) XXX_Size

func (m *LastObservedSignerSetTxRequest) XXX_Size() int

func (*LastObservedSignerSetTxRequest) XXX_Unmarshal

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

type LastSubmittedExternalEventRequest

type LastSubmittedExternalEventRequest struct {
	Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"`
	ChainId string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*LastSubmittedExternalEventRequest) Descriptor

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

func (*LastSubmittedExternalEventRequest) GetAddress

func (m *LastSubmittedExternalEventRequest) GetAddress() string

func (*LastSubmittedExternalEventRequest) GetChainId

func (m *LastSubmittedExternalEventRequest) GetChainId() string

func (*LastSubmittedExternalEventRequest) Marshal

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

func (*LastSubmittedExternalEventRequest) MarshalTo

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

func (*LastSubmittedExternalEventRequest) MarshalToSizedBuffer

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

func (*LastSubmittedExternalEventRequest) ProtoMessage

func (*LastSubmittedExternalEventRequest) ProtoMessage()

func (*LastSubmittedExternalEventRequest) Reset

func (*LastSubmittedExternalEventRequest) Size

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

func (*LastSubmittedExternalEventRequest) String

func (*LastSubmittedExternalEventRequest) Unmarshal

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

func (*LastSubmittedExternalEventRequest) XXX_DiscardUnknown

func (m *LastSubmittedExternalEventRequest) XXX_DiscardUnknown()

func (*LastSubmittedExternalEventRequest) XXX_Marshal

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

func (*LastSubmittedExternalEventRequest) XXX_Merge

func (*LastSubmittedExternalEventRequest) XXX_Size

func (m *LastSubmittedExternalEventRequest) XXX_Size() int

func (*LastSubmittedExternalEventRequest) XXX_Unmarshal

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

type LastSubmittedExternalEventResponse

type LastSubmittedExternalEventResponse struct {
	EventNonce uint64 `protobuf:"varint,1,opt,name=event_nonce,json=eventNonce,proto3" json:"event_nonce,omitempty"`
}

func (*LastSubmittedExternalEventResponse) Descriptor

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

func (*LastSubmittedExternalEventResponse) GetEventNonce

func (m *LastSubmittedExternalEventResponse) GetEventNonce() uint64

func (*LastSubmittedExternalEventResponse) Marshal

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

func (*LastSubmittedExternalEventResponse) MarshalTo

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

func (*LastSubmittedExternalEventResponse) MarshalToSizedBuffer

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

func (*LastSubmittedExternalEventResponse) ProtoMessage

func (*LastSubmittedExternalEventResponse) ProtoMessage()

func (*LastSubmittedExternalEventResponse) Reset

func (*LastSubmittedExternalEventResponse) Size

func (*LastSubmittedExternalEventResponse) String

func (*LastSubmittedExternalEventResponse) Unmarshal

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

func (*LastSubmittedExternalEventResponse) XXX_DiscardUnknown

func (m *LastSubmittedExternalEventResponse) XXX_DiscardUnknown()

func (*LastSubmittedExternalEventResponse) XXX_Marshal

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

func (*LastSubmittedExternalEventResponse) XXX_Merge

func (*LastSubmittedExternalEventResponse) XXX_Size

func (*LastSubmittedExternalEventResponse) XXX_Unmarshal

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

type LatestBlockHeight

type LatestBlockHeight struct {
	ExternalHeight uint64 `protobuf:"varint,1,opt,name=external_height,json=externalHeight,proto3" json:"external_height,omitempty"`
	CosmosHeight   uint64 `protobuf:"varint,2,opt,name=cosmos_height,json=cosmosHeight,proto3" json:"cosmos_height,omitempty"`
}

LatestBlockHeight defines the latest observed external block height and the corresponding timestamp value in nanoseconds.

func (*LatestBlockHeight) Descriptor

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

func (*LatestBlockHeight) GetCosmosHeight

func (m *LatestBlockHeight) GetCosmosHeight() uint64

func (*LatestBlockHeight) GetExternalHeight

func (m *LatestBlockHeight) GetExternalHeight() uint64

func (*LatestBlockHeight) Marshal

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

func (*LatestBlockHeight) MarshalTo

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

func (*LatestBlockHeight) MarshalToSizedBuffer

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

func (*LatestBlockHeight) ProtoMessage

func (*LatestBlockHeight) ProtoMessage()

func (*LatestBlockHeight) Reset

func (m *LatestBlockHeight) Reset()

func (*LatestBlockHeight) Size

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

func (*LatestBlockHeight) String

func (m *LatestBlockHeight) String() string

func (*LatestBlockHeight) Unmarshal

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

func (*LatestBlockHeight) XXX_DiscardUnknown

func (m *LatestBlockHeight) XXX_DiscardUnknown()

func (*LatestBlockHeight) XXX_Marshal

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

func (*LatestBlockHeight) XXX_Merge

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

func (*LatestBlockHeight) XXX_Size

func (m *LatestBlockHeight) XXX_Size() int

func (*LatestBlockHeight) XXX_Unmarshal

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

type LatestSignerSetTxRequest

type LatestSignerSetTxRequest struct {
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*LatestSignerSetTxRequest) Descriptor

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

func (*LatestSignerSetTxRequest) GetChainId

func (m *LatestSignerSetTxRequest) GetChainId() string

func (*LatestSignerSetTxRequest) Marshal

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

func (*LatestSignerSetTxRequest) MarshalTo

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

func (*LatestSignerSetTxRequest) MarshalToSizedBuffer

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

func (*LatestSignerSetTxRequest) ProtoMessage

func (*LatestSignerSetTxRequest) ProtoMessage()

func (*LatestSignerSetTxRequest) Reset

func (m *LatestSignerSetTxRequest) Reset()

func (*LatestSignerSetTxRequest) Size

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

func (*LatestSignerSetTxRequest) String

func (m *LatestSignerSetTxRequest) String() string

func (*LatestSignerSetTxRequest) Unmarshal

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

func (*LatestSignerSetTxRequest) XXX_DiscardUnknown

func (m *LatestSignerSetTxRequest) XXX_DiscardUnknown()

func (*LatestSignerSetTxRequest) XXX_Marshal

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

func (*LatestSignerSetTxRequest) XXX_Merge

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

func (*LatestSignerSetTxRequest) XXX_Size

func (m *LatestSignerSetTxRequest) XXX_Size() int

func (*LatestSignerSetTxRequest) XXX_Unmarshal

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

type MhubHooks

type MhubHooks interface {
	AfterContractCallExecutedEvent(ctx sdk.Context, event ContractCallExecutedEvent)
	AfterSignerSetExecutedEvent(ctx sdk.Context, event SignerSetTxExecutedEvent)
	AfterBatchExecutedEvent(ctx sdk.Context, event BatchExecutedEvent)
	AfterSendToHubEvent(ctx sdk.Context, event SendToHubEvent)
}

type MsgCancelSendToExternal

type MsgCancelSendToExternal struct {
	Id      uint64 `protobuf:"varint,1,opt,name=id,proto3" json:"id,omitempty"`
	Sender  string `protobuf:"bytes,2,opt,name=sender,proto3" json:"sender,omitempty"`
	ChainId string `protobuf:"bytes,3,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

MsgCancelSendToExternal allows the sender to cancel its own outgoing SendToExternal tx and recieve a refund of the tokens and bridge fees. This tx will only succeed if the SendToExternal tx hasn't been batched to be processed and relayed to External.

func NewMsgCancelSendToExternal

func NewMsgCancelSendToExternal(id uint64, chainId ChainID, orchestrator sdk.AccAddress) *MsgCancelSendToExternal

NewMsgCancelSendToExternal returns a new MsgCancelSendToEthereum

func (*MsgCancelSendToExternal) Descriptor

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

func (*MsgCancelSendToExternal) GetChainId

func (m *MsgCancelSendToExternal) GetChainId() string

func (*MsgCancelSendToExternal) GetId

func (m *MsgCancelSendToExternal) GetId() uint64

func (*MsgCancelSendToExternal) GetSender

func (m *MsgCancelSendToExternal) GetSender() string

func (MsgCancelSendToExternal) GetSignBytes

func (msg MsgCancelSendToExternal) GetSignBytes() []byte

GetSignBytes encodes the message for signing

func (MsgCancelSendToExternal) GetSigners

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

GetSigners defines whose signature is required

func (*MsgCancelSendToExternal) Marshal

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

func (*MsgCancelSendToExternal) MarshalTo

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

func (*MsgCancelSendToExternal) MarshalToSizedBuffer

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

func (*MsgCancelSendToExternal) ProtoMessage

func (*MsgCancelSendToExternal) ProtoMessage()

func (*MsgCancelSendToExternal) Reset

func (m *MsgCancelSendToExternal) Reset()

func (MsgCancelSendToExternal) Route

func (msg MsgCancelSendToExternal) Route() string

Route should return the name of the module

func (*MsgCancelSendToExternal) Size

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

func (*MsgCancelSendToExternal) String

func (m *MsgCancelSendToExternal) String() string

func (MsgCancelSendToExternal) Type

func (msg MsgCancelSendToExternal) Type() string

Type should return the action

func (*MsgCancelSendToExternal) Unmarshal

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

func (MsgCancelSendToExternal) ValidateBasic

func (msg MsgCancelSendToExternal) ValidateBasic() error

ValidateBasic performs stateless checks

func (*MsgCancelSendToExternal) XXX_DiscardUnknown

func (m *MsgCancelSendToExternal) XXX_DiscardUnknown()

func (*MsgCancelSendToExternal) XXX_Marshal

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

func (*MsgCancelSendToExternal) XXX_Merge

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

func (*MsgCancelSendToExternal) XXX_Size

func (m *MsgCancelSendToExternal) XXX_Size() int

func (*MsgCancelSendToExternal) XXX_Unmarshal

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

type MsgCancelSendToExternalResponse

type MsgCancelSendToExternalResponse struct {
}

func (*MsgCancelSendToExternalResponse) Descriptor

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

func (*MsgCancelSendToExternalResponse) Marshal

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

func (*MsgCancelSendToExternalResponse) MarshalTo

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

func (*MsgCancelSendToExternalResponse) MarshalToSizedBuffer

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

func (*MsgCancelSendToExternalResponse) ProtoMessage

func (*MsgCancelSendToExternalResponse) ProtoMessage()

func (*MsgCancelSendToExternalResponse) Reset

func (*MsgCancelSendToExternalResponse) Size

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

func (*MsgCancelSendToExternalResponse) String

func (*MsgCancelSendToExternalResponse) Unmarshal

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

func (*MsgCancelSendToExternalResponse) XXX_DiscardUnknown

func (m *MsgCancelSendToExternalResponse) XXX_DiscardUnknown()

func (*MsgCancelSendToExternalResponse) XXX_Marshal

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

func (*MsgCancelSendToExternalResponse) XXX_Merge

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

func (*MsgCancelSendToExternalResponse) XXX_Size

func (m *MsgCancelSendToExternalResponse) XXX_Size() int

func (*MsgCancelSendToExternalResponse) XXX_Unmarshal

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

type MsgClient

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 MsgDelegateKeys

type MsgDelegateKeys struct {
	ValidatorAddress    string `protobuf:"bytes,1,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
	OrchestratorAddress string `protobuf:"bytes,2,opt,name=orchestrator_address,json=orchestratorAddress,proto3" json:"orchestrator_address,omitempty"`
	ExternalAddress     string `protobuf:"bytes,3,opt,name=external_address,json=externalAddress,proto3" json:"external_address,omitempty"`
	EthSignature        []byte `protobuf:"bytes,4,opt,name=eth_signature,json=ethSignature,proto3" json:"eth_signature,omitempty"`
	ChainId             string `protobuf:"bytes,5,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

MsgDelegateKey allows validators to delegate their voting responsibilities to a given orchestrator address. This key is then used as an optional authentication method for attesting events from External Chain.

func NewMsgDelegateKeys

func NewMsgDelegateKeys(val sdk.ValAddress, chainId ChainID, orchAddr sdk.AccAddress, ethAddr string, ethSig []byte) *MsgDelegateKeys

NewMsgDelegateKeys returns a reference to a new MsgDelegateKeys.

func (*MsgDelegateKeys) Descriptor

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

func (*MsgDelegateKeys) GetChainId

func (m *MsgDelegateKeys) GetChainId() string

func (*MsgDelegateKeys) GetEthSignature

func (m *MsgDelegateKeys) GetEthSignature() []byte

func (*MsgDelegateKeys) GetExternalAddress

func (m *MsgDelegateKeys) GetExternalAddress() string

func (*MsgDelegateKeys) GetOrchestratorAddress

func (m *MsgDelegateKeys) GetOrchestratorAddress() string

func (*MsgDelegateKeys) GetSignBytes

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

GetSignBytes encodes the message for signing

func (*MsgDelegateKeys) GetSigners

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

GetSigners defines whose signature is required

func (*MsgDelegateKeys) GetValidatorAddress

func (m *MsgDelegateKeys) GetValidatorAddress() string

func (*MsgDelegateKeys) Marshal

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

func (*MsgDelegateKeys) MarshalTo

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

func (*MsgDelegateKeys) MarshalToSizedBuffer

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

func (*MsgDelegateKeys) ProtoMessage

func (*MsgDelegateKeys) ProtoMessage()

func (*MsgDelegateKeys) Reset

func (m *MsgDelegateKeys) Reset()

func (*MsgDelegateKeys) Route

func (msg *MsgDelegateKeys) Route() string

Route should return the name of the module

func (*MsgDelegateKeys) Size

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

func (*MsgDelegateKeys) String

func (m *MsgDelegateKeys) String() string

func (*MsgDelegateKeys) Type

func (msg *MsgDelegateKeys) Type() string

Type should return the action

func (*MsgDelegateKeys) Unmarshal

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

func (*MsgDelegateKeys) ValidateBasic

func (msg *MsgDelegateKeys) ValidateBasic() (err error)

ValidateBasic performs stateless checks

func (*MsgDelegateKeys) XXX_DiscardUnknown

func (m *MsgDelegateKeys) XXX_DiscardUnknown()

func (*MsgDelegateKeys) XXX_Marshal

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

func (*MsgDelegateKeys) XXX_Merge

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

func (*MsgDelegateKeys) XXX_Size

func (m *MsgDelegateKeys) XXX_Size() int

func (*MsgDelegateKeys) XXX_Unmarshal

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

type MsgDelegateKeysResponse

type MsgDelegateKeysResponse struct {
}

func (*MsgDelegateKeysResponse) Descriptor

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

func (*MsgDelegateKeysResponse) Marshal

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

func (*MsgDelegateKeysResponse) MarshalTo

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

func (*MsgDelegateKeysResponse) MarshalToSizedBuffer

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

func (*MsgDelegateKeysResponse) ProtoMessage

func (*MsgDelegateKeysResponse) ProtoMessage()

func (*MsgDelegateKeysResponse) Reset

func (m *MsgDelegateKeysResponse) Reset()

func (*MsgDelegateKeysResponse) Size

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

func (*MsgDelegateKeysResponse) String

func (m *MsgDelegateKeysResponse) String() string

func (*MsgDelegateKeysResponse) Unmarshal

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

func (*MsgDelegateKeysResponse) XXX_DiscardUnknown

func (m *MsgDelegateKeysResponse) XXX_DiscardUnknown()

func (*MsgDelegateKeysResponse) XXX_Marshal

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

func (*MsgDelegateKeysResponse) XXX_Merge

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

func (*MsgDelegateKeysResponse) XXX_Size

func (m *MsgDelegateKeysResponse) XXX_Size() int

func (*MsgDelegateKeysResponse) XXX_Unmarshal

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

type MsgRequestBatchTx

type MsgRequestBatchTx struct {
	Denom   string `protobuf:"bytes,1,opt,name=denom,proto3" json:"denom,omitempty"`
	Signer  string `protobuf:"bytes,2,opt,name=signer,proto3" json:"signer,omitempty"`
	ChainId string `protobuf:"bytes,3,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

MsgRequestBatchTx requests a batch of transactions with a given coin denomination to send across the bridge to external chain.

func NewMsgRequestBatchTx

func NewMsgRequestBatchTx(denom string, signer sdk.AccAddress) *MsgRequestBatchTx

NewMsgRequestBatchTx returns a new msgRequestBatch

func (*MsgRequestBatchTx) Descriptor

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

func (*MsgRequestBatchTx) GetChainId

func (m *MsgRequestBatchTx) GetChainId() string

func (*MsgRequestBatchTx) GetDenom

func (m *MsgRequestBatchTx) GetDenom() string

func (MsgRequestBatchTx) GetSignBytes

func (msg MsgRequestBatchTx) GetSignBytes() []byte

GetSignBytes encodes the message for signing

func (*MsgRequestBatchTx) GetSigner

func (m *MsgRequestBatchTx) GetSigner() string

func (MsgRequestBatchTx) GetSigners

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

GetSigners defines whose signature is required

func (*MsgRequestBatchTx) Marshal

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

func (*MsgRequestBatchTx) MarshalTo

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

func (*MsgRequestBatchTx) MarshalToSizedBuffer

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

func (*MsgRequestBatchTx) ProtoMessage

func (*MsgRequestBatchTx) ProtoMessage()

func (*MsgRequestBatchTx) Reset

func (m *MsgRequestBatchTx) Reset()

func (MsgRequestBatchTx) Route

func (msg MsgRequestBatchTx) Route() string

Route should return the name of the module

func (*MsgRequestBatchTx) Size

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

func (*MsgRequestBatchTx) String

func (m *MsgRequestBatchTx) String() string

func (MsgRequestBatchTx) Type

func (msg MsgRequestBatchTx) Type() string

Type should return the action

func (*MsgRequestBatchTx) Unmarshal

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

func (MsgRequestBatchTx) ValidateBasic

func (msg MsgRequestBatchTx) ValidateBasic() error

ValidateBasic performs stateless checks

func (*MsgRequestBatchTx) XXX_DiscardUnknown

func (m *MsgRequestBatchTx) XXX_DiscardUnknown()

func (*MsgRequestBatchTx) XXX_Marshal

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

func (*MsgRequestBatchTx) XXX_Merge

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

func (*MsgRequestBatchTx) XXX_Size

func (m *MsgRequestBatchTx) XXX_Size() int

func (*MsgRequestBatchTx) XXX_Unmarshal

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

type MsgRequestBatchTxResponse

type MsgRequestBatchTxResponse struct {
}

func (*MsgRequestBatchTxResponse) Descriptor

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

func (*MsgRequestBatchTxResponse) Marshal

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

func (*MsgRequestBatchTxResponse) MarshalTo

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

func (*MsgRequestBatchTxResponse) MarshalToSizedBuffer

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

func (*MsgRequestBatchTxResponse) ProtoMessage

func (*MsgRequestBatchTxResponse) ProtoMessage()

func (*MsgRequestBatchTxResponse) Reset

func (m *MsgRequestBatchTxResponse) Reset()

func (*MsgRequestBatchTxResponse) Size

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

func (*MsgRequestBatchTxResponse) String

func (m *MsgRequestBatchTxResponse) String() string

func (*MsgRequestBatchTxResponse) Unmarshal

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

func (*MsgRequestBatchTxResponse) XXX_DiscardUnknown

func (m *MsgRequestBatchTxResponse) XXX_DiscardUnknown()

func (*MsgRequestBatchTxResponse) XXX_Marshal

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

func (*MsgRequestBatchTxResponse) XXX_Merge

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

func (*MsgRequestBatchTxResponse) XXX_Size

func (m *MsgRequestBatchTxResponse) XXX_Size() int

func (*MsgRequestBatchTxResponse) XXX_Unmarshal

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

type MsgSendToExternal

type MsgSendToExternal struct {
	Sender            string     `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty"`
	ExternalRecipient string     `protobuf:"bytes,2,opt,name=external_recipient,json=externalRecipient,proto3" json:"external_recipient,omitempty"`
	Amount            types.Coin `protobuf:"bytes,3,opt,name=amount,proto3" json:"amount"`
	BridgeFee         types.Coin `protobuf:"bytes,4,opt,name=bridge_fee,json=bridgeFee,proto3" json:"bridge_fee"`
	ChainId           string     `protobuf:"bytes,5,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

MsgSendToExternal submits a SendToExternal attempt to bridge an asset over to External chain. The SendToExternal will be stored and then included in a batch and then submitted to external chain.

func NewMsgSendToExternal

func NewMsgSendToExternal(chainId ChainID, sender sdk.AccAddress, destAddress string, send sdk.Coin, bridgeFee sdk.Coin) *MsgSendToExternal

NewMsgSendToExternal returns a new MsgSendToEthereum

func (*MsgSendToExternal) Descriptor

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

func (*MsgSendToExternal) GetAmount

func (m *MsgSendToExternal) GetAmount() types.Coin

func (*MsgSendToExternal) GetBridgeFee

func (m *MsgSendToExternal) GetBridgeFee() types.Coin

func (*MsgSendToExternal) GetChainId

func (m *MsgSendToExternal) GetChainId() string

func (*MsgSendToExternal) GetExternalRecipient

func (m *MsgSendToExternal) GetExternalRecipient() string

func (*MsgSendToExternal) GetSender

func (m *MsgSendToExternal) GetSender() string

func (MsgSendToExternal) GetSignBytes

func (msg MsgSendToExternal) GetSignBytes() []byte

GetSignBytes encodes the message for signing

func (MsgSendToExternal) GetSigners

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

GetSigners defines whose signature is required

func (*MsgSendToExternal) Marshal

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

func (*MsgSendToExternal) MarshalTo

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

func (*MsgSendToExternal) MarshalToSizedBuffer

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

func (*MsgSendToExternal) ProtoMessage

func (*MsgSendToExternal) ProtoMessage()

func (*MsgSendToExternal) Reset

func (m *MsgSendToExternal) Reset()

func (MsgSendToExternal) Route

func (msg MsgSendToExternal) Route() string

Route should return the name of the module

func (*MsgSendToExternal) Size

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

func (*MsgSendToExternal) String

func (m *MsgSendToExternal) String() string

func (MsgSendToExternal) Type

func (msg MsgSendToExternal) Type() string

Type should return the action

func (*MsgSendToExternal) Unmarshal

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

func (MsgSendToExternal) ValidateBasic

func (msg MsgSendToExternal) ValidateBasic() error

ValidateBasic runs stateless checks on the message Checks if the Eth address is valid

func (*MsgSendToExternal) XXX_DiscardUnknown

func (m *MsgSendToExternal) XXX_DiscardUnknown()

func (*MsgSendToExternal) XXX_Marshal

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

func (*MsgSendToExternal) XXX_Merge

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

func (*MsgSendToExternal) XXX_Size

func (m *MsgSendToExternal) XXX_Size() int

func (*MsgSendToExternal) XXX_Unmarshal

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

type MsgSendToExternalResponse

type MsgSendToExternalResponse struct {
	Id uint64 `protobuf:"varint,1,opt,name=id,proto3" json:"id,omitempty"`
}

MsgSendToExternalResponse returns the SendToExternal transaction ID which will be included in the batch tx.

func (*MsgSendToExternalResponse) Descriptor

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

func (*MsgSendToExternalResponse) GetId

func (m *MsgSendToExternalResponse) GetId() uint64

func (*MsgSendToExternalResponse) Marshal

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

func (*MsgSendToExternalResponse) MarshalTo

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

func (*MsgSendToExternalResponse) MarshalToSizedBuffer

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

func (*MsgSendToExternalResponse) ProtoMessage

func (*MsgSendToExternalResponse) ProtoMessage()

func (*MsgSendToExternalResponse) Reset

func (m *MsgSendToExternalResponse) Reset()

func (*MsgSendToExternalResponse) Size

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

func (*MsgSendToExternalResponse) String

func (m *MsgSendToExternalResponse) String() string

func (*MsgSendToExternalResponse) Unmarshal

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

func (*MsgSendToExternalResponse) XXX_DiscardUnknown

func (m *MsgSendToExternalResponse) XXX_DiscardUnknown()

func (*MsgSendToExternalResponse) XXX_Marshal

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

func (*MsgSendToExternalResponse) XXX_Merge

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

func (*MsgSendToExternalResponse) XXX_Size

func (m *MsgSendToExternalResponse) XXX_Size() int

func (*MsgSendToExternalResponse) XXX_Unmarshal

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

type MsgSubmitExternalEvent

type MsgSubmitExternalEvent struct {
	Event   *types1.Any `protobuf:"bytes,1,opt,name=event,proto3" json:"event,omitempty"`
	Signer  string      `protobuf:"bytes,2,opt,name=signer,proto3" json:"signer,omitempty"`
	ChainId string      `protobuf:"bytes,3,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

MsgSubmitExternalEvent

func (*MsgSubmitExternalEvent) Descriptor

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

func (*MsgSubmitExternalEvent) GetSignBytes

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

GetSignBytes encodes the message for signing

func (*MsgSubmitExternalEvent) GetSigners

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

GetSigners defines whose signature is required

func (*MsgSubmitExternalEvent) Marshal

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

func (*MsgSubmitExternalEvent) MarshalTo

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

func (*MsgSubmitExternalEvent) MarshalToSizedBuffer

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

func (*MsgSubmitExternalEvent) ProtoMessage

func (*MsgSubmitExternalEvent) ProtoMessage()

func (*MsgSubmitExternalEvent) Reset

func (m *MsgSubmitExternalEvent) Reset()

func (*MsgSubmitExternalEvent) Route

func (msg *MsgSubmitExternalEvent) Route() string

Route should return the name of the module

func (*MsgSubmitExternalEvent) Size

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

func (*MsgSubmitExternalEvent) String

func (m *MsgSubmitExternalEvent) String() string

func (*MsgSubmitExternalEvent) Type

func (msg *MsgSubmitExternalEvent) Type() string

Type should return the action

func (*MsgSubmitExternalEvent) Unmarshal

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

func (*MsgSubmitExternalEvent) UnpackInterfaces

func (msg *MsgSubmitExternalEvent) UnpackInterfaces(unpacker cdctypes.AnyUnpacker) error

func (*MsgSubmitExternalEvent) ValidateBasic

func (msg *MsgSubmitExternalEvent) ValidateBasic() (err error)

ValidateBasic performs stateless checks

func (*MsgSubmitExternalEvent) XXX_DiscardUnknown

func (m *MsgSubmitExternalEvent) XXX_DiscardUnknown()

func (*MsgSubmitExternalEvent) XXX_Marshal

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

func (*MsgSubmitExternalEvent) XXX_Merge

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

func (*MsgSubmitExternalEvent) XXX_Size

func (m *MsgSubmitExternalEvent) XXX_Size() int

func (*MsgSubmitExternalEvent) XXX_Unmarshal

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

type MsgSubmitExternalEventResponse

type MsgSubmitExternalEventResponse struct {
}

func (*MsgSubmitExternalEventResponse) Descriptor

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

func (*MsgSubmitExternalEventResponse) Marshal

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

func (*MsgSubmitExternalEventResponse) MarshalTo

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

func (*MsgSubmitExternalEventResponse) MarshalToSizedBuffer

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

func (*MsgSubmitExternalEventResponse) ProtoMessage

func (*MsgSubmitExternalEventResponse) ProtoMessage()

func (*MsgSubmitExternalEventResponse) Reset

func (m *MsgSubmitExternalEventResponse) Reset()

func (*MsgSubmitExternalEventResponse) Size

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

func (*MsgSubmitExternalEventResponse) String

func (*MsgSubmitExternalEventResponse) Unmarshal

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

func (*MsgSubmitExternalEventResponse) XXX_DiscardUnknown

func (m *MsgSubmitExternalEventResponse) XXX_DiscardUnknown()

func (*MsgSubmitExternalEventResponse) XXX_Marshal

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

func (*MsgSubmitExternalEventResponse) XXX_Merge

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

func (*MsgSubmitExternalEventResponse) XXX_Size

func (m *MsgSubmitExternalEventResponse) XXX_Size() int

func (*MsgSubmitExternalEventResponse) XXX_Unmarshal

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

type MsgSubmitExternalTxConfirmation

type MsgSubmitExternalTxConfirmation struct {
	// TODO: can we make this take an array?
	Confirmation *types1.Any `protobuf:"bytes,1,opt,name=confirmation,proto3" json:"confirmation,omitempty"`
	Signer       string      `protobuf:"bytes,2,opt,name=signer,proto3" json:"signer,omitempty"`
	ChainId      string      `protobuf:"bytes,3,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

MsgSubmitExternalTxConfirmation submits an external signature for a given validator

func (*MsgSubmitExternalTxConfirmation) Descriptor

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

func (*MsgSubmitExternalTxConfirmation) GetSignBytes

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

GetSignBytes encodes the message for signing

func (*MsgSubmitExternalTxConfirmation) GetSigners

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

GetSigners defines whose signature is required

func (*MsgSubmitExternalTxConfirmation) Marshal

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

func (*MsgSubmitExternalTxConfirmation) MarshalTo

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

func (*MsgSubmitExternalTxConfirmation) MarshalToSizedBuffer

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

func (*MsgSubmitExternalTxConfirmation) ProtoMessage

func (*MsgSubmitExternalTxConfirmation) ProtoMessage()

func (*MsgSubmitExternalTxConfirmation) Reset

func (*MsgSubmitExternalTxConfirmation) Route

Route should return the name of the module

func (*MsgSubmitExternalTxConfirmation) Size

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

func (*MsgSubmitExternalTxConfirmation) String

func (*MsgSubmitExternalTxConfirmation) Type

Type should return the action

func (*MsgSubmitExternalTxConfirmation) Unmarshal

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

func (*MsgSubmitExternalTxConfirmation) UnpackInterfaces

func (msg *MsgSubmitExternalTxConfirmation) UnpackInterfaces(unpacker cdctypes.AnyUnpacker) error

func (*MsgSubmitExternalTxConfirmation) ValidateBasic

func (msg *MsgSubmitExternalTxConfirmation) ValidateBasic() (err error)

ValidateBasic performs stateless checks

func (*MsgSubmitExternalTxConfirmation) XXX_DiscardUnknown

func (m *MsgSubmitExternalTxConfirmation) XXX_DiscardUnknown()

func (*MsgSubmitExternalTxConfirmation) XXX_Marshal

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

func (*MsgSubmitExternalTxConfirmation) XXX_Merge

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

func (*MsgSubmitExternalTxConfirmation) XXX_Size

func (m *MsgSubmitExternalTxConfirmation) XXX_Size() int

func (*MsgSubmitExternalTxConfirmation) XXX_Unmarshal

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

type MsgSubmitTxConfirmationResponse

type MsgSubmitTxConfirmationResponse struct {
}

func (*MsgSubmitTxConfirmationResponse) Descriptor

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

func (*MsgSubmitTxConfirmationResponse) Marshal

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

func (*MsgSubmitTxConfirmationResponse) MarshalTo

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

func (*MsgSubmitTxConfirmationResponse) MarshalToSizedBuffer

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

func (*MsgSubmitTxConfirmationResponse) ProtoMessage

func (*MsgSubmitTxConfirmationResponse) ProtoMessage()

func (*MsgSubmitTxConfirmationResponse) Reset

func (*MsgSubmitTxConfirmationResponse) Size

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

func (*MsgSubmitTxConfirmationResponse) String

func (*MsgSubmitTxConfirmationResponse) Unmarshal

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

func (*MsgSubmitTxConfirmationResponse) XXX_DiscardUnknown

func (m *MsgSubmitTxConfirmationResponse) XXX_DiscardUnknown()

func (*MsgSubmitTxConfirmationResponse) XXX_Marshal

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

func (*MsgSubmitTxConfirmationResponse) XXX_Merge

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

func (*MsgSubmitTxConfirmationResponse) XXX_Size

func (m *MsgSubmitTxConfirmationResponse) XXX_Size() int

func (*MsgSubmitTxConfirmationResponse) XXX_Unmarshal

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

type MultiMhub2Hooks

type MultiMhub2Hooks []MhubHooks

func NewMultiMhub2Hooks

func NewMultiMhub2Hooks(hooks ...MhubHooks) MultiMhub2Hooks

func (MultiMhub2Hooks) AfterBatchExecutedEvent

func (mghs MultiMhub2Hooks) AfterBatchExecutedEvent(ctx sdk.Context, event BatchExecutedEvent)

func (MultiMhub2Hooks) AfterContractCallExecutedEvent

func (mghs MultiMhub2Hooks) AfterContractCallExecutedEvent(ctx sdk.Context, event ContractCallExecutedEvent)

func (MultiMhub2Hooks) AfterSendToHubEvent

func (mghs MultiMhub2Hooks) AfterSendToHubEvent(ctx sdk.Context, event SendToHubEvent)

func (MultiMhub2Hooks) AfterSignerSetExecutedEvent

func (mghs MultiMhub2Hooks) AfterSignerSetExecutedEvent(ctx sdk.Context, event SignerSetTxExecutedEvent)

type Nonce

type Nonce struct {
	ValidatorAddress string `protobuf:"bytes,1,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
	LastEventNonce   uint64 `protobuf:"varint,2,opt,name=last_event_nonce,json=lastEventNonce,proto3" json:"last_event_nonce,omitempty"`
}

func (*Nonce) Descriptor

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

func (*Nonce) GetLastEventNonce

func (m *Nonce) GetLastEventNonce() uint64

func (*Nonce) GetValidatorAddress

func (m *Nonce) GetValidatorAddress() string

func (*Nonce) Marshal

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

func (*Nonce) MarshalTo

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

func (*Nonce) MarshalToSizedBuffer

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

func (*Nonce) ProtoMessage

func (*Nonce) ProtoMessage()

func (*Nonce) Reset

func (m *Nonce) Reset()

func (*Nonce) Size

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

func (*Nonce) String

func (m *Nonce) String() string

func (*Nonce) Unmarshal

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

func (*Nonce) XXX_DiscardUnknown

func (m *Nonce) XXX_DiscardUnknown()

func (*Nonce) XXX_Marshal

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

func (*Nonce) XXX_Merge

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

func (*Nonce) XXX_Size

func (m *Nonce) XXX_Size() int

func (*Nonce) XXX_Unmarshal

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

type OracleKeeper

type OracleKeeper interface {
	MustGetTokenPrice(ctx sdk.Context, denom string) sdk.Dec
	GetTokenPrice(ctx sdk.Context, denom string) (sdk.Dec, error)
	GetHolderValue(ctx sdk.Context, address string) sdk.Int
}

type OutgoingTx

type OutgoingTx interface {

	// The only one that will be problematic is BatchTx which needs to pull all the constituent
	// transactions before calculating the checkpoint
	GetCheckpoint([]byte) []byte
	GetStoreIndex(chainId ChainID) []byte
	GetCosmosHeight() uint64
	SetSequence(seq uint64)
}

func UnpackOutgoingTx

func UnpackOutgoingTx(any *types.Any) (OutgoingTx, error)

type Params

type Params struct {
	GravityId                string `protobuf:"bytes,1,opt,name=gravity_id,json=gravityId,proto3" json:"gravity_id,omitempty"`
	ContractSourceHash       string `protobuf:"bytes,2,opt,name=contract_source_hash,json=contractSourceHash,proto3" json:"contract_source_hash,omitempty"`
	BridgeEthereumAddress    string `` /* 126-byte string literal not displayed */
	BridgeChainId            uint64 `protobuf:"varint,5,opt,name=bridge_chain_id,json=bridgeChainId,proto3" json:"bridge_chain_id,omitempty"`
	SignedSignerSetTxsWindow uint64 `` /* 140-byte string literal not displayed */
	SignedBatchesWindow      uint64 `protobuf:"varint,7,opt,name=signed_batches_window,json=signedBatchesWindow,proto3" json:"signed_batches_window,omitempty"`
	EthereumSignaturesWindow uint64 `` /* 136-byte string literal not displayed */
	TargetEthTxTimeout       uint64 `protobuf:"varint,10,opt,name=target_eth_tx_timeout,json=targetEthTxTimeout,proto3" json:"target_eth_tx_timeout,omitempty"`
	AverageBlockTime         uint64 `protobuf:"varint,11,opt,name=average_block_time,json=averageBlockTime,proto3" json:"average_block_time,omitempty"`
	AverageEthereumBlockTime uint64 `` /* 139-byte string literal not displayed */
	AverageBscBlockTime      uint64 `protobuf:"varint,13,opt,name=average_bsc_block_time,json=averageBscBlockTime,proto3" json:"average_bsc_block_time,omitempty"`
	// TODO: slash fraction for contract call txs too
	SlashFractionSignerSetTx                  github_com_cosmos_cosmos_sdk_types.Dec `` /* 180-byte string literal not displayed */
	SlashFractionBatch                        github_com_cosmos_cosmos_sdk_types.Dec `` /* 158-byte string literal not displayed */
	SlashFractionEthereumSignature            github_com_cosmos_cosmos_sdk_types.Dec `` /* 196-byte string literal not displayed */
	SlashFractionConflictingEthereumSignature github_com_cosmos_cosmos_sdk_types.Dec `` /* 231-byte string literal not displayed */
	UnbondSlashingSignerSetTxsWindow          uint64                                 `` /* 167-byte string literal not displayed */
	Chains                                    []string                               `protobuf:"bytes,19,rep,name=chains,proto3" json:"chains,omitempty"`
	OutgoingTxTimeout                         uint64                                 `protobuf:"varint,20,opt,name=outgoing_tx_timeout,json=outgoingTxTimeout,proto3" json:"outgoing_tx_timeout,omitempty"`
}

Params represent the Mhub2 genesis and store parameters gravity_id: a random 32 byte value to prevent signature reuse, for example if the cosmos validators decided to use the same Ethereum keys for another chain also running Mhub2 we would not want it to be possible to play a deposit from chain A back on chain B's Mhub2. This value IS USED ON ETHEREUM so it must be set in your genesis.json before launch and not changed after deploying Mhub2

contract_hash: the code hash of a known good version of the Mhub2 contract solidity code. This can be used to verify the correct version of the contract has been deployed. This is a reference value for goernance action only it is never read by any Mhub2 code

bridge_ethereum_address: is address of the bridge contract on the Ethereum side, this is a reference value for governance only and is not actually used by any Mhub2 code

bridge_chain_id: the unique identifier of the Ethereum chain, this is a reference value only and is not actually used by any Mhub2 code

These reference values may be used by future Mhub2 client implemetnations to allow for saftey features or convenience features like the Mhub2 address in your relayer. A relayer would require a configured Mhub2 address if governance had not set the address on the chain it was relaying for.

signed_signer_set_txs_window signed_batches_window signed_ethereum_signatures_window

These values represent the time in blocks that a validator has to submit a signature for a batch or valset, or to submit a ethereum_signature for a particular attestation nonce. In the case of attestations this clock starts when the attestation is created, but only allows for slashing once the event has passed

target_eth_tx_timeout:

This is the 'target' value for when ethereum transactions time out, this is a target because Ethereum is a probabilistic chain and you can't say for sure what the block frequency is ahead of time.

average_block_time average_ethereum_block_time

These values are the average Cosmos block time and Ethereum block time respectively and they are used to compute what the target batch timeout is. It is important that governance updates these in case of any major, prolonged change in the time it takes to produce a block

slash_fraction_signer_set_tx slash_fraction_batch slash_fraction_ethereum_signature slash_fraction_conflicting_ethereum_signature

The slashing fractions for the various Mhub2 related slashing conditions. The first three refer to not submitting a particular message, the third for submitting a different ethereum_signature for the same Ethereum event

func DefaultParams

func DefaultParams() *Params

DefaultParams returns a copy of the default params

func (*Params) Descriptor

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

func (Params) Equal

func (p Params) Equal(p2 Params) bool

Equal returns a boolean determining if two Params types are identical.

func (*Params) GetAverageBlockTime

func (m *Params) GetAverageBlockTime() uint64

func (*Params) GetAverageBscBlockTime

func (m *Params) GetAverageBscBlockTime() uint64

func (*Params) GetAverageEthereumBlockTime

func (m *Params) GetAverageEthereumBlockTime() uint64

func (*Params) GetBridgeChainId

func (m *Params) GetBridgeChainId() uint64

func (*Params) GetBridgeEthereumAddress

func (m *Params) GetBridgeEthereumAddress() string

func (*Params) GetChains

func (m *Params) GetChains() []string

func (*Params) GetContractSourceHash

func (m *Params) GetContractSourceHash() string

func (*Params) GetEthereumSignaturesWindow

func (m *Params) GetEthereumSignaturesWindow() uint64

func (*Params) GetGravityId

func (m *Params) GetGravityId() string

func (*Params) GetOutgoingTxTimeout

func (m *Params) GetOutgoingTxTimeout() uint64

func (*Params) GetSignedBatchesWindow

func (m *Params) GetSignedBatchesWindow() uint64

func (*Params) GetSignedSignerSetTxsWindow

func (m *Params) GetSignedSignerSetTxsWindow() uint64

func (*Params) GetTargetEthTxTimeout

func (m *Params) GetTargetEthTxTimeout() uint64

func (*Params) GetUnbondSlashingSignerSetTxsWindow

func (m *Params) GetUnbondSlashingSignerSetTxsWindow() 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 ParamSet interface and returns all the key/value pairs pairs of auth module's parameters.

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 (m *Params) String() string

func (*Params) Unmarshal

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

func (Params) ValidateBasic

func (p Params) ValidateBasic() error

ValidateBasic checks that the parameters have valid values.

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 ParamsRequest

type ParamsRequest struct {
}

rpc Params

func (*ParamsRequest) Descriptor

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

func (*ParamsRequest) Marshal

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

func (*ParamsRequest) MarshalTo

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

func (*ParamsRequest) MarshalToSizedBuffer

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

func (*ParamsRequest) ProtoMessage

func (*ParamsRequest) ProtoMessage()

func (*ParamsRequest) Reset

func (m *ParamsRequest) Reset()

func (*ParamsRequest) Size

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

func (*ParamsRequest) String

func (m *ParamsRequest) String() string

func (*ParamsRequest) Unmarshal

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

func (*ParamsRequest) XXX_DiscardUnknown

func (m *ParamsRequest) XXX_DiscardUnknown()

func (*ParamsRequest) XXX_Marshal

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

func (*ParamsRequest) XXX_Merge

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

func (*ParamsRequest) XXX_Size

func (m *ParamsRequest) XXX_Size() int

func (*ParamsRequest) XXX_Unmarshal

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

type ParamsResponse

type ParamsResponse struct {
	Params Params `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
}

func (*ParamsResponse) Descriptor

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

func (*ParamsResponse) GetParams

func (m *ParamsResponse) GetParams() Params

func (*ParamsResponse) Marshal

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

func (*ParamsResponse) MarshalTo

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

func (*ParamsResponse) MarshalToSizedBuffer

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

func (*ParamsResponse) ProtoMessage

func (*ParamsResponse) ProtoMessage()

func (*ParamsResponse) Reset

func (m *ParamsResponse) Reset()

func (*ParamsResponse) Size

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

func (*ParamsResponse) String

func (m *ParamsResponse) String() string

func (*ParamsResponse) Unmarshal

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

func (*ParamsResponse) XXX_DiscardUnknown

func (m *ParamsResponse) XXX_DiscardUnknown()

func (*ParamsResponse) XXX_Marshal

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

func (*ParamsResponse) XXX_Merge

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

func (*ParamsResponse) XXX_Size

func (m *ParamsResponse) XXX_Size() int

func (*ParamsResponse) XXX_Unmarshal

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

type QueryClient

type QueryClient interface {
	// Module parameters query
	Params(ctx context.Context, in *ParamsRequest, opts ...grpc.CallOption) (*ParamsResponse, error)
	// get info on individual outgoing data
	SignerSetTx(ctx context.Context, in *SignerSetTxRequest, opts ...grpc.CallOption) (*SignerSetTxResponse, error)
	LatestSignerSetTx(ctx context.Context, in *LatestSignerSetTxRequest, opts ...grpc.CallOption) (*SignerSetTxResponse, error)
	LastObservedSignerSetTx(ctx context.Context, in *LastObservedSignerSetTxRequest, opts ...grpc.CallOption) (*SignerSetTxResponse, error)
	BatchTx(ctx context.Context, in *BatchTxRequest, opts ...grpc.CallOption) (*BatchTxResponse, error)
	ContractCallTx(ctx context.Context, in *ContractCallTxRequest, opts ...grpc.CallOption) (*ContractCallTxResponse, error)
	// get collections of outgoing traffic from the bridge
	SignerSetTxs(ctx context.Context, in *SignerSetTxsRequest, opts ...grpc.CallOption) (*SignerSetTxsResponse, error)
	BatchTxs(ctx context.Context, in *BatchTxsRequest, opts ...grpc.CallOption) (*BatchTxsResponse, error)
	ContractCallTxs(ctx context.Context, in *ContractCallTxsRequest, opts ...grpc.CallOption) (*ContractCallTxsResponse, error)
	// TODO: can/should we group these into one endpoint?
	SignerSetTxConfirmations(ctx context.Context, in *SignerSetTxConfirmationsRequest, opts ...grpc.CallOption) (*SignerSetTxConfirmationsResponse, error)
	BatchTxConfirmations(ctx context.Context, in *BatchTxConfirmationsRequest, opts ...grpc.CallOption) (*BatchTxConfirmationsResponse, error)
	ContractCallTxConfirmations(ctx context.Context, in *ContractCallTxConfirmationsRequest, opts ...grpc.CallOption) (*ContractCallTxConfirmationsResponse, error)
	// pending external signature queries for orchestrators to figure out which
	// signatures they are missing
	// TODO: can/should we group this into one endpoint?
	UnsignedSignerSetTxs(ctx context.Context, in *UnsignedSignerSetTxsRequest, opts ...grpc.CallOption) (*UnsignedSignerSetTxsResponse, error)
	UnsignedBatchTxs(ctx context.Context, in *UnsignedBatchTxsRequest, opts ...grpc.CallOption) (*UnsignedBatchTxsResponse, error)
	UnsignedContractCallTxs(ctx context.Context, in *UnsignedContractCallTxsRequest, opts ...grpc.CallOption) (*UnsignedContractCallTxsResponse, error)
	LastSubmittedExternalEvent(ctx context.Context, in *LastSubmittedExternalEventRequest, opts ...grpc.CallOption) (*LastSubmittedExternalEventResponse, error)
	// Queries the fees for all pending batches, results are returned in sdk.Coin
	// (fee_amount_int)(contract_address) style
	BatchTxFees(ctx context.Context, in *BatchTxFeesRequest, opts ...grpc.CallOption) (*BatchTxFeesResponse, error)
	// Query for info about denoms tracked by mhub2
	ExternalIdToDenom(ctx context.Context, in *ExternalIdToDenomRequest, opts ...grpc.CallOption) (*ExternalIdToDenomResponse, error)
	// Query for info about denoms tracked by mhub2
	DenomToExternalId(ctx context.Context, in *DenomToExternalIdRequest, opts ...grpc.CallOption) (*DenomToExternalIdResponse, error)
	// Query for batch send to externals
	BatchedSendToExternals(ctx context.Context, in *BatchedSendToExternalsRequest, opts ...grpc.CallOption) (*BatchedSendToExternalsResponse, error)
	// Query for unbatched send to externals
	UnbatchedSendToExternals(ctx context.Context, in *UnbatchedSendToExternalsRequest, opts ...grpc.CallOption) (*UnbatchedSendToExternalsResponse, error)
	// delegate keys
	DelegateKeysByValidator(ctx context.Context, in *DelegateKeysByValidatorRequest, opts ...grpc.CallOption) (*DelegateKeysByValidatorResponse, error)
	DelegateKeysByExternalSigner(ctx context.Context, in *DelegateKeysByExternalSignerRequest, opts ...grpc.CallOption) (*DelegateKeysByExternalSignerResponse, error)
	DelegateKeysByOrchestrator(ctx context.Context, in *DelegateKeysByOrchestratorRequest, opts ...grpc.CallOption) (*DelegateKeysByOrchestratorResponse, error)
	DelegateKeys(ctx context.Context, in *DelegateKeysRequest, opts ...grpc.CallOption) (*DelegateKeysResponse, error)
	TokenInfos(ctx context.Context, in *TokenInfosRequest, opts ...grpc.CallOption) (*TokenInfosResponse, error)
	TransactionStatus(ctx context.Context, in *TransactionStatusRequest, opts ...grpc.CallOption) (*TransactionStatusResponse, error)
	TransactionFeeRecord(ctx context.Context, in *TransactionFeeRecordRequest, opts ...grpc.CallOption) (*TransactionFeeRecordResponse, error)
	DiscountForHolder(ctx context.Context, in *DiscountForHolderRequest, opts ...grpc.CallOption) (*DiscountForHolderResponse, 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 QueryServer

type QueryServer interface {
	// Module parameters query
	Params(context.Context, *ParamsRequest) (*ParamsResponse, error)
	// get info on individual outgoing data
	SignerSetTx(context.Context, *SignerSetTxRequest) (*SignerSetTxResponse, error)
	LatestSignerSetTx(context.Context, *LatestSignerSetTxRequest) (*SignerSetTxResponse, error)
	LastObservedSignerSetTx(context.Context, *LastObservedSignerSetTxRequest) (*SignerSetTxResponse, error)
	BatchTx(context.Context, *BatchTxRequest) (*BatchTxResponse, error)
	ContractCallTx(context.Context, *ContractCallTxRequest) (*ContractCallTxResponse, error)
	// get collections of outgoing traffic from the bridge
	SignerSetTxs(context.Context, *SignerSetTxsRequest) (*SignerSetTxsResponse, error)
	BatchTxs(context.Context, *BatchTxsRequest) (*BatchTxsResponse, error)
	ContractCallTxs(context.Context, *ContractCallTxsRequest) (*ContractCallTxsResponse, error)
	// TODO: can/should we group these into one endpoint?
	SignerSetTxConfirmations(context.Context, *SignerSetTxConfirmationsRequest) (*SignerSetTxConfirmationsResponse, error)
	BatchTxConfirmations(context.Context, *BatchTxConfirmationsRequest) (*BatchTxConfirmationsResponse, error)
	ContractCallTxConfirmations(context.Context, *ContractCallTxConfirmationsRequest) (*ContractCallTxConfirmationsResponse, error)
	// pending external signature queries for orchestrators to figure out which
	// signatures they are missing
	// TODO: can/should we group this into one endpoint?
	UnsignedSignerSetTxs(context.Context, *UnsignedSignerSetTxsRequest) (*UnsignedSignerSetTxsResponse, error)
	UnsignedBatchTxs(context.Context, *UnsignedBatchTxsRequest) (*UnsignedBatchTxsResponse, error)
	UnsignedContractCallTxs(context.Context, *UnsignedContractCallTxsRequest) (*UnsignedContractCallTxsResponse, error)
	LastSubmittedExternalEvent(context.Context, *LastSubmittedExternalEventRequest) (*LastSubmittedExternalEventResponse, error)
	// Queries the fees for all pending batches, results are returned in sdk.Coin
	// (fee_amount_int)(contract_address) style
	BatchTxFees(context.Context, *BatchTxFeesRequest) (*BatchTxFeesResponse, error)
	// Query for info about denoms tracked by mhub2
	ExternalIdToDenom(context.Context, *ExternalIdToDenomRequest) (*ExternalIdToDenomResponse, error)
	// Query for info about denoms tracked by mhub2
	DenomToExternalId(context.Context, *DenomToExternalIdRequest) (*DenomToExternalIdResponse, error)
	// Query for batch send to externals
	BatchedSendToExternals(context.Context, *BatchedSendToExternalsRequest) (*BatchedSendToExternalsResponse, error)
	// Query for unbatched send to externals
	UnbatchedSendToExternals(context.Context, *UnbatchedSendToExternalsRequest) (*UnbatchedSendToExternalsResponse, error)
	// delegate keys
	DelegateKeysByValidator(context.Context, *DelegateKeysByValidatorRequest) (*DelegateKeysByValidatorResponse, error)
	DelegateKeysByExternalSigner(context.Context, *DelegateKeysByExternalSignerRequest) (*DelegateKeysByExternalSignerResponse, error)
	DelegateKeysByOrchestrator(context.Context, *DelegateKeysByOrchestratorRequest) (*DelegateKeysByOrchestratorResponse, error)
	DelegateKeys(context.Context, *DelegateKeysRequest) (*DelegateKeysResponse, error)
	TokenInfos(context.Context, *TokenInfosRequest) (*TokenInfosResponse, error)
	TransactionStatus(context.Context, *TransactionStatusRequest) (*TransactionStatusResponse, error)
	TransactionFeeRecord(context.Context, *TransactionFeeRecordRequest) (*TransactionFeeRecordResponse, error)
	DiscountForHolder(context.Context, *DiscountForHolderRequest) (*DiscountForHolderResponse, error)
}

QueryServer is the server API for Query service.

type SendToExternal

type SendToExternal struct {
	Id                uint64        `protobuf:"varint,1,opt,name=id,proto3" json:"id,omitempty"`
	Sender            string        `protobuf:"bytes,2,opt,name=sender,proto3" json:"sender,omitempty"`
	ExternalRecipient string        `protobuf:"bytes,3,opt,name=external_recipient,json=externalRecipient,proto3" json:"external_recipient,omitempty"`
	ChainId           string        `protobuf:"bytes,4,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	Token             ExternalToken `protobuf:"bytes,5,opt,name=token,proto3" json:"token"`
	Fee               ExternalToken `protobuf:"bytes,6,opt,name=fee,proto3" json:"fee"`
	TxHash            string        `protobuf:"bytes,7,opt,name=tx_hash,json=txHash,proto3" json:"tx_hash,omitempty"`
	ValCommission     ExternalToken `protobuf:"bytes,8,opt,name=val_commission,json=valCommission,proto3" json:"val_commission"`
	CreatedAt         uint64        `protobuf:"varint,9,opt,name=created_at,json=createdAt,proto3" json:"created_at,omitempty"`
	RefundAddress     string        `protobuf:"bytes,10,opt,name=refund_address,json=refundAddress,proto3" json:"refund_address,omitempty"`
	RefundChainId     string        `protobuf:"bytes,11,opt,name=refund_chain_id,json=refundChainId,proto3" json:"refund_chain_id,omitempty"`
}

SendToExternal represents an individual SendToExternal from Cosmos to External chain

func NewSendToExternalTx

func NewSendToExternalTx(id uint64, chainId ChainID, tokenId uint64, externalTokenId string, sender sdk.AccAddress,
	recipient common.Address, amount, feeAmount, valCommission uint64, txHash string, createdAt uint64) *SendToExternal

func (*SendToExternal) Descriptor

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

func (*SendToExternal) GetChainId

func (m *SendToExternal) GetChainId() string

func (*SendToExternal) GetCreatedAt

func (m *SendToExternal) GetCreatedAt() uint64

func (*SendToExternal) GetExternalRecipient

func (m *SendToExternal) GetExternalRecipient() string

func (*SendToExternal) GetFee

func (m *SendToExternal) GetFee() ExternalToken

func (*SendToExternal) GetId

func (m *SendToExternal) GetId() uint64

func (*SendToExternal) GetRefundAddress

func (m *SendToExternal) GetRefundAddress() string

func (*SendToExternal) GetRefundChainId

func (m *SendToExternal) GetRefundChainId() string

func (*SendToExternal) GetSender

func (m *SendToExternal) GetSender() string

func (*SendToExternal) GetToken

func (m *SendToExternal) GetToken() ExternalToken

func (*SendToExternal) GetTxHash

func (m *SendToExternal) GetTxHash() string

func (*SendToExternal) GetValCommission

func (m *SendToExternal) GetValCommission() ExternalToken

func (*SendToExternal) Marshal

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

func (*SendToExternal) MarshalTo

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

func (*SendToExternal) MarshalToSizedBuffer

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

func (*SendToExternal) ProtoMessage

func (*SendToExternal) ProtoMessage()

func (*SendToExternal) Reset

func (m *SendToExternal) Reset()

func (*SendToExternal) Size

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

func (*SendToExternal) String

func (m *SendToExternal) String() string

func (*SendToExternal) Unmarshal

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

func (*SendToExternal) XXX_DiscardUnknown

func (m *SendToExternal) XXX_DiscardUnknown()

func (*SendToExternal) XXX_Marshal

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

func (*SendToExternal) XXX_Merge

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

func (*SendToExternal) XXX_Size

func (m *SendToExternal) XXX_Size() int

func (*SendToExternal) XXX_Unmarshal

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

type SendToHubEvent

type SendToHubEvent struct {
	EventNonce     uint64                                 `protobuf:"varint,1,opt,name=event_nonce,json=eventNonce,proto3" json:"event_nonce,omitempty"`
	ExternalCoinId string                                 `protobuf:"bytes,2,opt,name=external_coin_id,json=externalCoinId,proto3" json:"external_coin_id,omitempty"`
	Amount         github_com_cosmos_cosmos_sdk_types.Int `protobuf:"bytes,3,opt,name=amount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Int" json:"amount"`
	Sender         string                                 `protobuf:"bytes,4,opt,name=sender,proto3" json:"sender,omitempty"`
	CosmosReceiver string                                 `protobuf:"bytes,5,opt,name=cosmos_receiver,json=cosmosReceiver,proto3" json:"cosmos_receiver,omitempty"`
	ExternalHeight uint64                                 `protobuf:"varint,6,opt,name=external_height,json=externalHeight,proto3" json:"external_height,omitempty"`
	TxHash         string                                 `protobuf:"bytes,7,opt,name=tx_hash,json=txHash,proto3" json:"tx_hash,omitempty"`
}

SendToHubEvent is submitted when the SendToHubEvent is emitted by they mhub2 contract.

func (*SendToHubEvent) Descriptor

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

func (*SendToHubEvent) Equal

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

func (*SendToHubEvent) GetCosmosReceiver

func (m *SendToHubEvent) GetCosmosReceiver() string

func (*SendToHubEvent) GetEventNonce

func (m *SendToHubEvent) GetEventNonce() uint64

func (*SendToHubEvent) GetExternalCoinId

func (m *SendToHubEvent) GetExternalCoinId() string

func (*SendToHubEvent) GetExternalHeight

func (m *SendToHubEvent) GetExternalHeight() uint64

func (*SendToHubEvent) GetSender

func (m *SendToHubEvent) GetSender() string

func (*SendToHubEvent) GetTxHash

func (m *SendToHubEvent) GetTxHash() string

func (*SendToHubEvent) Hash

func (sthe *SendToHubEvent) Hash() tmbytes.HexBytes

func (*SendToHubEvent) Marshal

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

func (*SendToHubEvent) MarshalTo

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

func (*SendToHubEvent) MarshalToSizedBuffer

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

func (*SendToHubEvent) ProtoMessage

func (*SendToHubEvent) ProtoMessage()

func (*SendToHubEvent) Reset

func (m *SendToHubEvent) Reset()

func (*SendToHubEvent) Size

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

func (*SendToHubEvent) String

func (m *SendToHubEvent) String() string

func (*SendToHubEvent) Unmarshal

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

func (*SendToHubEvent) Validate

func (stce *SendToHubEvent) Validate(chainId ChainID) error

func (*SendToHubEvent) XXX_DiscardUnknown

func (m *SendToHubEvent) XXX_DiscardUnknown()

func (*SendToHubEvent) XXX_Marshal

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

func (*SendToHubEvent) XXX_Merge

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

func (*SendToHubEvent) XXX_Size

func (m *SendToHubEvent) XXX_Size() int

func (*SendToHubEvent) XXX_Unmarshal

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

type SignerSetTx

type SignerSetTx struct {
	Nonce    uint64          `protobuf:"varint,1,opt,name=nonce,proto3" json:"nonce,omitempty"`
	Height   uint64          `protobuf:"varint,2,opt,name=height,proto3" json:"height,omitempty"`
	Signers  ExternalSigners `protobuf:"bytes,3,rep,name=signers,proto3,castrepeated=ExternalSigners" json:"signers,omitempty"`
	Sequence uint64          `protobuf:"varint,4,opt,name=sequence,proto3" json:"sequence,omitempty"`
}

SignerSetTx is the Bridge multisig set that relays transactions the two chains. The staking validators keep external keys which are used to check signatures in order to get significant gas savings.

func NewSignerSetTx

func NewSignerSetTx(nonce, height uint64, members ExternalSigners) *SignerSetTx

NewSignerSetTx returns a new valset

func (*SignerSetTx) Descriptor

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

func (SignerSetTx) GetCheckpoint

func (u SignerSetTx) GetCheckpoint(gravityID []byte) []byte

GetCheckpoint returns the checkpoint

func (*SignerSetTx) GetCosmosHeight

func (sstx *SignerSetTx) GetCosmosHeight() uint64

func (*SignerSetTx) GetHeight

func (m *SignerSetTx) GetHeight() uint64

func (*SignerSetTx) GetNonce

func (m *SignerSetTx) GetNonce() uint64

func (*SignerSetTx) GetSequence

func (m *SignerSetTx) GetSequence() uint64

func (*SignerSetTx) GetSigners

func (m *SignerSetTx) GetSigners() ExternalSigners

func (*SignerSetTx) GetStoreIndex

func (sstx *SignerSetTx) GetStoreIndex(chainId ChainID) []byte

TODO: do we need a prefix byte for the different types?

func (*SignerSetTx) Marshal

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

func (*SignerSetTx) MarshalTo

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

func (*SignerSetTx) MarshalToSizedBuffer

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

func (*SignerSetTx) ProtoMessage

func (*SignerSetTx) ProtoMessage()

func (*SignerSetTx) Reset

func (m *SignerSetTx) Reset()

func (*SignerSetTx) SetSequence

func (sstx *SignerSetTx) SetSequence(seq uint64)

func (*SignerSetTx) Size

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

func (*SignerSetTx) String

func (m *SignerSetTx) String() string

func (*SignerSetTx) Unmarshal

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

func (*SignerSetTx) XXX_DiscardUnknown

func (m *SignerSetTx) XXX_DiscardUnknown()

func (*SignerSetTx) XXX_Marshal

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

func (*SignerSetTx) XXX_Merge

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

func (*SignerSetTx) XXX_Size

func (m *SignerSetTx) XXX_Size() int

func (*SignerSetTx) XXX_Unmarshal

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

type SignerSetTxConfirmation

type SignerSetTxConfirmation struct {
	SignerSetNonce uint64 `protobuf:"varint,1,opt,name=signer_set_nonce,json=signerSetNonce,proto3" json:"signer_set_nonce,omitempty"`
	ExternalSigner string `protobuf:"bytes,2,opt,name=external_signer,json=externalSigner,proto3" json:"external_signer,omitempty"`
	Signature      []byte `protobuf:"bytes,3,opt,name=signature,proto3" json:"signature,omitempty"`
}

SignerSetTxConfirmation is a signature on behalf of a validator for a SignerSetTx

func (*SignerSetTxConfirmation) Descriptor

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

func (*SignerSetTxConfirmation) GetExternalSigner

func (m *SignerSetTxConfirmation) GetExternalSigner() string

func (*SignerSetTxConfirmation) GetSignature

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

func (*SignerSetTxConfirmation) GetSigner

func (u *SignerSetTxConfirmation) GetSigner() common.Address

func (*SignerSetTxConfirmation) GetSignerSetNonce

func (m *SignerSetTxConfirmation) GetSignerSetNonce() uint64

func (*SignerSetTxConfirmation) GetStoreIndex

func (sstx *SignerSetTxConfirmation) GetStoreIndex(chainId ChainID) []byte

func (*SignerSetTxConfirmation) Marshal

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

func (*SignerSetTxConfirmation) MarshalTo

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

func (*SignerSetTxConfirmation) MarshalToSizedBuffer

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

func (*SignerSetTxConfirmation) ProtoMessage

func (*SignerSetTxConfirmation) ProtoMessage()

func (*SignerSetTxConfirmation) Reset

func (m *SignerSetTxConfirmation) Reset()

func (*SignerSetTxConfirmation) Size

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

func (*SignerSetTxConfirmation) String

func (m *SignerSetTxConfirmation) String() string

func (*SignerSetTxConfirmation) Unmarshal

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

func (*SignerSetTxConfirmation) Validate

func (u *SignerSetTxConfirmation) Validate() error

func (*SignerSetTxConfirmation) XXX_DiscardUnknown

func (m *SignerSetTxConfirmation) XXX_DiscardUnknown()

func (*SignerSetTxConfirmation) XXX_Marshal

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

func (*SignerSetTxConfirmation) XXX_Merge

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

func (*SignerSetTxConfirmation) XXX_Size

func (m *SignerSetTxConfirmation) XXX_Size() int

func (*SignerSetTxConfirmation) XXX_Unmarshal

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

type SignerSetTxConfirmationsRequest

type SignerSetTxConfirmationsRequest struct {
	SignerSetNonce uint64 `protobuf:"varint,1,opt,name=signer_set_nonce,json=signerSetNonce,proto3" json:"signer_set_nonce,omitempty"`
	ChainId        string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

rpc SignerSetTxConfirmations

func (*SignerSetTxConfirmationsRequest) Descriptor

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

func (*SignerSetTxConfirmationsRequest) GetChainId

func (m *SignerSetTxConfirmationsRequest) GetChainId() string

func (*SignerSetTxConfirmationsRequest) GetSignerSetNonce

func (m *SignerSetTxConfirmationsRequest) GetSignerSetNonce() uint64

func (*SignerSetTxConfirmationsRequest) Marshal

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

func (*SignerSetTxConfirmationsRequest) MarshalTo

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

func (*SignerSetTxConfirmationsRequest) MarshalToSizedBuffer

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

func (*SignerSetTxConfirmationsRequest) ProtoMessage

func (*SignerSetTxConfirmationsRequest) ProtoMessage()

func (*SignerSetTxConfirmationsRequest) Reset

func (*SignerSetTxConfirmationsRequest) Size

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

func (*SignerSetTxConfirmationsRequest) String

func (*SignerSetTxConfirmationsRequest) Unmarshal

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

func (*SignerSetTxConfirmationsRequest) XXX_DiscardUnknown

func (m *SignerSetTxConfirmationsRequest) XXX_DiscardUnknown()

func (*SignerSetTxConfirmationsRequest) XXX_Marshal

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

func (*SignerSetTxConfirmationsRequest) XXX_Merge

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

func (*SignerSetTxConfirmationsRequest) XXX_Size

func (m *SignerSetTxConfirmationsRequest) XXX_Size() int

func (*SignerSetTxConfirmationsRequest) XXX_Unmarshal

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

type SignerSetTxConfirmationsResponse

type SignerSetTxConfirmationsResponse struct {
	Signatures []*SignerSetTxConfirmation `protobuf:"bytes,1,rep,name=signatures,proto3" json:"signatures,omitempty"`
}

func (*SignerSetTxConfirmationsResponse) Descriptor

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

func (*SignerSetTxConfirmationsResponse) GetSignatures

func (*SignerSetTxConfirmationsResponse) Marshal

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

func (*SignerSetTxConfirmationsResponse) MarshalTo

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

func (*SignerSetTxConfirmationsResponse) MarshalToSizedBuffer

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

func (*SignerSetTxConfirmationsResponse) ProtoMessage

func (*SignerSetTxConfirmationsResponse) ProtoMessage()

func (*SignerSetTxConfirmationsResponse) Reset

func (*SignerSetTxConfirmationsResponse) Size

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

func (*SignerSetTxConfirmationsResponse) String

func (*SignerSetTxConfirmationsResponse) Unmarshal

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

func (*SignerSetTxConfirmationsResponse) XXX_DiscardUnknown

func (m *SignerSetTxConfirmationsResponse) XXX_DiscardUnknown()

func (*SignerSetTxConfirmationsResponse) XXX_Marshal

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

func (*SignerSetTxConfirmationsResponse) XXX_Merge

func (*SignerSetTxConfirmationsResponse) XXX_Size

func (m *SignerSetTxConfirmationsResponse) XXX_Size() int

func (*SignerSetTxConfirmationsResponse) XXX_Unmarshal

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

type SignerSetTxExecutedEvent

type SignerSetTxExecutedEvent struct {
	EventNonce       uint64            `protobuf:"varint,1,opt,name=event_nonce,json=eventNonce,proto3" json:"event_nonce,omitempty"`
	SignerSetTxNonce uint64            `protobuf:"varint,2,opt,name=signer_set_tx_nonce,json=signerSetTxNonce,proto3" json:"signer_set_tx_nonce,omitempty"`
	ExternalHeight   uint64            `protobuf:"varint,3,opt,name=external_height,json=externalHeight,proto3" json:"external_height,omitempty"`
	Members          []*ExternalSigner `protobuf:"bytes,4,rep,name=members,proto3" json:"members,omitempty"`
	TxHash           string            `protobuf:"bytes,5,opt,name=tx_hash,json=txHash,proto3" json:"tx_hash,omitempty"`
}

This informs the Cosmos module that a validator set has been updated.

func (*SignerSetTxExecutedEvent) Descriptor

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

func (*SignerSetTxExecutedEvent) GetEventNonce

func (m *SignerSetTxExecutedEvent) GetEventNonce() uint64

func (*SignerSetTxExecutedEvent) GetExternalHeight

func (m *SignerSetTxExecutedEvent) GetExternalHeight() uint64

func (*SignerSetTxExecutedEvent) GetMembers

func (m *SignerSetTxExecutedEvent) GetMembers() []*ExternalSigner

func (*SignerSetTxExecutedEvent) GetSignerSetTxNonce

func (m *SignerSetTxExecutedEvent) GetSignerSetTxNonce() uint64

func (*SignerSetTxExecutedEvent) GetTxHash

func (m *SignerSetTxExecutedEvent) GetTxHash() string

func (*SignerSetTxExecutedEvent) Hash

func (*SignerSetTxExecutedEvent) Marshal

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

func (*SignerSetTxExecutedEvent) MarshalTo

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

func (*SignerSetTxExecutedEvent) MarshalToSizedBuffer

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

func (*SignerSetTxExecutedEvent) ProtoMessage

func (*SignerSetTxExecutedEvent) ProtoMessage()

func (*SignerSetTxExecutedEvent) Reset

func (m *SignerSetTxExecutedEvent) Reset()

func (*SignerSetTxExecutedEvent) Size

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

func (*SignerSetTxExecutedEvent) String

func (m *SignerSetTxExecutedEvent) String() string

func (*SignerSetTxExecutedEvent) Unmarshal

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

func (*SignerSetTxExecutedEvent) Validate

func (sse *SignerSetTxExecutedEvent) Validate(chainId ChainID) error

func (*SignerSetTxExecutedEvent) XXX_DiscardUnknown

func (m *SignerSetTxExecutedEvent) XXX_DiscardUnknown()

func (*SignerSetTxExecutedEvent) XXX_Marshal

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

func (*SignerSetTxExecutedEvent) XXX_Merge

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

func (*SignerSetTxExecutedEvent) XXX_Size

func (m *SignerSetTxExecutedEvent) XXX_Size() int

func (*SignerSetTxExecutedEvent) XXX_Unmarshal

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

type SignerSetTxRequest

type SignerSetTxRequest struct {
	SignerSetNonce uint64 `protobuf:"varint,1,opt,name=signer_set_nonce,json=signerSetNonce,proto3" json:"signer_set_nonce,omitempty"`
	ChainId        string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

rpc SignerSetTx

func (*SignerSetTxRequest) Descriptor

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

func (*SignerSetTxRequest) GetChainId

func (m *SignerSetTxRequest) GetChainId() string

func (*SignerSetTxRequest) GetSignerSetNonce

func (m *SignerSetTxRequest) GetSignerSetNonce() uint64

func (*SignerSetTxRequest) Marshal

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

func (*SignerSetTxRequest) MarshalTo

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

func (*SignerSetTxRequest) MarshalToSizedBuffer

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

func (*SignerSetTxRequest) ProtoMessage

func (*SignerSetTxRequest) ProtoMessage()

func (*SignerSetTxRequest) Reset

func (m *SignerSetTxRequest) Reset()

func (*SignerSetTxRequest) Size

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

func (*SignerSetTxRequest) String

func (m *SignerSetTxRequest) String() string

func (*SignerSetTxRequest) Unmarshal

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

func (*SignerSetTxRequest) XXX_DiscardUnknown

func (m *SignerSetTxRequest) XXX_DiscardUnknown()

func (*SignerSetTxRequest) XXX_Marshal

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

func (*SignerSetTxRequest) XXX_Merge

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

func (*SignerSetTxRequest) XXX_Size

func (m *SignerSetTxRequest) XXX_Size() int

func (*SignerSetTxRequest) XXX_Unmarshal

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

type SignerSetTxResponse

type SignerSetTxResponse struct {
	SignerSet *SignerSetTx `protobuf:"bytes,1,opt,name=signer_set,json=signerSet,proto3" json:"signer_set,omitempty"`
}

func (*SignerSetTxResponse) Descriptor

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

func (*SignerSetTxResponse) GetSignerSet

func (m *SignerSetTxResponse) GetSignerSet() *SignerSetTx

func (*SignerSetTxResponse) Marshal

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

func (*SignerSetTxResponse) MarshalTo

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

func (*SignerSetTxResponse) MarshalToSizedBuffer

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

func (*SignerSetTxResponse) ProtoMessage

func (*SignerSetTxResponse) ProtoMessage()

func (*SignerSetTxResponse) Reset

func (m *SignerSetTxResponse) Reset()

func (*SignerSetTxResponse) Size

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

func (*SignerSetTxResponse) String

func (m *SignerSetTxResponse) String() string

func (*SignerSetTxResponse) Unmarshal

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

func (*SignerSetTxResponse) XXX_DiscardUnknown

func (m *SignerSetTxResponse) XXX_DiscardUnknown()

func (*SignerSetTxResponse) XXX_Marshal

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

func (*SignerSetTxResponse) XXX_Merge

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

func (*SignerSetTxResponse) XXX_Size

func (m *SignerSetTxResponse) XXX_Size() int

func (*SignerSetTxResponse) XXX_Unmarshal

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

type SignerSetTxsRequest

type SignerSetTxsRequest struct {
	Pagination *query.PageRequest `protobuf:"bytes,1,opt,name=pagination,proto3" json:"pagination,omitempty"`
	ChainId    string             `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

rpc SignerSetTxs

func (*SignerSetTxsRequest) Descriptor

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

func (*SignerSetTxsRequest) GetChainId

func (m *SignerSetTxsRequest) GetChainId() string

func (*SignerSetTxsRequest) GetPagination

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

func (*SignerSetTxsRequest) Marshal

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

func (*SignerSetTxsRequest) MarshalTo

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

func (*SignerSetTxsRequest) MarshalToSizedBuffer

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

func (*SignerSetTxsRequest) ProtoMessage

func (*SignerSetTxsRequest) ProtoMessage()

func (*SignerSetTxsRequest) Reset

func (m *SignerSetTxsRequest) Reset()

func (*SignerSetTxsRequest) Size

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

func (*SignerSetTxsRequest) String

func (m *SignerSetTxsRequest) String() string

func (*SignerSetTxsRequest) Unmarshal

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

func (*SignerSetTxsRequest) XXX_DiscardUnknown

func (m *SignerSetTxsRequest) XXX_DiscardUnknown()

func (*SignerSetTxsRequest) XXX_Marshal

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

func (*SignerSetTxsRequest) XXX_Merge

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

func (*SignerSetTxsRequest) XXX_Size

func (m *SignerSetTxsRequest) XXX_Size() int

func (*SignerSetTxsRequest) XXX_Unmarshal

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

type SignerSetTxsResponse

type SignerSetTxsResponse struct {
	SignerSets []*SignerSetTx      `protobuf:"bytes,1,rep,name=signer_sets,json=signerSets,proto3" json:"signer_sets,omitempty"`
	Pagination *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*SignerSetTxsResponse) Descriptor

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

func (*SignerSetTxsResponse) GetPagination

func (m *SignerSetTxsResponse) GetPagination() *query.PageResponse

func (*SignerSetTxsResponse) GetSignerSets

func (m *SignerSetTxsResponse) GetSignerSets() []*SignerSetTx

func (*SignerSetTxsResponse) Marshal

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

func (*SignerSetTxsResponse) MarshalTo

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

func (*SignerSetTxsResponse) MarshalToSizedBuffer

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

func (*SignerSetTxsResponse) ProtoMessage

func (*SignerSetTxsResponse) ProtoMessage()

func (*SignerSetTxsResponse) Reset

func (m *SignerSetTxsResponse) Reset()

func (*SignerSetTxsResponse) Size

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

func (*SignerSetTxsResponse) String

func (m *SignerSetTxsResponse) String() string

func (*SignerSetTxsResponse) Unmarshal

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

func (*SignerSetTxsResponse) XXX_DiscardUnknown

func (m *SignerSetTxsResponse) XXX_DiscardUnknown()

func (*SignerSetTxsResponse) XXX_Marshal

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

func (*SignerSetTxsResponse) XXX_Merge

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

func (*SignerSetTxsResponse) XXX_Size

func (m *SignerSetTxsResponse) XXX_Size() int

func (*SignerSetTxsResponse) XXX_Unmarshal

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

type SlashingKeeper

type SlashingKeeper interface {
	GetValidatorSigningInfo(ctx sdk.Context, address sdk.ConsAddress) (info slashingtypes.ValidatorSigningInfo, found bool)
}

type StakingKeeper

type StakingKeeper interface {
	GetBondedValidatorsByPower(ctx sdk.Context) []stakingtypes.Validator
	GetLastValidatorPower(ctx sdk.Context, operator sdk.ValAddress) int64
	GetLastTotalPower(ctx sdk.Context) (power sdk.Int)
	IterateValidators(sdk.Context, func(index int64, validator stakingtypes.ValidatorI) (stop bool))
	ValidatorQueueIterator(ctx sdk.Context, endTime time.Time, endHeight int64) sdk.Iterator
	GetParams(ctx sdk.Context) stakingtypes.Params
	GetValidator(ctx sdk.Context, addr sdk.ValAddress) (validator stakingtypes.Validator, found bool)
	IterateBondedValidatorsByPower(sdk.Context, func(index int64, validator stakingtypes.ValidatorI) (stop bool))
	IterateLastValidators(sdk.Context, func(index int64, validator stakingtypes.ValidatorI) (stop bool))
	Validator(sdk.Context, sdk.ValAddress) stakingtypes.ValidatorI
	ValidatorByConsAddr(sdk.Context, sdk.ConsAddress) stakingtypes.ValidatorI
	Slash(sdk.Context, sdk.ConsAddress, int64, int64, sdk.Dec)
	Jail(sdk.Context, sdk.ConsAddress)
}

StakingKeeper defines the expected staking keeper methods

type TokenInfo

type TokenInfo struct {
	Id               uint64                                 `protobuf:"varint,1,opt,name=id,proto3" json:"id,omitempty"`
	Denom            string                                 `protobuf:"bytes,2,opt,name=denom,proto3" json:"denom,omitempty"`
	ChainId          string                                 `protobuf:"bytes,3,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	ExternalTokenId  string                                 `protobuf:"bytes,4,opt,name=external_token_id,json=externalTokenId,proto3" json:"external_token_id,omitempty"`
	ExternalDecimals uint64                                 `protobuf:"varint,5,opt,name=external_decimals,json=externalDecimals,proto3" json:"external_decimals,omitempty"`
	Commission       github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,6,opt,name=commission,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"commission"`
}

func (*TokenInfo) Descriptor

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

func (*TokenInfo) GetChainId

func (m *TokenInfo) GetChainId() string

func (*TokenInfo) GetDenom

func (m *TokenInfo) GetDenom() string

func (*TokenInfo) GetExternalDecimals

func (m *TokenInfo) GetExternalDecimals() uint64

func (*TokenInfo) GetExternalTokenId

func (m *TokenInfo) GetExternalTokenId() string

func (*TokenInfo) GetId

func (m *TokenInfo) GetId() uint64

func (*TokenInfo) Marshal

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

func (*TokenInfo) MarshalTo

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

func (*TokenInfo) MarshalToSizedBuffer

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

func (*TokenInfo) ProtoMessage

func (*TokenInfo) ProtoMessage()

func (*TokenInfo) Reset

func (m *TokenInfo) Reset()

func (*TokenInfo) Size

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

func (*TokenInfo) String

func (m *TokenInfo) String() string

func (*TokenInfo) Unmarshal

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

func (*TokenInfo) XXX_DiscardUnknown

func (m *TokenInfo) XXX_DiscardUnknown()

func (*TokenInfo) XXX_Marshal

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

func (*TokenInfo) XXX_Merge

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

func (*TokenInfo) XXX_Size

func (m *TokenInfo) XXX_Size() int

func (*TokenInfo) XXX_Unmarshal

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

type TokenInfos

type TokenInfos struct {
	TokenInfos []*TokenInfo `protobuf:"bytes,1,rep,name=token_infos,json=tokenInfos,proto3" json:"token_infos,omitempty"`
}

func (*TokenInfos) Descriptor

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

func (*TokenInfos) GetTokenInfos

func (m *TokenInfos) GetTokenInfos() []*TokenInfo

func (*TokenInfos) Marshal

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

func (*TokenInfos) MarshalTo

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

func (*TokenInfos) MarshalToSizedBuffer

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

func (*TokenInfos) ProtoMessage

func (*TokenInfos) ProtoMessage()

func (*TokenInfos) Reset

func (m *TokenInfos) Reset()

func (*TokenInfos) Size

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

func (*TokenInfos) String

func (m *TokenInfos) String() string

func (*TokenInfos) Unmarshal

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

func (*TokenInfos) XXX_DiscardUnknown

func (m *TokenInfos) XXX_DiscardUnknown()

func (*TokenInfos) XXX_Marshal

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

func (*TokenInfos) XXX_Merge

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

func (*TokenInfos) XXX_Size

func (m *TokenInfos) XXX_Size() int

func (*TokenInfos) XXX_Unmarshal

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

type TokenInfosChangeProposal

type TokenInfosChangeProposal struct {
	NewInfos *TokenInfos `protobuf:"bytes,1,opt,name=new_infos,json=newInfos,proto3" json:"new_infos,omitempty"`
}

func NewTokenInfosChangeProposal

func NewTokenInfosChangeProposal(tokenInfos *TokenInfos) *TokenInfosChangeProposal

func (*TokenInfosChangeProposal) Descriptor

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

func (*TokenInfosChangeProposal) GetDescription

func (tic *TokenInfosChangeProposal) GetDescription() string

func (*TokenInfosChangeProposal) GetTitle

func (tic *TokenInfosChangeProposal) GetTitle() string

func (*TokenInfosChangeProposal) Marshal

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

func (*TokenInfosChangeProposal) MarshalTo

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

func (*TokenInfosChangeProposal) MarshalToSizedBuffer

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

func (*TokenInfosChangeProposal) ProposalRoute

func (tic *TokenInfosChangeProposal) ProposalRoute() string

func (*TokenInfosChangeProposal) ProposalType

func (tic *TokenInfosChangeProposal) ProposalType() string

func (*TokenInfosChangeProposal) ProtoMessage

func (*TokenInfosChangeProposal) ProtoMessage()

func (*TokenInfosChangeProposal) Reset

func (m *TokenInfosChangeProposal) Reset()

func (*TokenInfosChangeProposal) Size

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

func (TokenInfosChangeProposal) String

func (tic TokenInfosChangeProposal) String() string

String implements the Stringer interface.

func (*TokenInfosChangeProposal) Unmarshal

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

func (*TokenInfosChangeProposal) ValidateBasic

func (tic *TokenInfosChangeProposal) ValidateBasic() error

func (*TokenInfosChangeProposal) XXX_DiscardUnknown

func (m *TokenInfosChangeProposal) XXX_DiscardUnknown()

func (*TokenInfosChangeProposal) XXX_Marshal

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

func (*TokenInfosChangeProposal) XXX_Merge

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

func (*TokenInfosChangeProposal) XXX_Size

func (m *TokenInfosChangeProposal) XXX_Size() int

func (*TokenInfosChangeProposal) XXX_Unmarshal

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

type TokenInfosRequest

type TokenInfosRequest struct {
}

func (*TokenInfosRequest) Descriptor

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

func (*TokenInfosRequest) Marshal

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

func (*TokenInfosRequest) MarshalTo

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

func (*TokenInfosRequest) MarshalToSizedBuffer

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

func (*TokenInfosRequest) ProtoMessage

func (*TokenInfosRequest) ProtoMessage()

func (*TokenInfosRequest) Reset

func (m *TokenInfosRequest) Reset()

func (*TokenInfosRequest) Size

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

func (*TokenInfosRequest) String

func (m *TokenInfosRequest) String() string

func (*TokenInfosRequest) Unmarshal

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

func (*TokenInfosRequest) XXX_DiscardUnknown

func (m *TokenInfosRequest) XXX_DiscardUnknown()

func (*TokenInfosRequest) XXX_Marshal

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

func (*TokenInfosRequest) XXX_Merge

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

func (*TokenInfosRequest) XXX_Size

func (m *TokenInfosRequest) XXX_Size() int

func (*TokenInfosRequest) XXX_Unmarshal

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

type TokenInfosResponse

type TokenInfosResponse struct {
	List TokenInfos `protobuf:"bytes,1,opt,name=list,proto3" json:"list"`
}

func (*TokenInfosResponse) Descriptor

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

func (*TokenInfosResponse) GetList

func (m *TokenInfosResponse) GetList() TokenInfos

func (*TokenInfosResponse) Marshal

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

func (*TokenInfosResponse) MarshalTo

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

func (*TokenInfosResponse) MarshalToSizedBuffer

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

func (*TokenInfosResponse) ProtoMessage

func (*TokenInfosResponse) ProtoMessage()

func (*TokenInfosResponse) Reset

func (m *TokenInfosResponse) Reset()

func (*TokenInfosResponse) Size

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

func (*TokenInfosResponse) String

func (m *TokenInfosResponse) String() string

func (*TokenInfosResponse) Unmarshal

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

func (*TokenInfosResponse) XXX_DiscardUnknown

func (m *TokenInfosResponse) XXX_DiscardUnknown()

func (*TokenInfosResponse) XXX_Marshal

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

func (*TokenInfosResponse) XXX_Merge

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

func (*TokenInfosResponse) XXX_Size

func (m *TokenInfosResponse) XXX_Size() int

func (*TokenInfosResponse) XXX_Unmarshal

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

type TransactionFeeRecordRequest

type TransactionFeeRecordRequest struct {
	TxHash string `protobuf:"bytes,1,opt,name=tx_hash,json=txHash,proto3" json:"tx_hash,omitempty"`
}

func (*TransactionFeeRecordRequest) Descriptor

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

func (*TransactionFeeRecordRequest) GetTxHash

func (m *TransactionFeeRecordRequest) GetTxHash() string

func (*TransactionFeeRecordRequest) Marshal

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

func (*TransactionFeeRecordRequest) MarshalTo

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

func (*TransactionFeeRecordRequest) MarshalToSizedBuffer

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

func (*TransactionFeeRecordRequest) ProtoMessage

func (*TransactionFeeRecordRequest) ProtoMessage()

func (*TransactionFeeRecordRequest) Reset

func (m *TransactionFeeRecordRequest) Reset()

func (*TransactionFeeRecordRequest) Size

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

func (*TransactionFeeRecordRequest) String

func (m *TransactionFeeRecordRequest) String() string

func (*TransactionFeeRecordRequest) Unmarshal

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

func (*TransactionFeeRecordRequest) XXX_DiscardUnknown

func (m *TransactionFeeRecordRequest) XXX_DiscardUnknown()

func (*TransactionFeeRecordRequest) XXX_Marshal

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

func (*TransactionFeeRecordRequest) XXX_Merge

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

func (*TransactionFeeRecordRequest) XXX_Size

func (m *TransactionFeeRecordRequest) XXX_Size() int

func (*TransactionFeeRecordRequest) XXX_Unmarshal

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

type TransactionFeeRecordResponse

type TransactionFeeRecordResponse struct {
	Record *TxFeeRecord `protobuf:"bytes,1,opt,name=record,proto3" json:"record,omitempty"`
}

func (*TransactionFeeRecordResponse) Descriptor

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

func (*TransactionFeeRecordResponse) GetRecord

func (m *TransactionFeeRecordResponse) GetRecord() *TxFeeRecord

func (*TransactionFeeRecordResponse) Marshal

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

func (*TransactionFeeRecordResponse) MarshalTo

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

func (*TransactionFeeRecordResponse) MarshalToSizedBuffer

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

func (*TransactionFeeRecordResponse) ProtoMessage

func (*TransactionFeeRecordResponse) ProtoMessage()

func (*TransactionFeeRecordResponse) Reset

func (m *TransactionFeeRecordResponse) Reset()

func (*TransactionFeeRecordResponse) Size

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

func (*TransactionFeeRecordResponse) String

func (*TransactionFeeRecordResponse) Unmarshal

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

func (*TransactionFeeRecordResponse) XXX_DiscardUnknown

func (m *TransactionFeeRecordResponse) XXX_DiscardUnknown()

func (*TransactionFeeRecordResponse) XXX_Marshal

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

func (*TransactionFeeRecordResponse) XXX_Merge

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

func (*TransactionFeeRecordResponse) XXX_Size

func (m *TransactionFeeRecordResponse) XXX_Size() int

func (*TransactionFeeRecordResponse) XXX_Unmarshal

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

type TransactionStatusRequest

type TransactionStatusRequest struct {
	TxHash string `protobuf:"bytes,1,opt,name=tx_hash,json=txHash,proto3" json:"tx_hash,omitempty"`
}

func (*TransactionStatusRequest) Descriptor

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

func (*TransactionStatusRequest) GetTxHash

func (m *TransactionStatusRequest) GetTxHash() string

func (*TransactionStatusRequest) Marshal

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

func (*TransactionStatusRequest) MarshalTo

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

func (*TransactionStatusRequest) MarshalToSizedBuffer

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

func (*TransactionStatusRequest) ProtoMessage

func (*TransactionStatusRequest) ProtoMessage()

func (*TransactionStatusRequest) Reset

func (m *TransactionStatusRequest) Reset()

func (*TransactionStatusRequest) Size

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

func (*TransactionStatusRequest) String

func (m *TransactionStatusRequest) String() string

func (*TransactionStatusRequest) Unmarshal

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

func (*TransactionStatusRequest) XXX_DiscardUnknown

func (m *TransactionStatusRequest) XXX_DiscardUnknown()

func (*TransactionStatusRequest) XXX_Marshal

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

func (*TransactionStatusRequest) XXX_Merge

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

func (*TransactionStatusRequest) XXX_Size

func (m *TransactionStatusRequest) XXX_Size() int

func (*TransactionStatusRequest) XXX_Unmarshal

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

type TransactionStatusResponse

type TransactionStatusResponse struct {
	Status *TxStatus `protobuf:"bytes,1,opt,name=status,proto3" json:"status,omitempty"`
}

func (*TransactionStatusResponse) Descriptor

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

func (*TransactionStatusResponse) GetStatus

func (m *TransactionStatusResponse) GetStatus() *TxStatus

func (*TransactionStatusResponse) Marshal

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

func (*TransactionStatusResponse) MarshalTo

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

func (*TransactionStatusResponse) MarshalToSizedBuffer

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

func (*TransactionStatusResponse) ProtoMessage

func (*TransactionStatusResponse) ProtoMessage()

func (*TransactionStatusResponse) Reset

func (m *TransactionStatusResponse) Reset()

func (*TransactionStatusResponse) Size

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

func (*TransactionStatusResponse) String

func (m *TransactionStatusResponse) String() string

func (*TransactionStatusResponse) Unmarshal

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

func (*TransactionStatusResponse) XXX_DiscardUnknown

func (m *TransactionStatusResponse) XXX_DiscardUnknown()

func (*TransactionStatusResponse) XXX_Marshal

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

func (*TransactionStatusResponse) XXX_Merge

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

func (*TransactionStatusResponse) XXX_Size

func (m *TransactionStatusResponse) XXX_Size() int

func (*TransactionStatusResponse) XXX_Unmarshal

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

type TransferToChainEvent

type TransferToChainEvent struct {
	EventNonce       uint64                                 `protobuf:"varint,1,opt,name=event_nonce,json=eventNonce,proto3" json:"event_nonce,omitempty"`
	ExternalCoinId   string                                 `protobuf:"bytes,2,opt,name=external_coin_id,json=externalCoinId,proto3" json:"external_coin_id,omitempty"`
	Amount           github_com_cosmos_cosmos_sdk_types.Int `protobuf:"bytes,3,opt,name=amount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Int" json:"amount"`
	Fee              github_com_cosmos_cosmos_sdk_types.Int `protobuf:"bytes,4,opt,name=fee,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Int" json:"fee"`
	Sender           string                                 `protobuf:"bytes,5,opt,name=sender,proto3" json:"sender,omitempty"`
	ReceiverChainId  string                                 `protobuf:"bytes,6,opt,name=receiver_chain_id,json=receiverChainId,proto3" json:"receiver_chain_id,omitempty"`
	ExternalReceiver string                                 `protobuf:"bytes,7,opt,name=external_receiver,json=externalReceiver,proto3" json:"external_receiver,omitempty"`
	ExternalHeight   uint64                                 `protobuf:"varint,8,opt,name=external_height,json=externalHeight,proto3" json:"external_height,omitempty"`
	TxHash           string                                 `protobuf:"bytes,9,opt,name=tx_hash,json=txHash,proto3" json:"tx_hash,omitempty"`
}

TransferToChainEvent is submitted when the TransferToChainEvent is emitted by they mhub2 contract.

func (*TransferToChainEvent) Descriptor

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

func (*TransferToChainEvent) Equal

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

func (*TransferToChainEvent) GetEventNonce

func (m *TransferToChainEvent) GetEventNonce() uint64

func (*TransferToChainEvent) GetExternalCoinId

func (m *TransferToChainEvent) GetExternalCoinId() string

func (*TransferToChainEvent) GetExternalHeight

func (m *TransferToChainEvent) GetExternalHeight() uint64

func (*TransferToChainEvent) GetExternalReceiver

func (m *TransferToChainEvent) GetExternalReceiver() string

func (*TransferToChainEvent) GetReceiverChainId

func (m *TransferToChainEvent) GetReceiverChainId() string

func (*TransferToChainEvent) GetSender

func (m *TransferToChainEvent) GetSender() string

func (*TransferToChainEvent) GetTxHash

func (m *TransferToChainEvent) GetTxHash() string

func (*TransferToChainEvent) Hash

func (ttce *TransferToChainEvent) Hash() tmbytes.HexBytes

func (*TransferToChainEvent) Marshal

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

func (*TransferToChainEvent) MarshalTo

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

func (*TransferToChainEvent) MarshalToSizedBuffer

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

func (*TransferToChainEvent) ProtoMessage

func (*TransferToChainEvent) ProtoMessage()

func (*TransferToChainEvent) Reset

func (m *TransferToChainEvent) Reset()

func (*TransferToChainEvent) Size

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

func (*TransferToChainEvent) String

func (m *TransferToChainEvent) String() string

func (*TransferToChainEvent) Unmarshal

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

func (*TransferToChainEvent) Validate

func (ttce *TransferToChainEvent) Validate(chainId ChainID) error

func (*TransferToChainEvent) XXX_DiscardUnknown

func (m *TransferToChainEvent) XXX_DiscardUnknown()

func (*TransferToChainEvent) XXX_Marshal

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

func (*TransferToChainEvent) XXX_Merge

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

func (*TransferToChainEvent) XXX_Size

func (m *TransferToChainEvent) XXX_Size() int

func (*TransferToChainEvent) XXX_Unmarshal

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

type TxFeeRecord

type TxFeeRecord struct {
	ValCommission github_com_cosmos_cosmos_sdk_types.Int `` /* 140-byte string literal not displayed */
	ExternalFee   github_com_cosmos_cosmos_sdk_types.Int `` /* 134-byte string literal not displayed */
}

func (*TxFeeRecord) Descriptor

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

func (*TxFeeRecord) Marshal

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

func (*TxFeeRecord) MarshalTo

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

func (*TxFeeRecord) MarshalToSizedBuffer

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

func (*TxFeeRecord) ProtoMessage

func (*TxFeeRecord) ProtoMessage()

func (*TxFeeRecord) Reset

func (m *TxFeeRecord) Reset()

func (*TxFeeRecord) Size

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

func (*TxFeeRecord) String

func (m *TxFeeRecord) String() string

func (*TxFeeRecord) Unmarshal

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

func (*TxFeeRecord) XXX_DiscardUnknown

func (m *TxFeeRecord) XXX_DiscardUnknown()

func (*TxFeeRecord) XXX_Marshal

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

func (*TxFeeRecord) XXX_Merge

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

func (*TxFeeRecord) XXX_Size

func (m *TxFeeRecord) XXX_Size() int

func (*TxFeeRecord) XXX_Unmarshal

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

type TxStatus

type TxStatus struct {
	InTxHash  string       `protobuf:"bytes,1,opt,name=in_tx_hash,json=inTxHash,proto3" json:"in_tx_hash"`
	OutTxHash string       `protobuf:"bytes,2,opt,name=out_tx_hash,json=outTxHash,proto3" json:"out_tx_hash"`
	Status    TxStatusType `protobuf:"varint,3,opt,name=status,proto3,enum=mhub2.v1.TxStatusType" json:"status"`
}

func (*TxStatus) Descriptor

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

func (*TxStatus) GetInTxHash

func (m *TxStatus) GetInTxHash() string

func (*TxStatus) GetOutTxHash

func (m *TxStatus) GetOutTxHash() string

func (*TxStatus) GetStatus

func (m *TxStatus) GetStatus() TxStatusType

func (*TxStatus) Marshal

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

func (*TxStatus) MarshalTo

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

func (*TxStatus) MarshalToSizedBuffer

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

func (*TxStatus) ProtoMessage

func (*TxStatus) ProtoMessage()

func (*TxStatus) Reset

func (m *TxStatus) Reset()

func (*TxStatus) Size

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

func (*TxStatus) String

func (m *TxStatus) String() string

func (*TxStatus) Unmarshal

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

func (*TxStatus) XXX_DiscardUnknown

func (m *TxStatus) XXX_DiscardUnknown()

func (*TxStatus) XXX_Marshal

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

func (*TxStatus) XXX_Merge

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

func (*TxStatus) XXX_Size

func (m *TxStatus) XXX_Size() int

func (*TxStatus) XXX_Unmarshal

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

type TxStatusType

type TxStatusType int32
const (
	TX_STATUS_NOT_FOUND        TxStatusType = 0
	TX_STATUS_DEPOSIT_RECEIVED TxStatusType = 1
	TX_STATUS_BATCH_CREATED    TxStatusType = 2
	TX_STATUS_BATCH_EXECUTED   TxStatusType = 3
	TX_STATUS_REFUNDED         TxStatusType = 4
)

func (TxStatusType) EnumDescriptor

func (TxStatusType) EnumDescriptor() ([]byte, []int)

func (TxStatusType) String

func (x TxStatusType) String() string

type UnbatchedSendToExternalsRequest

type UnbatchedSendToExternalsRequest struct {
	SenderAddress string             `protobuf:"bytes,1,opt,name=sender_address,json=senderAddress,proto3" json:"sender_address,omitempty"`
	ChainId       string             `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	Pagination    *query.PageRequest `protobuf:"bytes,3,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*UnbatchedSendToExternalsRequest) Descriptor

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

func (*UnbatchedSendToExternalsRequest) GetChainId

func (m *UnbatchedSendToExternalsRequest) GetChainId() string

func (*UnbatchedSendToExternalsRequest) GetPagination

func (*UnbatchedSendToExternalsRequest) GetSenderAddress

func (m *UnbatchedSendToExternalsRequest) GetSenderAddress() string

func (*UnbatchedSendToExternalsRequest) Marshal

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

func (*UnbatchedSendToExternalsRequest) MarshalTo

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

func (*UnbatchedSendToExternalsRequest) MarshalToSizedBuffer

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

func (*UnbatchedSendToExternalsRequest) ProtoMessage

func (*UnbatchedSendToExternalsRequest) ProtoMessage()

func (*UnbatchedSendToExternalsRequest) Reset

func (*UnbatchedSendToExternalsRequest) Size

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

func (*UnbatchedSendToExternalsRequest) String

func (*UnbatchedSendToExternalsRequest) Unmarshal

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

func (*UnbatchedSendToExternalsRequest) XXX_DiscardUnknown

func (m *UnbatchedSendToExternalsRequest) XXX_DiscardUnknown()

func (*UnbatchedSendToExternalsRequest) XXX_Marshal

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

func (*UnbatchedSendToExternalsRequest) XXX_Merge

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

func (*UnbatchedSendToExternalsRequest) XXX_Size

func (m *UnbatchedSendToExternalsRequest) XXX_Size() int

func (*UnbatchedSendToExternalsRequest) XXX_Unmarshal

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

type UnbatchedSendToExternalsResponse

type UnbatchedSendToExternalsResponse struct {
	SendToExternals []*SendToExternal   `protobuf:"bytes,1,rep,name=send_to_externals,json=sendToExternals,proto3" json:"send_to_externals,omitempty"`
	ChainId         string              `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	Pagination      *query.PageResponse `protobuf:"bytes,3,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*UnbatchedSendToExternalsResponse) Descriptor

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

func (*UnbatchedSendToExternalsResponse) GetChainId

func (m *UnbatchedSendToExternalsResponse) GetChainId() string

func (*UnbatchedSendToExternalsResponse) GetPagination

func (*UnbatchedSendToExternalsResponse) GetSendToExternals

func (m *UnbatchedSendToExternalsResponse) GetSendToExternals() []*SendToExternal

func (*UnbatchedSendToExternalsResponse) Marshal

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

func (*UnbatchedSendToExternalsResponse) MarshalTo

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

func (*UnbatchedSendToExternalsResponse) MarshalToSizedBuffer

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

func (*UnbatchedSendToExternalsResponse) ProtoMessage

func (*UnbatchedSendToExternalsResponse) ProtoMessage()

func (*UnbatchedSendToExternalsResponse) Reset

func (*UnbatchedSendToExternalsResponse) Size

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

func (*UnbatchedSendToExternalsResponse) String

func (*UnbatchedSendToExternalsResponse) Unmarshal

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

func (*UnbatchedSendToExternalsResponse) XXX_DiscardUnknown

func (m *UnbatchedSendToExternalsResponse) XXX_DiscardUnknown()

func (*UnbatchedSendToExternalsResponse) XXX_Marshal

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

func (*UnbatchedSendToExternalsResponse) XXX_Merge

func (*UnbatchedSendToExternalsResponse) XXX_Size

func (m *UnbatchedSendToExternalsResponse) XXX_Size() int

func (*UnbatchedSendToExternalsResponse) XXX_Unmarshal

func (m *UnbatchedSendToExternalsResponse) XXX_Unmarshal(b []byte) error

type UnimplementedMsgServer

type UnimplementedMsgServer struct {
}

UnimplementedMsgServer can be embedded to have forward compatible implementations.

func (*UnimplementedMsgServer) CancelSendToExternal

func (*UnimplementedMsgServer) RequestBatchTx

func (*UnimplementedMsgServer) SendToExternal

func (*UnimplementedMsgServer) SetDelegateKeys

func (*UnimplementedMsgServer) SubmitExternalEvent

func (*UnimplementedMsgServer) SubmitTxConfirmation

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) BatchTx

func (*UnimplementedQueryServer) BatchTxConfirmations

func (*UnimplementedQueryServer) BatchTxFees

func (*UnimplementedQueryServer) BatchTxs

func (*UnimplementedQueryServer) BatchedSendToExternals

func (*UnimplementedQueryServer) ContractCallTx

func (*UnimplementedQueryServer) ContractCallTxs

func (*UnimplementedQueryServer) DelegateKeys

func (*UnimplementedQueryServer) DelegateKeysByOrchestrator

func (*UnimplementedQueryServer) DelegateKeysByValidator

func (*UnimplementedQueryServer) DenomToExternalId

func (*UnimplementedQueryServer) DiscountForHolder

func (*UnimplementedQueryServer) ExternalIdToDenom

func (*UnimplementedQueryServer) LastObservedSignerSetTx

func (*UnimplementedQueryServer) LastSubmittedExternalEvent

func (*UnimplementedQueryServer) LatestSignerSetTx

func (*UnimplementedQueryServer) Params

func (*UnimplementedQueryServer) SignerSetTx

func (*UnimplementedQueryServer) SignerSetTxConfirmations

func (*UnimplementedQueryServer) SignerSetTxs

func (*UnimplementedQueryServer) TokenInfos

func (*UnimplementedQueryServer) TransactionFeeRecord

func (*UnimplementedQueryServer) TransactionStatus

func (*UnimplementedQueryServer) UnbatchedSendToExternals

func (*UnimplementedQueryServer) UnsignedBatchTxs

func (*UnimplementedQueryServer) UnsignedContractCallTxs

func (*UnimplementedQueryServer) UnsignedSignerSetTxs

type UnsignedBatchTxsRequest

type UnsignedBatchTxsRequest struct {
	// NOTE: this is an sdk.AccAddress and can represent either the
	// orchestrator address or the cooresponding validator address
	Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"`
	ChainId string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*UnsignedBatchTxsRequest) Descriptor

func (*UnsignedBatchTxsRequest) Descriptor() ([]byte, []int)

func (*UnsignedBatchTxsRequest) GetAddress

func (m *UnsignedBatchTxsRequest) GetAddress() string

func (*UnsignedBatchTxsRequest) GetChainId

func (m *UnsignedBatchTxsRequest) GetChainId() string

func (*UnsignedBatchTxsRequest) Marshal

func (m *UnsignedBatchTxsRequest) Marshal() (dAtA []byte, err error)

func (*UnsignedBatchTxsRequest) MarshalTo

func (m *UnsignedBatchTxsRequest) MarshalTo(dAtA []byte) (int, error)

func (*UnsignedBatchTxsRequest) MarshalToSizedBuffer

func (m *UnsignedBatchTxsRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*UnsignedBatchTxsRequest) ProtoMessage

func (*UnsignedBatchTxsRequest) ProtoMessage()

func (*UnsignedBatchTxsRequest) Reset

func (m *UnsignedBatchTxsRequest) Reset()

func (*UnsignedBatchTxsRequest) Size

func (m *UnsignedBatchTxsRequest) Size() (n int)

func (*UnsignedBatchTxsRequest) String

func (m *UnsignedBatchTxsRequest) String() string

func (*UnsignedBatchTxsRequest) Unmarshal

func (m *UnsignedBatchTxsRequest) Unmarshal(dAtA []byte) error

func (*UnsignedBatchTxsRequest) XXX_DiscardUnknown

func (m *UnsignedBatchTxsRequest) XXX_DiscardUnknown()

func (*UnsignedBatchTxsRequest) XXX_Marshal

func (m *UnsignedBatchTxsRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*UnsignedBatchTxsRequest) XXX_Merge

func (m *UnsignedBatchTxsRequest) XXX_Merge(src proto.Message)

func (*UnsignedBatchTxsRequest) XXX_Size

func (m *UnsignedBatchTxsRequest) XXX_Size() int

func (*UnsignedBatchTxsRequest) XXX_Unmarshal

func (m *UnsignedBatchTxsRequest) XXX_Unmarshal(b []byte) error

type UnsignedBatchTxsResponse

type UnsignedBatchTxsResponse struct {
	// Note these are returned with the signature empty
	Batches []*BatchTx `protobuf:"bytes,1,rep,name=batches,proto3" json:"batches,omitempty"`
}

func (*UnsignedBatchTxsResponse) Descriptor

func (*UnsignedBatchTxsResponse) Descriptor() ([]byte, []int)

func (*UnsignedBatchTxsResponse) GetBatches

func (m *UnsignedBatchTxsResponse) GetBatches() []*BatchTx

func (*UnsignedBatchTxsResponse) Marshal

func (m *UnsignedBatchTxsResponse) Marshal() (dAtA []byte, err error)

func (*UnsignedBatchTxsResponse) MarshalTo

func (m *UnsignedBatchTxsResponse) MarshalTo(dAtA []byte) (int, error)

func (*UnsignedBatchTxsResponse) MarshalToSizedBuffer

func (m *UnsignedBatchTxsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*UnsignedBatchTxsResponse) ProtoMessage

func (*UnsignedBatchTxsResponse) ProtoMessage()

func (*UnsignedBatchTxsResponse) Reset

func (m *UnsignedBatchTxsResponse) Reset()

func (*UnsignedBatchTxsResponse) Size

func (m *UnsignedBatchTxsResponse) Size() (n int)

func (*UnsignedBatchTxsResponse) String

func (m *UnsignedBatchTxsResponse) String() string

func (*UnsignedBatchTxsResponse) Unmarshal

func (m *UnsignedBatchTxsResponse) Unmarshal(dAtA []byte) error

func (*UnsignedBatchTxsResponse) XXX_DiscardUnknown

func (m *UnsignedBatchTxsResponse) XXX_DiscardUnknown()

func (*UnsignedBatchTxsResponse) XXX_Marshal

func (m *UnsignedBatchTxsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*UnsignedBatchTxsResponse) XXX_Merge

func (m *UnsignedBatchTxsResponse) XXX_Merge(src proto.Message)

func (*UnsignedBatchTxsResponse) XXX_Size

func (m *UnsignedBatchTxsResponse) XXX_Size() int

func (*UnsignedBatchTxsResponse) XXX_Unmarshal

func (m *UnsignedBatchTxsResponse) XXX_Unmarshal(b []byte) error

type UnsignedContractCallTxsRequest

type UnsignedContractCallTxsRequest struct {
	Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"`
	ChainId string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

rpc UnsignedContractCallTxs

func (*UnsignedContractCallTxsRequest) Descriptor

func (*UnsignedContractCallTxsRequest) Descriptor() ([]byte, []int)

func (*UnsignedContractCallTxsRequest) GetAddress

func (m *UnsignedContractCallTxsRequest) GetAddress() string

func (*UnsignedContractCallTxsRequest) GetChainId

func (m *UnsignedContractCallTxsRequest) GetChainId() string

func (*UnsignedContractCallTxsRequest) Marshal

func (m *UnsignedContractCallTxsRequest) Marshal() (dAtA []byte, err error)

func (*UnsignedContractCallTxsRequest) MarshalTo

func (m *UnsignedContractCallTxsRequest) MarshalTo(dAtA []byte) (int, error)

func (*UnsignedContractCallTxsRequest) MarshalToSizedBuffer

func (m *UnsignedContractCallTxsRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*UnsignedContractCallTxsRequest) ProtoMessage

func (*UnsignedContractCallTxsRequest) ProtoMessage()

func (*UnsignedContractCallTxsRequest) Reset

func (m *UnsignedContractCallTxsRequest) Reset()

func (*UnsignedContractCallTxsRequest) Size

func (m *UnsignedContractCallTxsRequest) Size() (n int)

func (*UnsignedContractCallTxsRequest) String

func (*UnsignedContractCallTxsRequest) Unmarshal

func (m *UnsignedContractCallTxsRequest) Unmarshal(dAtA []byte) error

func (*UnsignedContractCallTxsRequest) XXX_DiscardUnknown

func (m *UnsignedContractCallTxsRequest) XXX_DiscardUnknown()

func (*UnsignedContractCallTxsRequest) XXX_Marshal

func (m *UnsignedContractCallTxsRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*UnsignedContractCallTxsRequest) XXX_Merge

func (m *UnsignedContractCallTxsRequest) XXX_Merge(src proto.Message)

func (*UnsignedContractCallTxsRequest) XXX_Size

func (m *UnsignedContractCallTxsRequest) XXX_Size() int

func (*UnsignedContractCallTxsRequest) XXX_Unmarshal

func (m *UnsignedContractCallTxsRequest) XXX_Unmarshal(b []byte) error

type UnsignedContractCallTxsResponse

type UnsignedContractCallTxsResponse struct {
	Calls []*ContractCallTx `protobuf:"bytes,1,rep,name=calls,proto3" json:"calls,omitempty"`
}

func (*UnsignedContractCallTxsResponse) Descriptor

func (*UnsignedContractCallTxsResponse) Descriptor() ([]byte, []int)

func (*UnsignedContractCallTxsResponse) GetCalls

func (*UnsignedContractCallTxsResponse) Marshal

func (m *UnsignedContractCallTxsResponse) Marshal() (dAtA []byte, err error)

func (*UnsignedContractCallTxsResponse) MarshalTo

func (m *UnsignedContractCallTxsResponse) MarshalTo(dAtA []byte) (int, error)

func (*UnsignedContractCallTxsResponse) MarshalToSizedBuffer

func (m *UnsignedContractCallTxsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*UnsignedContractCallTxsResponse) ProtoMessage

func (*UnsignedContractCallTxsResponse) ProtoMessage()

func (*UnsignedContractCallTxsResponse) Reset

func (*UnsignedContractCallTxsResponse) Size

func (m *UnsignedContractCallTxsResponse) Size() (n int)

func (*UnsignedContractCallTxsResponse) String

func (*UnsignedContractCallTxsResponse) Unmarshal

func (m *UnsignedContractCallTxsResponse) Unmarshal(dAtA []byte) error

func (*UnsignedContractCallTxsResponse) XXX_DiscardUnknown

func (m *UnsignedContractCallTxsResponse) XXX_DiscardUnknown()

func (*UnsignedContractCallTxsResponse) XXX_Marshal

func (m *UnsignedContractCallTxsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*UnsignedContractCallTxsResponse) XXX_Merge

func (m *UnsignedContractCallTxsResponse) XXX_Merge(src proto.Message)

func (*UnsignedContractCallTxsResponse) XXX_Size

func (m *UnsignedContractCallTxsResponse) XXX_Size() int

func (*UnsignedContractCallTxsResponse) XXX_Unmarshal

func (m *UnsignedContractCallTxsResponse) XXX_Unmarshal(b []byte) error

type UnsignedSignerSetTxsRequest

type UnsignedSignerSetTxsRequest struct {
	// NOTE: this is an sdk.AccAddress and can represent either the
	// orchestartor address or the cooresponding validator address
	Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"`
	ChainId string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

rpc UnsignedSignerSetTxs

func (*UnsignedSignerSetTxsRequest) Descriptor

func (*UnsignedSignerSetTxsRequest) Descriptor() ([]byte, []int)

func (*UnsignedSignerSetTxsRequest) GetAddress

func (m *UnsignedSignerSetTxsRequest) GetAddress() string

func (*UnsignedSignerSetTxsRequest) GetChainId

func (m *UnsignedSignerSetTxsRequest) GetChainId() string

func (*UnsignedSignerSetTxsRequest) Marshal

func (m *UnsignedSignerSetTxsRequest) Marshal() (dAtA []byte, err error)

func (*UnsignedSignerSetTxsRequest) MarshalTo

func (m *UnsignedSignerSetTxsRequest) MarshalTo(dAtA []byte) (int, error)

func (*UnsignedSignerSetTxsRequest) MarshalToSizedBuffer

func (m *UnsignedSignerSetTxsRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*UnsignedSignerSetTxsRequest) ProtoMessage

func (*UnsignedSignerSetTxsRequest) ProtoMessage()

func (*UnsignedSignerSetTxsRequest) Reset

func (m *UnsignedSignerSetTxsRequest) Reset()

func (*UnsignedSignerSetTxsRequest) Size

func (m *UnsignedSignerSetTxsRequest) Size() (n int)

func (*UnsignedSignerSetTxsRequest) String

func (m *UnsignedSignerSetTxsRequest) String() string

func (*UnsignedSignerSetTxsRequest) Unmarshal

func (m *UnsignedSignerSetTxsRequest) Unmarshal(dAtA []byte) error

func (*UnsignedSignerSetTxsRequest) XXX_DiscardUnknown

func (m *UnsignedSignerSetTxsRequest) XXX_DiscardUnknown()

func (*UnsignedSignerSetTxsRequest) XXX_Marshal

func (m *UnsignedSignerSetTxsRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*UnsignedSignerSetTxsRequest) XXX_Merge

func (m *UnsignedSignerSetTxsRequest) XXX_Merge(src proto.Message)

func (*UnsignedSignerSetTxsRequest) XXX_Size

func (m *UnsignedSignerSetTxsRequest) XXX_Size() int

func (*UnsignedSignerSetTxsRequest) XXX_Unmarshal

func (m *UnsignedSignerSetTxsRequest) XXX_Unmarshal(b []byte) error

type UnsignedSignerSetTxsResponse

type UnsignedSignerSetTxsResponse struct {
	SignerSets []*SignerSetTx `protobuf:"bytes,1,rep,name=signer_sets,json=signerSets,proto3" json:"signer_sets,omitempty"`
}

func (*UnsignedSignerSetTxsResponse) Descriptor

func (*UnsignedSignerSetTxsResponse) Descriptor() ([]byte, []int)

func (*UnsignedSignerSetTxsResponse) GetSignerSets

func (m *UnsignedSignerSetTxsResponse) GetSignerSets() []*SignerSetTx

func (*UnsignedSignerSetTxsResponse) Marshal

func (m *UnsignedSignerSetTxsResponse) Marshal() (dAtA []byte, err error)

func (*UnsignedSignerSetTxsResponse) MarshalTo

func (m *UnsignedSignerSetTxsResponse) MarshalTo(dAtA []byte) (int, error)

func (*UnsignedSignerSetTxsResponse) MarshalToSizedBuffer

func (m *UnsignedSignerSetTxsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*UnsignedSignerSetTxsResponse) ProtoMessage

func (*UnsignedSignerSetTxsResponse) ProtoMessage()

func (*UnsignedSignerSetTxsResponse) Reset

func (m *UnsignedSignerSetTxsResponse) Reset()

func (*UnsignedSignerSetTxsResponse) Size

func (m *UnsignedSignerSetTxsResponse) Size() (n int)

func (*UnsignedSignerSetTxsResponse) String

func (*UnsignedSignerSetTxsResponse) Unmarshal

func (m *UnsignedSignerSetTxsResponse) Unmarshal(dAtA []byte) error

func (*UnsignedSignerSetTxsResponse) XXX_DiscardUnknown

func (m *UnsignedSignerSetTxsResponse) XXX_DiscardUnknown()

func (*UnsignedSignerSetTxsResponse) XXX_Marshal

func (m *UnsignedSignerSetTxsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*UnsignedSignerSetTxsResponse) XXX_Merge

func (m *UnsignedSignerSetTxsResponse) XXX_Merge(src proto.Message)

func (*UnsignedSignerSetTxsResponse) XXX_Size

func (m *UnsignedSignerSetTxsResponse) XXX_Size() int

func (*UnsignedSignerSetTxsResponse) XXX_Unmarshal

func (m *UnsignedSignerSetTxsResponse) XXX_Unmarshal(b []byte) error

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL