types

package
v0.7.0 Latest Latest
Warning

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

Go to latest
Published: May 26, 2023 License: Apache-2.0 Imports: 46 Imported by: 1

Documentation

Overview

Package types is a generated GoMock package.

Package types is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

Index

Constants

View Source
const (
	EventTypeAck     = "acknowledgement"
	EventTypeTimeout = "timeout"

	AttributeKeyAckSuccess = "success"
	AttributeKeyAck        = "acknowledgement"
	AttributeKeyAckError   = "error"
)

IBC events

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

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

	// RouterKey defines the module's message routing key
	RouterKey = ModuleName

	// MemStoreKey defines the in-memory store key
	MemStoreKey = "mem_zoneconcierge"

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

	// Ordering defines the ordering the IBC module supports
	Ordering = channeltypes.ORDERED

	// PortID is the default port id that module binds to
	PortID = "zoneconcierge"
)
View Source
const (
	DefaultIbcPacketTimeoutSeconds uint32 = 60 * 60 * 24       // 24 hours
	MaxIbcPacketTimeoutSeconds     uint32 = 60 * 60 * 24 * 365 // 1 year
)
View Source
const DefaultIndex uint64 = 1

DefaultIndex is the default global index

Variables

View Source
var (
	ErrSample                   = errorsmod.Register(ModuleName, 1100, "sample error")
	ErrInvalidPacketTimeout     = errorsmod.Register(ModuleName, 1101, "invalid packet timeout")
	ErrInvalidVersion           = errorsmod.Register(ModuleName, 1102, "invalid version")
	ErrHeaderNotFound           = errorsmod.Register(ModuleName, 1103, "no header exists at this height")
	ErrInvalidHeader            = errorsmod.Register(ModuleName, 1104, "input header is invalid")
	ErrNoValidAncestorHeader    = errorsmod.Register(ModuleName, 1105, "no valid ancestor for this header")
	ErrForkNotFound             = errorsmod.Register(ModuleName, 1106, "cannot find fork")
	ErrInvalidForks             = errorsmod.Register(ModuleName, 1107, "input forks is invalid")
	ErrChainInfoNotFound        = errorsmod.Register(ModuleName, 1108, "no chain info exists")
	ErrEpochChainInfoNotFound   = errorsmod.Register(ModuleName, 1109, "no chain info exists at this epoch")
	ErrEpochHeadersNotFound     = errorsmod.Register(ModuleName, 1110, "no timestamped header exists at this epoch")
	ErrFinalizedEpochNotFound   = errorsmod.Register(ModuleName, 1111, "cannot find a finalized epoch")
	ErrInvalidProofEpochSealed  = errorsmod.Register(ModuleName, 1112, "invalid ProofEpochSealed")
	ErrInvalidMerkleProof       = errorsmod.Register(ModuleName, 1113, "invalid Merkle inclusion proof")
	ErrInvalidChainInfo         = errorsmod.Register(ModuleName, 1114, "invalid chain info")
	ErrFinalizingBTCTipNotFound = errorsmod.Register(ModuleName, 1115, "cannot find a finalizing BTC tip")
	ErrInvalidChainIDs          = errorsmod.Register(ModuleName, 1116, "chain ids contain duplicates or empty strings")
)

x/zoneconcierge module sentinel errors

View Source
var (
	ErrInvalidLengthGenesis        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowGenesis          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupGenesis = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	PortKey             = []byte{0x11} // PortKey defines the key to store the port ID in store
	ChainInfoKey        = []byte{0x12} // ChainInfoKey defines the key to store the chain info for each CZ in store
	CanonicalChainKey   = []byte{0x13} // CanonicalChainKey defines the key to store the canonical chain for each CZ in store
	ForkKey             = []byte{0x14} // ForkKey defines the key to store the forks for each CZ in store
	EpochChainInfoKey   = []byte{0x15} // EpochChainInfoKey defines the key to store each epoch's latests chain info for each CZ in store
	FinalizedEpochKey   = []byte{0x16} // FinalizedEpochKey defines the key to store the last finalised epoch
	FinalizingBTCTipKey = []byte{0x17} // FinalizingBTCTipKey defines the key to store the BTC tip when the last epoch is finalised
	ParamsKey           = []byte{0x18} // key prefix for the parameters
)
View Source
var (
	ErrInvalidLengthPacket        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowPacket          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupPacket = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthParams        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowParams          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupParams = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthQuery        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowQuery          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupQuery = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthTx        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowTx          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupTx = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthZoneconcierge        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowZoneconcierge          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupZoneconcierge = fmt.Errorf("proto: unexpected end of group")
)

Functions

func KeyPrefix

func KeyPrefix(p string) []byte

func RegisterCodec

func RegisterCodec(cdc *codec.LegacyAmino)

func RegisterInterfaces

func RegisterInterfaces(registry cdctypes.InterfaceRegistry)

func RegisterMsgServer

func RegisterMsgServer(s grpc1.Server, srv MsgServer)

func RegisterQueryHandler

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

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

func RegisterQueryHandlerClient

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

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

func RegisterQueryHandlerFromEndpoint

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

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

func RegisterQueryHandlerServer

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

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

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

Types

type AccountKeeper

type AccountKeeper interface {
	GetModuleAddress(name string) sdk.AccAddress
	GetModuleAccount(ctx sdk.Context, name string) types.ModuleAccountI
}

AccountKeeper defines the contract required for account APIs.

type BTCLightClientKeeper added in v0.7.0

type BTCLightClientKeeper interface {
	GetTipInfo(ctx sdk.Context) *btclctypes.BTCHeaderInfo
	GetBaseBTCHeader(ctx sdk.Context) *btclctypes.BTCHeaderInfo
	GetHighestCommonAncestor(ctx sdk.Context, header1 *btclctypes.BTCHeaderInfo, header2 *btclctypes.BTCHeaderInfo) *btclctypes.BTCHeaderInfo
	GetInOrderAncestorsUntil(ctx sdk.Context, descendant *btclctypes.BTCHeaderInfo, ancestor *btclctypes.BTCHeaderInfo) []*btclctypes.BTCHeaderInfo
	GetMainChainUpTo(ctx sdk.Context, depth uint64) []*btclctypes.BTCHeaderInfo
}

type BTCTimestamp added in v0.7.0

type BTCTimestamp struct {
	// header is the last CZ header in the finalized Babylon epoch
	Header *IndexedHeader `protobuf:"bytes,1,opt,name=header,proto3" json:"header,omitempty"`
	// btc_headers is BTC headers between
	// - the block AFTER the common ancestor of BTC tip at epoch `lastFinalizedEpoch-1` and BTC tip at epoch `lastFinalizedEpoch`
	// - BTC tip at epoch `lastFinalizedEpoch`
	// where `lastFinalizedEpoch` is the last finalised epoch in Babylon
	BtcHeaders []*types.BTCHeaderInfo `protobuf:"bytes,2,rep,name=btc_headers,json=btcHeaders,proto3" json:"btc_headers,omitempty"`
	// epoch_info is the metadata of the sealed epoch
	EpochInfo *types1.Epoch `protobuf:"bytes,3,opt,name=epoch_info,json=epochInfo,proto3" json:"epoch_info,omitempty"`
	// raw_checkpoint is the raw checkpoint that seals this epoch
	RawCheckpoint *types2.RawCheckpoint `protobuf:"bytes,4,opt,name=raw_checkpoint,json=rawCheckpoint,proto3" json:"raw_checkpoint,omitempty"`
	// btc_submission_key is position of two BTC txs that include the raw checkpoint of this epoch
	BtcSubmissionKey *types3.SubmissionKey `protobuf:"bytes,5,opt,name=btc_submission_key,json=btcSubmissionKey,proto3" json:"btc_submission_key,omitempty"`
	//
	// Proofs that the header is finalized
	Proof *ProofFinalizedChainInfo `protobuf:"bytes,6,opt,name=proof,proto3" json:"proof,omitempty"`
}

BTCTimestamp is a BTC timestamp that carries information of a BTC-finalised epoch It includes a number of BTC headers, a raw checkpoint, an epoch metadata, and a CZ header if there exists CZ headers checkpointed to this epoch. Upon a newly finalised epoch in Babylon, Babylon will send a BTC timestamp to each Cosmos zone that has phase-2 integration with Babylon via IBC.

func (*BTCTimestamp) Descriptor added in v0.7.0

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

func (*BTCTimestamp) GetBtcHeaders added in v0.7.0

func (m *BTCTimestamp) GetBtcHeaders() []*types.BTCHeaderInfo

func (*BTCTimestamp) GetBtcSubmissionKey added in v0.7.0

func (m *BTCTimestamp) GetBtcSubmissionKey() *types3.SubmissionKey

func (*BTCTimestamp) GetEpochInfo added in v0.7.0

func (m *BTCTimestamp) GetEpochInfo() *types1.Epoch

func (*BTCTimestamp) GetHeader added in v0.7.0

func (m *BTCTimestamp) GetHeader() *IndexedHeader

func (*BTCTimestamp) GetProof added in v0.7.0

func (m *BTCTimestamp) GetProof() *ProofFinalizedChainInfo

func (*BTCTimestamp) GetRawCheckpoint added in v0.7.0

func (m *BTCTimestamp) GetRawCheckpoint() *types2.RawCheckpoint

func (*BTCTimestamp) Marshal added in v0.7.0

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

func (*BTCTimestamp) MarshalTo added in v0.7.0

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

func (*BTCTimestamp) MarshalToSizedBuffer added in v0.7.0

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

func (*BTCTimestamp) ProtoMessage added in v0.7.0

func (*BTCTimestamp) ProtoMessage()

func (*BTCTimestamp) Reset added in v0.7.0

func (m *BTCTimestamp) Reset()

func (*BTCTimestamp) Size added in v0.7.0

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

func (*BTCTimestamp) String added in v0.7.0

func (m *BTCTimestamp) String() string

func (*BTCTimestamp) Unmarshal added in v0.7.0

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

func (*BTCTimestamp) XXX_DiscardUnknown added in v0.7.0

func (m *BTCTimestamp) XXX_DiscardUnknown()

func (*BTCTimestamp) XXX_Marshal added in v0.7.0

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

func (*BTCTimestamp) XXX_Merge added in v0.7.0

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

func (*BTCTimestamp) XXX_Size added in v0.7.0

func (m *BTCTimestamp) XXX_Size() int

func (*BTCTimestamp) XXX_Unmarshal added in v0.7.0

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

type BankKeeper

type BankKeeper interface {
	SendCoins(ctx sdk.Context, fromAddr sdk.AccAddress, toAddr sdk.AccAddress, amt sdk.Coins) error
	MintCoins(ctx sdk.Context, moduleName string, amt sdk.Coins) error
	BurnCoins(ctx sdk.Context, moduleName string, amt sdk.Coins) error
	SendCoinsFromModuleToAccount(ctx sdk.Context, senderModule string, recipientAddr sdk.AccAddress, amt sdk.Coins) error
	SendCoinsFromAccountToModule(ctx sdk.Context, senderAddr sdk.AccAddress, recipientModule string, amt sdk.Coins) error
	BlockedAddr(addr sdk.AccAddress) bool
}

BankKeeper defines the expected bank keeper

type BtcCheckpointKeeper

type BtcCheckpointKeeper interface {
	GetParams(ctx sdk.Context) (p btcctypes.Params)
	GetEpochData(ctx sdk.Context, e uint64) *btcctypes.EpochData
	GetBestSubmission(ctx sdk.Context, e uint64) (btcctypes.BtcStatus, *btcctypes.SubmissionKey, error)
	GetSubmissionData(ctx sdk.Context, sk btcctypes.SubmissionKey) *btcctypes.SubmissionData
	GetEpochBestSubmissionBtcInfo(ctx sdk.Context, ed *btcctypes.EpochData) *btcctypes.SubmissionBtcInfo
}

type ChainInfo

type ChainInfo struct {
	// chain_id is the ID of the chain
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// latest_header is the latest header in CZ's canonical chain
	LatestHeader *IndexedHeader `protobuf:"bytes,2,opt,name=latest_header,json=latestHeader,proto3" json:"latest_header,omitempty"`
	// latest_forks is the latest forks, formed as a series of IndexedHeader (from
	// low to high)
	LatestForks *Forks `protobuf:"bytes,3,opt,name=latest_forks,json=latestForks,proto3" json:"latest_forks,omitempty"`
	// timestamped_headers_count is the number of timestamped headers in CZ's
	// canonical chain
	TimestampedHeadersCount uint64 `` /* 133-byte string literal not displayed */
}

ChainInfo is the information of a CZ

func (*ChainInfo) Descriptor

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

func (*ChainInfo) Equal

func (ci *ChainInfo) Equal(ci2 *ChainInfo) bool

func (*ChainInfo) GetChainId

func (m *ChainInfo) GetChainId() string

func (*ChainInfo) GetLatestForks

func (m *ChainInfo) GetLatestForks() *Forks

func (*ChainInfo) GetLatestHeader

func (m *ChainInfo) GetLatestHeader() *IndexedHeader

func (*ChainInfo) GetTimestampedHeadersCount

func (m *ChainInfo) GetTimestampedHeadersCount() uint64

func (*ChainInfo) IsLatestHeader

func (ci *ChainInfo) IsLatestHeader(header *IndexedHeader) bool

IsLatestHeader checks if a given header is higher than the latest header in chain info

func (*ChainInfo) Marshal

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

func (*ChainInfo) MarshalTo

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

func (*ChainInfo) MarshalToSizedBuffer

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

func (*ChainInfo) ProtoMessage

func (*ChainInfo) ProtoMessage()

func (*ChainInfo) Reset

func (m *ChainInfo) Reset()

func (*ChainInfo) Size

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

func (*ChainInfo) String

func (m *ChainInfo) String() string

func (*ChainInfo) Unmarshal

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

func (*ChainInfo) ValidateBasic

func (ci *ChainInfo) ValidateBasic() error

func (*ChainInfo) XXX_DiscardUnknown

func (m *ChainInfo) XXX_DiscardUnknown()

func (*ChainInfo) XXX_Marshal

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

func (*ChainInfo) XXX_Merge

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

func (*ChainInfo) XXX_Size

func (m *ChainInfo) XXX_Size() int

func (*ChainInfo) XXX_Unmarshal

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

type ChannelKeeper

type ChannelKeeper interface {
	GetChannel(ctx sdk.Context, srcPort, srcChan string) (channel channeltypes.Channel, found bool)
	GetNextSequenceSend(ctx sdk.Context, portID, channelID string) (uint64, bool)
	GetAllChannels(ctx sdk.Context) (channels []channeltypes.IdentifiedChannel)
	GetChannelClientState(ctx sdk.Context, portID, channelID string) (string, ibcexported.ClientState, error)
}

ChannelKeeper defines the expected IBC channel keeper

type CheckpointingKeeper

type CheckpointingKeeper interface {
	GetBLSPubKeySet(ctx sdk.Context, epochNumber uint64) ([]*checkpointingtypes.ValidatorWithBlsKey, error)
	GetRawCheckpoint(ctx sdk.Context, epochNumber uint64) (*checkpointingtypes.RawCheckpointWithMeta, error)
}

type ClientKeeper

type ClientKeeper interface {
	GetClientConsensusState(ctx sdk.Context, clientID string) (connection ibcexported.ConsensusState, found bool)
}

ClientKeeper defines the expected IBC client keeper

type ConnectionKeeper

type ConnectionKeeper interface {
	GetConnection(ctx sdk.Context, connectionID string) (connection connectiontypes.ConnectionEnd, found bool)
}

ConnectionKeeper defines the expected IBC connection keeper

type EpochingKeeper

type EpochingKeeper interface {
	GetHistoricalEpoch(ctx sdk.Context, epochNumber uint64) (*epochingtypes.Epoch, error)
	GetEpoch(ctx sdk.Context) *epochingtypes.Epoch
	ProveAppHashInEpoch(ctx sdk.Context, height uint64, epochNumber uint64) (*tmcrypto.Proof, error)
}

type FinalizedChainInfo added in v0.6.0

type FinalizedChainInfo struct {
	// chain_id is the ID of the chain
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// finalized_chain_info is the info of the CZ
	FinalizedChainInfo *ChainInfo `protobuf:"bytes,2,opt,name=finalized_chain_info,json=finalizedChainInfo,proto3" json:"finalized_chain_info,omitempty"`
	// epoch_info is the metadata of the last BTC-finalised epoch
	EpochInfo *types1.Epoch `protobuf:"bytes,3,opt,name=epoch_info,json=epochInfo,proto3" json:"epoch_info,omitempty"`
	// raw_checkpoint is the raw checkpoint of this epoch
	RawCheckpoint *types2.RawCheckpoint `protobuf:"bytes,4,opt,name=raw_checkpoint,json=rawCheckpoint,proto3" json:"raw_checkpoint,omitempty"`
	// btc_submission_key is position of two BTC txs that include the raw
	// checkpoint of this epoch
	BtcSubmissionKey *types3.SubmissionKey `protobuf:"bytes,5,opt,name=btc_submission_key,json=btcSubmissionKey,proto3" json:"btc_submission_key,omitempty"`
	// proof is the proof that the chain info is finalized
	Proof *ProofFinalizedChainInfo `protobuf:"bytes,6,opt,name=proof,proto3" json:"proof,omitempty"`
}

FinalizedChainInfo is the information of a CZ that is BTC-finalised

func (*FinalizedChainInfo) Descriptor added in v0.6.0

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

func (*FinalizedChainInfo) GetBtcSubmissionKey added in v0.6.0

func (m *FinalizedChainInfo) GetBtcSubmissionKey() *types3.SubmissionKey

func (*FinalizedChainInfo) GetChainId added in v0.6.0

func (m *FinalizedChainInfo) GetChainId() string

func (*FinalizedChainInfo) GetEpochInfo added in v0.6.0

func (m *FinalizedChainInfo) GetEpochInfo() *types1.Epoch

func (*FinalizedChainInfo) GetFinalizedChainInfo added in v0.6.0

func (m *FinalizedChainInfo) GetFinalizedChainInfo() *ChainInfo

func (*FinalizedChainInfo) GetProof added in v0.6.0

func (*FinalizedChainInfo) GetRawCheckpoint added in v0.6.0

func (m *FinalizedChainInfo) GetRawCheckpoint() *types2.RawCheckpoint

func (*FinalizedChainInfo) Marshal added in v0.6.0

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

func (*FinalizedChainInfo) MarshalTo added in v0.6.0

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

func (*FinalizedChainInfo) MarshalToSizedBuffer added in v0.6.0

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

func (*FinalizedChainInfo) ProtoMessage added in v0.6.0

func (*FinalizedChainInfo) ProtoMessage()

func (*FinalizedChainInfo) Reset added in v0.6.0

func (m *FinalizedChainInfo) Reset()

func (*FinalizedChainInfo) Size added in v0.6.0

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

func (*FinalizedChainInfo) String added in v0.6.0

func (m *FinalizedChainInfo) String() string

func (*FinalizedChainInfo) Unmarshal added in v0.6.0

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

func (*FinalizedChainInfo) XXX_DiscardUnknown added in v0.6.0

func (m *FinalizedChainInfo) XXX_DiscardUnknown()

func (*FinalizedChainInfo) XXX_Marshal added in v0.6.0

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

func (*FinalizedChainInfo) XXX_Merge added in v0.6.0

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

func (*FinalizedChainInfo) XXX_Size added in v0.6.0

func (m *FinalizedChainInfo) XXX_Size() int

func (*FinalizedChainInfo) XXX_Unmarshal added in v0.6.0

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

type Forks

type Forks struct {
	// blocks is the list of non-canonical indexed headers at the same height
	Headers []*IndexedHeader `protobuf:"bytes,3,rep,name=headers,proto3" json:"headers,omitempty"`
}

Forks is a list of non-canonical `IndexedHeader`s at the same height. For example, assuming the following blockchain ``` A <- B <- C <- D <- E

\ -- D1
\ -- D2

``` Then the fork will be {[D1, D2]} where each item is in struct `IndexedBlock`.

Note that each `IndexedHeader` in the fork should have a valid quorum certificate. Such forks exist since Babylon considers CZs might have dishonest majority. Also note that the IBC-Go implementation will only consider the first header in a fork valid, since the subsequent headers cannot be verified without knowing the validator set in the previous header.

func (*Forks) Descriptor

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

func (*Forks) GetHeaders

func (m *Forks) GetHeaders() []*IndexedHeader

func (*Forks) Marshal

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

func (*Forks) MarshalTo

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

func (*Forks) MarshalToSizedBuffer

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

func (*Forks) ProtoMessage

func (*Forks) ProtoMessage()

func (*Forks) Reset

func (m *Forks) Reset()

func (*Forks) Size

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

func (*Forks) String

func (m *Forks) String() string

func (*Forks) Unmarshal

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

func (*Forks) XXX_DiscardUnknown

func (m *Forks) XXX_DiscardUnknown()

func (*Forks) XXX_Marshal

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

func (*Forks) XXX_Merge

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

func (*Forks) XXX_Size

func (m *Forks) XXX_Size() int

func (*Forks) XXX_Unmarshal

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

type GenesisState

type GenesisState struct {
	PortId string `protobuf:"bytes,1,opt,name=port_id,json=portId,proto3" json:"port_id,omitempty"`
	Params Params `protobuf:"bytes,2,opt,name=params,proto3" json:"params"`
}

GenesisState defines the zoneconcierge module's genesis state.

func DefaultGenesis

func DefaultGenesis() *GenesisState

DefaultGenesis returns the default genesis state

func NewGenesis added in v0.7.0

func NewGenesis(params Params) *GenesisState

NewGenesis creates a new GenesisState instance

func (*GenesisState) Descriptor

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

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() Params

func (*GenesisState) GetPortId

func (m *GenesisState) GetPortId() string

func (*GenesisState) Marshal

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

func (*GenesisState) MarshalTo

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

func (*GenesisState) MarshalToSizedBuffer

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

func (*GenesisState) ProtoMessage

func (*GenesisState) ProtoMessage()

func (*GenesisState) Reset

func (m *GenesisState) Reset()

func (*GenesisState) Size

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

func (*GenesisState) String

func (m *GenesisState) String() string

func (*GenesisState) Unmarshal

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

func (GenesisState) Validate

func (gs GenesisState) Validate() error

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

func (*GenesisState) XXX_DiscardUnknown

func (m *GenesisState) XXX_DiscardUnknown()

func (*GenesisState) XXX_Marshal

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

func (*GenesisState) XXX_Merge

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

func (*GenesisState) XXX_Size

func (m *GenesisState) XXX_Size() int

func (*GenesisState) XXX_Unmarshal

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

type ICS4Wrapper

type ICS4Wrapper interface {
	SendPacket(
		ctx sdk.Context,
		channelCap *capabilitytypes.Capability,
		sourcePort string,
		sourceChannel string,
		timeoutHeight clienttypes.Height,
		timeoutTimestamp uint64,
		data []byte,
	) (uint64, error)
}

ICS4Wrapper defines the expected ICS4Wrapper for middleware

type IndexedHeader

type IndexedHeader struct {
	// chain_id is the unique ID of the chain
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// hash is the hash of this header
	Hash []byte `protobuf:"bytes,2,opt,name=hash,proto3" json:"hash,omitempty"`
	// height is the height of this header on CZ ledger
	// (hash, height) jointly provides the position of the header on CZ ledger
	Height uint64 `protobuf:"varint,3,opt,name=height,proto3" json:"height,omitempty"`
	// time is the timestamp of this header on CZ ledger
	// it is needed for CZ to unbond all mature validators/delegations
	// before this timestamp when this header is BTC-finalised
	Time *time.Time `protobuf:"bytes,4,opt,name=time,proto3,stdtime" json:"time,omitempty"`
	// babylon_header is the header of the babylon block that includes this CZ
	// header
	BabylonHeader *types.Header `protobuf:"bytes,5,opt,name=babylon_header,json=babylonHeader,proto3" json:"babylon_header,omitempty"`
	// epoch is the epoch number of this header on Babylon ledger
	BabylonEpoch uint64 `protobuf:"varint,6,opt,name=babylon_epoch,json=babylonEpoch,proto3" json:"babylon_epoch,omitempty"`
	// babylon_tx_hash is the hash of the tx that includes this header
	// (babylon_block_height, babylon_tx_hash) jointly provides the position of
	// the header on Babylon ledger
	BabylonTxHash []byte `protobuf:"bytes,7,opt,name=babylon_tx_hash,json=babylonTxHash,proto3" json:"babylon_tx_hash,omitempty"`
}

IndexedHeader is the metadata of a CZ header

func (*IndexedHeader) Descriptor

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

func (*IndexedHeader) Equal

func (ih *IndexedHeader) Equal(ih2 *IndexedHeader) bool

func (*IndexedHeader) GetBabylonEpoch

func (m *IndexedHeader) GetBabylonEpoch() uint64

func (*IndexedHeader) GetBabylonHeader

func (m *IndexedHeader) GetBabylonHeader() *types.Header

func (*IndexedHeader) GetBabylonTxHash

func (m *IndexedHeader) GetBabylonTxHash() []byte

func (*IndexedHeader) GetChainId

func (m *IndexedHeader) GetChainId() string

func (*IndexedHeader) GetHash

func (m *IndexedHeader) GetHash() []byte

func (*IndexedHeader) GetHeight

func (m *IndexedHeader) GetHeight() uint64

func (*IndexedHeader) GetTime added in v0.7.0

func (m *IndexedHeader) GetTime() *time.Time

func (*IndexedHeader) Marshal

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

func (*IndexedHeader) MarshalTo

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

func (*IndexedHeader) MarshalToSizedBuffer

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

func (*IndexedHeader) ProtoMessage

func (*IndexedHeader) ProtoMessage()

func (*IndexedHeader) Reset

func (m *IndexedHeader) Reset()

func (*IndexedHeader) Size

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

func (*IndexedHeader) String

func (m *IndexedHeader) String() string

func (*IndexedHeader) Unmarshal

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

func (*IndexedHeader) ValidateBasic

func (ih *IndexedHeader) ValidateBasic() error

func (*IndexedHeader) XXX_DiscardUnknown

func (m *IndexedHeader) XXX_DiscardUnknown()

func (*IndexedHeader) XXX_Marshal

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

func (*IndexedHeader) XXX_Merge

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

func (*IndexedHeader) XXX_Size

func (m *IndexedHeader) XXX_Size() int

func (*IndexedHeader) XXX_Unmarshal

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

type MockAccountKeeper

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

MockAccountKeeper is a mock of AccountKeeper interface.

func NewMockAccountKeeper

func NewMockAccountKeeper(ctrl *gomock.Controller) *MockAccountKeeper

NewMockAccountKeeper creates a new mock instance.

func (*MockAccountKeeper) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockAccountKeeper) GetModuleAccount

func (m *MockAccountKeeper) GetModuleAccount(ctx types3.Context, name string) types4.ModuleAccountI

GetModuleAccount mocks base method.

func (*MockAccountKeeper) GetModuleAddress

func (m *MockAccountKeeper) GetModuleAddress(name string) types3.AccAddress

GetModuleAddress mocks base method.

type MockAccountKeeperMockRecorder

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

MockAccountKeeperMockRecorder is the mock recorder for MockAccountKeeper.

func (*MockAccountKeeperMockRecorder) GetModuleAccount

func (mr *MockAccountKeeperMockRecorder) GetModuleAccount(ctx, name interface{}) *gomock.Call

GetModuleAccount indicates an expected call of GetModuleAccount.

func (*MockAccountKeeperMockRecorder) GetModuleAddress

func (mr *MockAccountKeeperMockRecorder) GetModuleAddress(name interface{}) *gomock.Call

GetModuleAddress indicates an expected call of GetModuleAddress.

type MockBTCLightClientKeeper added in v0.7.0

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

MockBTCLightClientKeeper is a mock of BTCLightClientKeeper interface.

func NewMockBTCLightClientKeeper added in v0.7.0

func NewMockBTCLightClientKeeper(ctrl *gomock.Controller) *MockBTCLightClientKeeper

NewMockBTCLightClientKeeper creates a new mock instance.

func (*MockBTCLightClientKeeper) EXPECT added in v0.7.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockBTCLightClientKeeper) GetBaseBTCHeader added in v0.7.0

func (m *MockBTCLightClientKeeper) GetBaseBTCHeader(ctx types3.Context) *types0.BTCHeaderInfo

GetBaseBTCHeader mocks base method.

func (*MockBTCLightClientKeeper) GetHighestCommonAncestor added in v0.7.0

func (m *MockBTCLightClientKeeper) GetHighestCommonAncestor(ctx types3.Context, header1, header2 *types0.BTCHeaderInfo) *types0.BTCHeaderInfo

GetHighestCommonAncestor mocks base method.

func (*MockBTCLightClientKeeper) GetInOrderAncestorsUntil added in v0.7.0

func (m *MockBTCLightClientKeeper) GetInOrderAncestorsUntil(ctx types3.Context, descendant, ancestor *types0.BTCHeaderInfo) []*types0.BTCHeaderInfo

GetInOrderAncestorsUntil mocks base method.

func (*MockBTCLightClientKeeper) GetMainChainUpTo added in v0.7.0

func (m *MockBTCLightClientKeeper) GetMainChainUpTo(ctx types3.Context, depth uint64) []*types0.BTCHeaderInfo

GetMainChainUpTo mocks base method.

func (*MockBTCLightClientKeeper) GetTipInfo added in v0.7.0

GetTipInfo mocks base method.

type MockBTCLightClientKeeperMockRecorder added in v0.7.0

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

MockBTCLightClientKeeperMockRecorder is the mock recorder for MockBTCLightClientKeeper.

func (*MockBTCLightClientKeeperMockRecorder) GetBaseBTCHeader added in v0.7.0

func (mr *MockBTCLightClientKeeperMockRecorder) GetBaseBTCHeader(ctx interface{}) *gomock.Call

GetBaseBTCHeader indicates an expected call of GetBaseBTCHeader.

func (*MockBTCLightClientKeeperMockRecorder) GetHighestCommonAncestor added in v0.7.0

func (mr *MockBTCLightClientKeeperMockRecorder) GetHighestCommonAncestor(ctx, header1, header2 interface{}) *gomock.Call

GetHighestCommonAncestor indicates an expected call of GetHighestCommonAncestor.

func (*MockBTCLightClientKeeperMockRecorder) GetInOrderAncestorsUntil added in v0.7.0

func (mr *MockBTCLightClientKeeperMockRecorder) GetInOrderAncestorsUntil(ctx, descendant, ancestor interface{}) *gomock.Call

GetInOrderAncestorsUntil indicates an expected call of GetInOrderAncestorsUntil.

func (*MockBTCLightClientKeeperMockRecorder) GetMainChainUpTo added in v0.7.0

func (mr *MockBTCLightClientKeeperMockRecorder) GetMainChainUpTo(ctx, depth interface{}) *gomock.Call

GetMainChainUpTo indicates an expected call of GetMainChainUpTo.

func (*MockBTCLightClientKeeperMockRecorder) GetTipInfo added in v0.7.0

func (mr *MockBTCLightClientKeeperMockRecorder) GetTipInfo(ctx interface{}) *gomock.Call

GetTipInfo indicates an expected call of GetTipInfo.

type MockBankKeeper

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

MockBankKeeper is a mock of BankKeeper interface.

func NewMockBankKeeper

func NewMockBankKeeper(ctrl *gomock.Controller) *MockBankKeeper

NewMockBankKeeper creates a new mock instance.

func (*MockBankKeeper) BlockedAddr

func (m *MockBankKeeper) BlockedAddr(addr types3.AccAddress) bool

BlockedAddr mocks base method.

func (*MockBankKeeper) BurnCoins

func (m *MockBankKeeper) BurnCoins(ctx types3.Context, moduleName string, amt types3.Coins) error

BurnCoins mocks base method.

func (*MockBankKeeper) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockBankKeeper) MintCoins

func (m *MockBankKeeper) MintCoins(ctx types3.Context, moduleName string, amt types3.Coins) error

MintCoins mocks base method.

func (*MockBankKeeper) SendCoins

func (m *MockBankKeeper) SendCoins(ctx types3.Context, fromAddr, toAddr types3.AccAddress, amt types3.Coins) error

SendCoins mocks base method.

func (*MockBankKeeper) SendCoinsFromAccountToModule

func (m *MockBankKeeper) SendCoinsFromAccountToModule(ctx types3.Context, senderAddr types3.AccAddress, recipientModule string, amt types3.Coins) error

SendCoinsFromAccountToModule mocks base method.

func (*MockBankKeeper) SendCoinsFromModuleToAccount

func (m *MockBankKeeper) SendCoinsFromModuleToAccount(ctx types3.Context, senderModule string, recipientAddr types3.AccAddress, amt types3.Coins) error

SendCoinsFromModuleToAccount mocks base method.

type MockBankKeeperMockRecorder

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

MockBankKeeperMockRecorder is the mock recorder for MockBankKeeper.

func (*MockBankKeeperMockRecorder) BlockedAddr

func (mr *MockBankKeeperMockRecorder) BlockedAddr(addr interface{}) *gomock.Call

BlockedAddr indicates an expected call of BlockedAddr.

func (*MockBankKeeperMockRecorder) BurnCoins

func (mr *MockBankKeeperMockRecorder) BurnCoins(ctx, moduleName, amt interface{}) *gomock.Call

BurnCoins indicates an expected call of BurnCoins.

func (*MockBankKeeperMockRecorder) MintCoins

func (mr *MockBankKeeperMockRecorder) MintCoins(ctx, moduleName, amt interface{}) *gomock.Call

MintCoins indicates an expected call of MintCoins.

func (*MockBankKeeperMockRecorder) SendCoins

func (mr *MockBankKeeperMockRecorder) SendCoins(ctx, fromAddr, toAddr, amt interface{}) *gomock.Call

SendCoins indicates an expected call of SendCoins.

func (*MockBankKeeperMockRecorder) SendCoinsFromAccountToModule

func (mr *MockBankKeeperMockRecorder) SendCoinsFromAccountToModule(ctx, senderAddr, recipientModule, amt interface{}) *gomock.Call

SendCoinsFromAccountToModule indicates an expected call of SendCoinsFromAccountToModule.

func (*MockBankKeeperMockRecorder) SendCoinsFromModuleToAccount

func (mr *MockBankKeeperMockRecorder) SendCoinsFromModuleToAccount(ctx, senderModule, recipientAddr, amt interface{}) *gomock.Call

SendCoinsFromModuleToAccount indicates an expected call of SendCoinsFromModuleToAccount.

type MockBtcCheckpointKeeper

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

MockBtcCheckpointKeeper is a mock of BtcCheckpointKeeper interface.

func NewMockBtcCheckpointKeeper

func NewMockBtcCheckpointKeeper(ctrl *gomock.Controller) *MockBtcCheckpointKeeper

NewMockBtcCheckpointKeeper creates a new mock instance.

func (*MockBtcCheckpointKeeper) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockBtcCheckpointKeeper) GetBestSubmission

GetBestSubmission mocks base method.

func (*MockBtcCheckpointKeeper) GetEpochBestSubmissionBtcInfo added in v0.7.0

func (m *MockBtcCheckpointKeeper) GetEpochBestSubmissionBtcInfo(ctx types3.Context, ed *types.EpochData) *types.SubmissionBtcInfo

GetEpochBestSubmissionBtcInfo mocks base method.

func (*MockBtcCheckpointKeeper) GetEpochData added in v0.7.0

func (m *MockBtcCheckpointKeeper) GetEpochData(ctx types3.Context, e uint64) *types.EpochData

GetEpochData mocks base method.

func (*MockBtcCheckpointKeeper) GetParams added in v0.7.0

GetParams mocks base method.

func (*MockBtcCheckpointKeeper) GetSubmissionData

GetSubmissionData mocks base method.

type MockBtcCheckpointKeeperMockRecorder

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

MockBtcCheckpointKeeperMockRecorder is the mock recorder for MockBtcCheckpointKeeper.

func (*MockBtcCheckpointKeeperMockRecorder) GetBestSubmission

func (mr *MockBtcCheckpointKeeperMockRecorder) GetBestSubmission(ctx, e interface{}) *gomock.Call

GetBestSubmission indicates an expected call of GetBestSubmission.

func (*MockBtcCheckpointKeeperMockRecorder) GetEpochBestSubmissionBtcInfo added in v0.7.0

func (mr *MockBtcCheckpointKeeperMockRecorder) GetEpochBestSubmissionBtcInfo(ctx, ed interface{}) *gomock.Call

GetEpochBestSubmissionBtcInfo indicates an expected call of GetEpochBestSubmissionBtcInfo.

func (*MockBtcCheckpointKeeperMockRecorder) GetEpochData added in v0.7.0

func (mr *MockBtcCheckpointKeeperMockRecorder) GetEpochData(ctx, e interface{}) *gomock.Call

GetEpochData indicates an expected call of GetEpochData.

func (*MockBtcCheckpointKeeperMockRecorder) GetParams added in v0.7.0

func (mr *MockBtcCheckpointKeeperMockRecorder) GetParams(ctx interface{}) *gomock.Call

GetParams indicates an expected call of GetParams.

func (*MockBtcCheckpointKeeperMockRecorder) GetSubmissionData

func (mr *MockBtcCheckpointKeeperMockRecorder) GetSubmissionData(ctx, sk interface{}) *gomock.Call

GetSubmissionData indicates an expected call of GetSubmissionData.

type MockChannelKeeper

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

MockChannelKeeper is a mock of ChannelKeeper interface.

func NewMockChannelKeeper

func NewMockChannelKeeper(ctrl *gomock.Controller) *MockChannelKeeper

NewMockChannelKeeper creates a new mock instance.

func (*MockChannelKeeper) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockChannelKeeper) GetAllChannels

func (m *MockChannelKeeper) GetAllChannels(ctx types3.Context) []types8.IdentifiedChannel

GetAllChannels mocks base method.

func (*MockChannelKeeper) GetChannel

func (m *MockChannelKeeper) GetChannel(ctx types3.Context, srcPort, srcChan string) (types8.Channel, bool)

GetChannel mocks base method.

func (*MockChannelKeeper) GetChannelClientState added in v0.7.0

func (m *MockChannelKeeper) GetChannelClientState(ctx types3.Context, portID, channelID string) (string, exported.ClientState, error)

GetChannelClientState mocks base method.

func (*MockChannelKeeper) GetNextSequenceSend

func (m *MockChannelKeeper) GetNextSequenceSend(ctx types3.Context, portID, channelID string) (uint64, bool)

GetNextSequenceSend mocks base method.

type MockChannelKeeperMockRecorder

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

MockChannelKeeperMockRecorder is the mock recorder for MockChannelKeeper.

func (*MockChannelKeeperMockRecorder) GetAllChannels

func (mr *MockChannelKeeperMockRecorder) GetAllChannels(ctx interface{}) *gomock.Call

GetAllChannels indicates an expected call of GetAllChannels.

func (*MockChannelKeeperMockRecorder) GetChannel

func (mr *MockChannelKeeperMockRecorder) GetChannel(ctx, srcPort, srcChan interface{}) *gomock.Call

GetChannel indicates an expected call of GetChannel.

func (*MockChannelKeeperMockRecorder) GetChannelClientState added in v0.7.0

func (mr *MockChannelKeeperMockRecorder) GetChannelClientState(ctx, portID, channelID interface{}) *gomock.Call

GetChannelClientState indicates an expected call of GetChannelClientState.

func (*MockChannelKeeperMockRecorder) GetNextSequenceSend

func (mr *MockChannelKeeperMockRecorder) GetNextSequenceSend(ctx, portID, channelID interface{}) *gomock.Call

GetNextSequenceSend indicates an expected call of GetNextSequenceSend.

type MockCheckpointingKeeper

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

MockCheckpointingKeeper is a mock of CheckpointingKeeper interface.

func NewMockCheckpointingKeeper

func NewMockCheckpointingKeeper(ctrl *gomock.Controller) *MockCheckpointingKeeper

NewMockCheckpointingKeeper creates a new mock instance.

func (*MockCheckpointingKeeper) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockCheckpointingKeeper) GetBLSPubKeySet

func (m *MockCheckpointingKeeper) GetBLSPubKeySet(ctx types3.Context, epochNumber uint64) ([]*types1.ValidatorWithBlsKey, error)

GetBLSPubKeySet mocks base method.

func (*MockCheckpointingKeeper) GetRawCheckpoint

func (m *MockCheckpointingKeeper) GetRawCheckpoint(ctx types3.Context, epochNumber uint64) (*types1.RawCheckpointWithMeta, error)

GetRawCheckpoint mocks base method.

type MockCheckpointingKeeperMockRecorder

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

MockCheckpointingKeeperMockRecorder is the mock recorder for MockCheckpointingKeeper.

func (*MockCheckpointingKeeperMockRecorder) GetBLSPubKeySet

func (mr *MockCheckpointingKeeperMockRecorder) GetBLSPubKeySet(ctx, epochNumber interface{}) *gomock.Call

GetBLSPubKeySet indicates an expected call of GetBLSPubKeySet.

func (*MockCheckpointingKeeperMockRecorder) GetRawCheckpoint

func (mr *MockCheckpointingKeeperMockRecorder) GetRawCheckpoint(ctx, epochNumber interface{}) *gomock.Call

GetRawCheckpoint indicates an expected call of GetRawCheckpoint.

type MockClientKeeper

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

MockClientKeeper is a mock of ClientKeeper interface.

func NewMockClientKeeper

func NewMockClientKeeper(ctrl *gomock.Controller) *MockClientKeeper

NewMockClientKeeper creates a new mock instance.

func (*MockClientKeeper) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockClientKeeper) GetClientConsensusState

func (m *MockClientKeeper) GetClientConsensusState(ctx types3.Context, clientID string) (exported.ConsensusState, bool)

GetClientConsensusState mocks base method.

type MockClientKeeperMockRecorder

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

MockClientKeeperMockRecorder is the mock recorder for MockClientKeeper.

func (*MockClientKeeperMockRecorder) GetClientConsensusState

func (mr *MockClientKeeperMockRecorder) GetClientConsensusState(ctx, clientID interface{}) *gomock.Call

GetClientConsensusState indicates an expected call of GetClientConsensusState.

type MockConnectionKeeper

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

MockConnectionKeeper is a mock of ConnectionKeeper interface.

func NewMockConnectionKeeper

func NewMockConnectionKeeper(ctrl *gomock.Controller) *MockConnectionKeeper

NewMockConnectionKeeper creates a new mock instance.

func (*MockConnectionKeeper) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockConnectionKeeper) GetConnection

func (m *MockConnectionKeeper) GetConnection(ctx types3.Context, connectionID string) (types7.ConnectionEnd, bool)

GetConnection mocks base method.

type MockConnectionKeeperMockRecorder

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

MockConnectionKeeperMockRecorder is the mock recorder for MockConnectionKeeper.

func (*MockConnectionKeeperMockRecorder) GetConnection

func (mr *MockConnectionKeeperMockRecorder) GetConnection(ctx, connectionID interface{}) *gomock.Call

GetConnection indicates an expected call of GetConnection.

type MockEpochingKeeper

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

MockEpochingKeeper is a mock of EpochingKeeper interface.

func NewMockEpochingKeeper

func NewMockEpochingKeeper(ctrl *gomock.Controller) *MockEpochingKeeper

NewMockEpochingKeeper creates a new mock instance.

func (*MockEpochingKeeper) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockEpochingKeeper) GetEpoch

func (m *MockEpochingKeeper) GetEpoch(ctx types3.Context) *types2.Epoch

GetEpoch mocks base method.

func (*MockEpochingKeeper) GetHistoricalEpoch

func (m *MockEpochingKeeper) GetHistoricalEpoch(ctx types3.Context, epochNumber uint64) (*types2.Epoch, error)

GetHistoricalEpoch mocks base method.

func (*MockEpochingKeeper) ProveAppHashInEpoch

func (m *MockEpochingKeeper) ProveAppHashInEpoch(ctx types3.Context, height, epochNumber uint64) (*crypto.Proof, error)

ProveAppHashInEpoch mocks base method.

type MockEpochingKeeperMockRecorder

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

MockEpochingKeeperMockRecorder is the mock recorder for MockEpochingKeeper.

func (*MockEpochingKeeperMockRecorder) GetEpoch

func (mr *MockEpochingKeeperMockRecorder) GetEpoch(ctx interface{}) *gomock.Call

GetEpoch indicates an expected call of GetEpoch.

func (*MockEpochingKeeperMockRecorder) GetHistoricalEpoch

func (mr *MockEpochingKeeperMockRecorder) GetHistoricalEpoch(ctx, epochNumber interface{}) *gomock.Call

GetHistoricalEpoch indicates an expected call of GetHistoricalEpoch.

func (*MockEpochingKeeperMockRecorder) ProveAppHashInEpoch

func (mr *MockEpochingKeeperMockRecorder) ProveAppHashInEpoch(ctx, height, epochNumber interface{}) *gomock.Call

ProveAppHashInEpoch indicates an expected call of ProveAppHashInEpoch.

type MockICS4Wrapper

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

MockICS4Wrapper is a mock of ICS4Wrapper interface.

func NewMockICS4Wrapper

func NewMockICS4Wrapper(ctrl *gomock.Controller) *MockICS4Wrapper

NewMockICS4Wrapper creates a new mock instance.

func (*MockICS4Wrapper) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockICS4Wrapper) SendPacket

func (m *MockICS4Wrapper) SendPacket(ctx types3.Context, channelCap *types5.Capability, sourcePort, sourceChannel string, timeoutHeight types6.Height, timeoutTimestamp uint64, data []byte) (uint64, error)

SendPacket mocks base method.

type MockICS4WrapperMockRecorder

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

MockICS4WrapperMockRecorder is the mock recorder for MockICS4Wrapper.

func (*MockICS4WrapperMockRecorder) SendPacket

func (mr *MockICS4WrapperMockRecorder) SendPacket(ctx, channelCap, sourcePort, sourceChannel, timeoutHeight, timeoutTimestamp, data interface{}) *gomock.Call

SendPacket indicates an expected call of SendPacket.

type MockPortKeeper

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

MockPortKeeper is a mock of PortKeeper interface.

func NewMockPortKeeper

func NewMockPortKeeper(ctrl *gomock.Controller) *MockPortKeeper

NewMockPortKeeper creates a new mock instance.

func (*MockPortKeeper) BindPort

func (m *MockPortKeeper) BindPort(ctx types3.Context, portID string) *types5.Capability

BindPort mocks base method.

func (*MockPortKeeper) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

type MockPortKeeperMockRecorder

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

MockPortKeeperMockRecorder is the mock recorder for MockPortKeeper.

func (*MockPortKeeperMockRecorder) BindPort

func (mr *MockPortKeeperMockRecorder) BindPort(ctx, portID interface{}) *gomock.Call

BindPort indicates an expected call of BindPort.

type MockScopedKeeper

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

MockScopedKeeper is a mock of ScopedKeeper interface.

func NewMockScopedKeeper

func NewMockScopedKeeper(ctrl *gomock.Controller) *MockScopedKeeper

NewMockScopedKeeper creates a new mock instance.

func (*MockScopedKeeper) AuthenticateCapability

func (m *MockScopedKeeper) AuthenticateCapability(ctx types3.Context, cap *types5.Capability, name string) bool

AuthenticateCapability mocks base method.

func (*MockScopedKeeper) ClaimCapability

func (m *MockScopedKeeper) ClaimCapability(ctx types3.Context, cap *types5.Capability, name string) error

ClaimCapability mocks base method.

func (*MockScopedKeeper) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockScopedKeeper) GetCapability

func (m *MockScopedKeeper) GetCapability(ctx types3.Context, name string) (*types5.Capability, bool)

GetCapability mocks base method.

func (*MockScopedKeeper) LookupModules

func (m *MockScopedKeeper) LookupModules(ctx types3.Context, name string) ([]string, *types5.Capability, error)

LookupModules mocks base method.

type MockScopedKeeperMockRecorder

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

MockScopedKeeperMockRecorder is the mock recorder for MockScopedKeeper.

func (*MockScopedKeeperMockRecorder) AuthenticateCapability

func (mr *MockScopedKeeperMockRecorder) AuthenticateCapability(ctx, cap, name interface{}) *gomock.Call

AuthenticateCapability indicates an expected call of AuthenticateCapability.

func (*MockScopedKeeperMockRecorder) ClaimCapability

func (mr *MockScopedKeeperMockRecorder) ClaimCapability(ctx, cap, name interface{}) *gomock.Call

ClaimCapability indicates an expected call of ClaimCapability.

func (*MockScopedKeeperMockRecorder) GetCapability

func (mr *MockScopedKeeperMockRecorder) GetCapability(ctx, name interface{}) *gomock.Call

GetCapability indicates an expected call of GetCapability.

func (*MockScopedKeeperMockRecorder) LookupModules

func (mr *MockScopedKeeperMockRecorder) LookupModules(ctx, name interface{}) *gomock.Call

LookupModules indicates an expected call of LookupModules.

type MockTMClient

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

MockTMClient is a mock of TMClient interface.

func NewMockTMClient

func NewMockTMClient(ctrl *gomock.Controller) *MockTMClient

NewMockTMClient creates a new mock instance.

func (*MockTMClient) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockTMClient) Tx

func (m *MockTMClient) Tx(ctx context.Context, hash []byte, prove bool) (*coretypes.ResultTx, error)

Tx mocks base method.

type MockTMClientMockRecorder

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

MockTMClientMockRecorder is the mock recorder for MockTMClient.

func (*MockTMClientMockRecorder) Tx

func (mr *MockTMClientMockRecorder) Tx(ctx, hash, prove interface{}) *gomock.Call

Tx indicates an expected call of Tx.

type MsgClient

type MsgClient interface {
	// UpdateParams updates the btccheckpoint module parameters.
	UpdateParams(ctx context.Context, in *MsgUpdateParams, opts ...grpc.CallOption) (*MsgUpdateParamsResponse, error)
}

MsgClient is the client API for Msg service.

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

func NewMsgClient

func NewMsgClient(cc grpc1.ClientConn) MsgClient

type MsgServer

type MsgServer interface {
	// UpdateParams updates the btccheckpoint module parameters.
	UpdateParams(context.Context, *MsgUpdateParams) (*MsgUpdateParamsResponse, error)
}

MsgServer is the server API for Msg service.

type MsgUpdateParams added in v0.7.0

type MsgUpdateParams struct {
	// authority is the address of the governance account.
	// just FYI: cosmos.AddressString marks that this field should use type alias
	// for AddressString instead of string, but the functionality is not yet implemented
	// in cosmos-proto
	Authority string `protobuf:"bytes,1,opt,name=authority,proto3" json:"authority,omitempty"`
	// params defines the epoching paramaeters parameters to update.
	//
	// NOTE: All parameters must be supplied.
	Params Params `protobuf:"bytes,2,opt,name=params,proto3" json:"params"`
}

MsgUpdateParams defines a message for updating zoneconcierge module parameters.

func (*MsgUpdateParams) Descriptor added in v0.7.0

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

func (*MsgUpdateParams) GetAuthority added in v0.7.0

func (m *MsgUpdateParams) GetAuthority() string

func (*MsgUpdateParams) GetParams added in v0.7.0

func (m *MsgUpdateParams) GetParams() Params

func (*MsgUpdateParams) GetSigners added in v0.7.0

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

GetSigners returns the expected signers for a MsgUpdateParams message.

func (*MsgUpdateParams) Marshal added in v0.7.0

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

func (*MsgUpdateParams) MarshalTo added in v0.7.0

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

func (*MsgUpdateParams) MarshalToSizedBuffer added in v0.7.0

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

func (*MsgUpdateParams) ProtoMessage added in v0.7.0

func (*MsgUpdateParams) ProtoMessage()

func (*MsgUpdateParams) Reset added in v0.7.0

func (m *MsgUpdateParams) Reset()

func (*MsgUpdateParams) Size added in v0.7.0

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

func (*MsgUpdateParams) String added in v0.7.0

func (m *MsgUpdateParams) String() string

func (*MsgUpdateParams) Unmarshal added in v0.7.0

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

func (*MsgUpdateParams) ValidateBasic added in v0.7.0

func (m *MsgUpdateParams) ValidateBasic() error

ValidateBasic does a sanity check on the provided data.

func (*MsgUpdateParams) XXX_DiscardUnknown added in v0.7.0

func (m *MsgUpdateParams) XXX_DiscardUnknown()

func (*MsgUpdateParams) XXX_Marshal added in v0.7.0

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

func (*MsgUpdateParams) XXX_Merge added in v0.7.0

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

func (*MsgUpdateParams) XXX_Size added in v0.7.0

func (m *MsgUpdateParams) XXX_Size() int

func (*MsgUpdateParams) XXX_Unmarshal added in v0.7.0

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

type MsgUpdateParamsResponse added in v0.7.0

type MsgUpdateParamsResponse struct {
}

MsgUpdateParamsResponse is the response to the MsgUpdateParams message.

func (*MsgUpdateParamsResponse) Descriptor added in v0.7.0

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

func (*MsgUpdateParamsResponse) Marshal added in v0.7.0

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

func (*MsgUpdateParamsResponse) MarshalTo added in v0.7.0

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

func (*MsgUpdateParamsResponse) MarshalToSizedBuffer added in v0.7.0

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

func (*MsgUpdateParamsResponse) ProtoMessage added in v0.7.0

func (*MsgUpdateParamsResponse) ProtoMessage()

func (*MsgUpdateParamsResponse) Reset added in v0.7.0

func (m *MsgUpdateParamsResponse) Reset()

func (*MsgUpdateParamsResponse) Size added in v0.7.0

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

func (*MsgUpdateParamsResponse) String added in v0.7.0

func (m *MsgUpdateParamsResponse) String() string

func (*MsgUpdateParamsResponse) Unmarshal added in v0.7.0

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

func (*MsgUpdateParamsResponse) XXX_DiscardUnknown added in v0.7.0

func (m *MsgUpdateParamsResponse) XXX_DiscardUnknown()

func (*MsgUpdateParamsResponse) XXX_Marshal added in v0.7.0

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

func (*MsgUpdateParamsResponse) XXX_Merge added in v0.7.0

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

func (*MsgUpdateParamsResponse) XXX_Size added in v0.7.0

func (m *MsgUpdateParamsResponse) XXX_Size() int

func (*MsgUpdateParamsResponse) XXX_Unmarshal added in v0.7.0

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

type Params

type Params struct {
	// ibc_packet_timeout_seconds is the time period after which an unrelayed
	// IBC packet becomes timeout, measured in seconds
	IbcPacketTimeoutSeconds uint32 `` /* 169-byte string literal not displayed */
}

Params defines the parameters for the module.

func DefaultParams

func DefaultParams() Params

DefaultParams returns a default set of parameters

func NewParams

func NewParams(ibcPacketTimeoutSeconds uint32) Params

NewParams creates a new Params instance

func (*Params) Descriptor

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

func (*Params) Equal added in v0.7.0

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

func (*Params) GetIbcPacketTimeoutSeconds added in v0.7.0

func (m *Params) GetIbcPacketTimeoutSeconds() uint32

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

func (p Params) Validate() error

Validate validates the set of params

func (*Params) XXX_DiscardUnknown

func (m *Params) XXX_DiscardUnknown()

func (*Params) XXX_Marshal

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

func (*Params) XXX_Merge

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

func (*Params) XXX_Size

func (m *Params) XXX_Size() int

func (*Params) XXX_Unmarshal

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

type PortKeeper

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

PortKeeper defines the expected IBC port keeper

type ProofEpochSealed

type ProofEpochSealed struct {
	// validator_set is the validator set of the sealed epoch
	// This validator set has generated a BLS multisig on `last_commit_hash` of
	// the sealer header
	ValidatorSet []*types2.ValidatorWithBlsKey `protobuf:"bytes,1,rep,name=validator_set,json=validatorSet,proto3" json:"validator_set,omitempty"`
	// proof_epoch_info is the Merkle proof that the epoch's metadata is committed
	// to `app_hash` of the sealer header
	ProofEpochInfo *crypto.ProofOps `protobuf:"bytes,2,opt,name=proof_epoch_info,json=proofEpochInfo,proto3" json:"proof_epoch_info,omitempty"`
	// proof_epoch_info is the Merkle proof that the epoch's validator set is
	// committed to `app_hash` of the sealer header
	ProofEpochValSet *crypto.ProofOps `protobuf:"bytes,3,opt,name=proof_epoch_val_set,json=proofEpochValSet,proto3" json:"proof_epoch_val_set,omitempty"`
}

ProofEpochSealed is the proof that an epoch is sealed by the sealer header, i.e., the 2nd header of the next epoch With the access of metadata - Metadata of this epoch, which includes the sealer header - Raw checkpoint of this epoch The verifier can perform the following verification rules: - The raw checkpoint's `last_commit_hash` is same as in the sealer header - More than 1/3 (in voting power) validators in the validator set of this epoch have signed `last_commit_hash` of the sealer header - The epoch medatata is committed to the `app_hash` of the sealer header - The validator set is committed to the `app_hash` of the sealer header

func (*ProofEpochSealed) Descriptor

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

func (*ProofEpochSealed) GetProofEpochInfo

func (m *ProofEpochSealed) GetProofEpochInfo() *crypto.ProofOps

func (*ProofEpochSealed) GetProofEpochValSet

func (m *ProofEpochSealed) GetProofEpochValSet() *crypto.ProofOps

func (*ProofEpochSealed) GetValidatorSet

func (m *ProofEpochSealed) GetValidatorSet() []*types2.ValidatorWithBlsKey

func (*ProofEpochSealed) Marshal

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

func (*ProofEpochSealed) MarshalTo

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

func (*ProofEpochSealed) MarshalToSizedBuffer

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

func (*ProofEpochSealed) ProtoMessage

func (*ProofEpochSealed) ProtoMessage()

func (*ProofEpochSealed) Reset

func (m *ProofEpochSealed) Reset()

func (*ProofEpochSealed) Size

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

func (*ProofEpochSealed) String

func (m *ProofEpochSealed) String() string

func (*ProofEpochSealed) Unmarshal

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

func (*ProofEpochSealed) ValidateBasic

func (p *ProofEpochSealed) ValidateBasic() error

func (*ProofEpochSealed) XXX_DiscardUnknown

func (m *ProofEpochSealed) XXX_DiscardUnknown()

func (*ProofEpochSealed) XXX_Marshal

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

func (*ProofEpochSealed) XXX_Merge

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

func (*ProofEpochSealed) XXX_Size

func (m *ProofEpochSealed) XXX_Size() int

func (*ProofEpochSealed) XXX_Unmarshal

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

type ProofFinalizedChainInfo

type ProofFinalizedChainInfo struct {
	// proof_tx_in_block is the proof that tx that carries the header is included
	// in a certain Babylon block
	ProofTxInBlock *types.TxProof `protobuf:"bytes,4,opt,name=proof_tx_in_block,json=proofTxInBlock,proto3" json:"proof_tx_in_block,omitempty"`
	// proof_header_in_epoch is the proof that the Babylon header is in a certain
	// epoch
	ProofHeaderInEpoch *crypto.Proof `protobuf:"bytes,5,opt,name=proof_header_in_epoch,json=proofHeaderInEpoch,proto3" json:"proof_header_in_epoch,omitempty"`
	// proof_epoch_sealed is the proof that the epoch is sealed
	ProofEpochSealed *ProofEpochSealed `protobuf:"bytes,6,opt,name=proof_epoch_sealed,json=proofEpochSealed,proto3" json:"proof_epoch_sealed,omitempty"`
	// proof_epoch_submitted is the proof that the epoch's checkpoint is included
	// in BTC ledger It is the two TransactionInfo in the best (i.e., earliest)
	// checkpoint submission
	ProofEpochSubmitted []*types3.TransactionInfo `protobuf:"bytes,7,rep,name=proof_epoch_submitted,json=proofEpochSubmitted,proto3" json:"proof_epoch_submitted,omitempty"`
}

ProofFinalizedChainInfo is a set of proofs that attest a chain info is BTC-finalised

func (*ProofFinalizedChainInfo) Descriptor

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

func (*ProofFinalizedChainInfo) GetProofEpochSealed

func (m *ProofFinalizedChainInfo) GetProofEpochSealed() *ProofEpochSealed

func (*ProofFinalizedChainInfo) GetProofEpochSubmitted

func (m *ProofFinalizedChainInfo) GetProofEpochSubmitted() []*types3.TransactionInfo

func (*ProofFinalizedChainInfo) GetProofHeaderInEpoch

func (m *ProofFinalizedChainInfo) GetProofHeaderInEpoch() *crypto.Proof

func (*ProofFinalizedChainInfo) GetProofTxInBlock

func (m *ProofFinalizedChainInfo) GetProofTxInBlock() *types.TxProof

func (*ProofFinalizedChainInfo) Marshal

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

func (*ProofFinalizedChainInfo) MarshalTo

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

func (*ProofFinalizedChainInfo) MarshalToSizedBuffer

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

func (*ProofFinalizedChainInfo) ProtoMessage

func (*ProofFinalizedChainInfo) ProtoMessage()

func (*ProofFinalizedChainInfo) Reset

func (m *ProofFinalizedChainInfo) Reset()

func (*ProofFinalizedChainInfo) Size

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

func (*ProofFinalizedChainInfo) String

func (m *ProofFinalizedChainInfo) String() string

func (*ProofFinalizedChainInfo) Unmarshal

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

func (*ProofFinalizedChainInfo) XXX_DiscardUnknown

func (m *ProofFinalizedChainInfo) XXX_DiscardUnknown()

func (*ProofFinalizedChainInfo) XXX_Marshal

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

func (*ProofFinalizedChainInfo) XXX_Merge

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

func (*ProofFinalizedChainInfo) XXX_Size

func (m *ProofFinalizedChainInfo) XXX_Size() int

func (*ProofFinalizedChainInfo) XXX_Unmarshal

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

type QueryChainListRequest

type QueryChainListRequest struct {
	// pagination defines whether to have the pagination in the request
	Pagination *query.PageRequest `protobuf:"bytes,1,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

QueryChainListRequest is request type for the Query/ChainList RPC method

func (*QueryChainListRequest) Descriptor

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

func (*QueryChainListRequest) GetPagination

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

func (*QueryChainListRequest) Marshal

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

func (*QueryChainListRequest) MarshalTo

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

func (*QueryChainListRequest) MarshalToSizedBuffer

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

func (*QueryChainListRequest) ProtoMessage

func (*QueryChainListRequest) ProtoMessage()

func (*QueryChainListRequest) Reset

func (m *QueryChainListRequest) Reset()

func (*QueryChainListRequest) Size

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

func (*QueryChainListRequest) String

func (m *QueryChainListRequest) String() string

func (*QueryChainListRequest) Unmarshal

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

func (*QueryChainListRequest) XXX_DiscardUnknown

func (m *QueryChainListRequest) XXX_DiscardUnknown()

func (*QueryChainListRequest) XXX_Marshal

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

func (*QueryChainListRequest) XXX_Merge

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

func (*QueryChainListRequest) XXX_Size

func (m *QueryChainListRequest) XXX_Size() int

func (*QueryChainListRequest) XXX_Unmarshal

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

type QueryChainListResponse

type QueryChainListResponse struct {
	// chain_ids are IDs of the chains in ascending alphabetical order
	ChainIds []string `protobuf:"bytes,1,rep,name=chain_ids,json=chainIds,proto3" json:"chain_ids,omitempty"`
	// pagination defines the pagination in the response
	Pagination *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

QueryChainListResponse is response type for the Query/ChainList RPC method

func (*QueryChainListResponse) Descriptor

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

func (*QueryChainListResponse) GetChainIds

func (m *QueryChainListResponse) GetChainIds() []string

func (*QueryChainListResponse) GetPagination

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

func (*QueryChainListResponse) Marshal

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

func (*QueryChainListResponse) MarshalTo

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

func (*QueryChainListResponse) MarshalToSizedBuffer

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

func (*QueryChainListResponse) ProtoMessage

func (*QueryChainListResponse) ProtoMessage()

func (*QueryChainListResponse) Reset

func (m *QueryChainListResponse) Reset()

func (*QueryChainListResponse) Size

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

func (*QueryChainListResponse) String

func (m *QueryChainListResponse) String() string

func (*QueryChainListResponse) Unmarshal

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

func (*QueryChainListResponse) XXX_DiscardUnknown

func (m *QueryChainListResponse) XXX_DiscardUnknown()

func (*QueryChainListResponse) XXX_Marshal

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

func (*QueryChainListResponse) XXX_Merge

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

func (*QueryChainListResponse) XXX_Size

func (m *QueryChainListResponse) XXX_Size() int

func (*QueryChainListResponse) XXX_Unmarshal

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

type QueryChainsInfoRequest added in v0.6.0

type QueryChainsInfoRequest struct {
	ChainIds []string `protobuf:"bytes,1,rep,name=chain_ids,json=chainIds,proto3" json:"chain_ids,omitempty"`
}

QueryChainsInfoRequest is request type for the Query/ChainsInfo RPC method.

func (*QueryChainsInfoRequest) Descriptor added in v0.6.0

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

func (*QueryChainsInfoRequest) GetChainIds added in v0.6.0

func (m *QueryChainsInfoRequest) GetChainIds() []string

func (*QueryChainsInfoRequest) Marshal added in v0.6.0

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

func (*QueryChainsInfoRequest) MarshalTo added in v0.6.0

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

func (*QueryChainsInfoRequest) MarshalToSizedBuffer added in v0.6.0

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

func (*QueryChainsInfoRequest) ProtoMessage added in v0.6.0

func (*QueryChainsInfoRequest) ProtoMessage()

func (*QueryChainsInfoRequest) Reset added in v0.6.0

func (m *QueryChainsInfoRequest) Reset()

func (*QueryChainsInfoRequest) Size added in v0.6.0

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

func (*QueryChainsInfoRequest) String added in v0.6.0

func (m *QueryChainsInfoRequest) String() string

func (*QueryChainsInfoRequest) Unmarshal added in v0.6.0

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

func (*QueryChainsInfoRequest) XXX_DiscardUnknown added in v0.6.0

func (m *QueryChainsInfoRequest) XXX_DiscardUnknown()

func (*QueryChainsInfoRequest) XXX_Marshal added in v0.6.0

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

func (*QueryChainsInfoRequest) XXX_Merge added in v0.6.0

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

func (*QueryChainsInfoRequest) XXX_Size added in v0.6.0

func (m *QueryChainsInfoRequest) XXX_Size() int

func (*QueryChainsInfoRequest) XXX_Unmarshal added in v0.6.0

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

type QueryChainsInfoResponse added in v0.6.0

type QueryChainsInfoResponse struct {
	ChainsInfo []*ChainInfo `protobuf:"bytes,1,rep,name=chains_info,json=chainsInfo,proto3" json:"chains_info,omitempty"`
}

QueryChainsInfoResponse is response type for the Query/ChainsInfo RPC method.

func (*QueryChainsInfoResponse) Descriptor added in v0.6.0

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

func (*QueryChainsInfoResponse) GetChainsInfo added in v0.6.0

func (m *QueryChainsInfoResponse) GetChainsInfo() []*ChainInfo

func (*QueryChainsInfoResponse) Marshal added in v0.6.0

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

func (*QueryChainsInfoResponse) MarshalTo added in v0.6.0

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

func (*QueryChainsInfoResponse) MarshalToSizedBuffer added in v0.6.0

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

func (*QueryChainsInfoResponse) ProtoMessage added in v0.6.0

func (*QueryChainsInfoResponse) ProtoMessage()

func (*QueryChainsInfoResponse) Reset added in v0.6.0

func (m *QueryChainsInfoResponse) Reset()

func (*QueryChainsInfoResponse) Size added in v0.6.0

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

func (*QueryChainsInfoResponse) String added in v0.6.0

func (m *QueryChainsInfoResponse) String() string

func (*QueryChainsInfoResponse) Unmarshal added in v0.6.0

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

func (*QueryChainsInfoResponse) XXX_DiscardUnknown added in v0.6.0

func (m *QueryChainsInfoResponse) XXX_DiscardUnknown()

func (*QueryChainsInfoResponse) XXX_Marshal added in v0.6.0

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

func (*QueryChainsInfoResponse) XXX_Merge added in v0.6.0

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

func (*QueryChainsInfoResponse) XXX_Size added in v0.6.0

func (m *QueryChainsInfoResponse) XXX_Size() int

func (*QueryChainsInfoResponse) XXX_Unmarshal added in v0.6.0

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

type QueryClient

type QueryClient interface {
	// Params queries the parameters of the module.
	Params(ctx context.Context, in *QueryParamsRequest, opts ...grpc.CallOption) (*QueryParamsResponse, error)
	// Header queries the CZ header and fork headers at a given height.
	Header(ctx context.Context, in *QueryHeaderRequest, opts ...grpc.CallOption) (*QueryHeaderResponse, error)
	// ChainList queries the list of chains that checkpoint to Babylon
	ChainList(ctx context.Context, in *QueryChainListRequest, opts ...grpc.CallOption) (*QueryChainListResponse, error)
	// ChainsInfo queries the latest info for a given list of chains in Babylon's view
	ChainsInfo(ctx context.Context, in *QueryChainsInfoRequest, opts ...grpc.CallOption) (*QueryChainsInfoResponse, error)
	// EpochChainsInfo queries the latest info for a list of chains
	// in a given epoch in Babylon's view
	EpochChainsInfo(ctx context.Context, in *QueryEpochChainsInfoRequest, opts ...grpc.CallOption) (*QueryEpochChainsInfoResponse, error)
	// ListHeaders queries the headers of a chain in Babylon's view, with
	// pagination support
	ListHeaders(ctx context.Context, in *QueryListHeadersRequest, opts ...grpc.CallOption) (*QueryListHeadersResponse, error)
	// ListEpochHeaders queries the headers of a chain timestamped in a given
	// epoch of Babylon, with pagination support
	ListEpochHeaders(ctx context.Context, in *QueryListEpochHeadersRequest, opts ...grpc.CallOption) (*QueryListEpochHeadersResponse, error)
	// FinalizedChainsInfo queries the BTC-finalised info of chains with given IDs, with proofs
	FinalizedChainsInfo(ctx context.Context, in *QueryFinalizedChainsInfoRequest, opts ...grpc.CallOption) (*QueryFinalizedChainsInfoResponse, error)
	// FinalizedChainInfoUntilHeight queries the BTC-finalised info no later than
	// the provided CZ height, with proofs
	FinalizedChainInfoUntilHeight(ctx context.Context, in *QueryFinalizedChainInfoUntilHeightRequest, opts ...grpc.CallOption) (*QueryFinalizedChainInfoUntilHeightResponse, 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 QueryEpochChainsInfoRequest added in v0.6.0

type QueryEpochChainsInfoRequest struct {
	EpochNum uint64   `protobuf:"varint,1,opt,name=epoch_num,json=epochNum,proto3" json:"epoch_num,omitempty"`
	ChainIds []string `protobuf:"bytes,2,rep,name=chain_ids,json=chainIds,proto3" json:"chain_ids,omitempty"`
}

QueryEpochChainsInfoRequest is request type for the Query/EpochChainsInfo RPC method.

func (*QueryEpochChainsInfoRequest) Descriptor added in v0.6.0

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

func (*QueryEpochChainsInfoRequest) GetChainIds added in v0.6.0

func (m *QueryEpochChainsInfoRequest) GetChainIds() []string

func (*QueryEpochChainsInfoRequest) GetEpochNum added in v0.6.0

func (m *QueryEpochChainsInfoRequest) GetEpochNum() uint64

func (*QueryEpochChainsInfoRequest) Marshal added in v0.6.0

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

func (*QueryEpochChainsInfoRequest) MarshalTo added in v0.6.0

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

func (*QueryEpochChainsInfoRequest) MarshalToSizedBuffer added in v0.6.0

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

func (*QueryEpochChainsInfoRequest) ProtoMessage added in v0.6.0

func (*QueryEpochChainsInfoRequest) ProtoMessage()

func (*QueryEpochChainsInfoRequest) Reset added in v0.6.0

func (m *QueryEpochChainsInfoRequest) Reset()

func (*QueryEpochChainsInfoRequest) Size added in v0.6.0

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

func (*QueryEpochChainsInfoRequest) String added in v0.6.0

func (m *QueryEpochChainsInfoRequest) String() string

func (*QueryEpochChainsInfoRequest) Unmarshal added in v0.6.0

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

func (*QueryEpochChainsInfoRequest) XXX_DiscardUnknown added in v0.6.0

func (m *QueryEpochChainsInfoRequest) XXX_DiscardUnknown()

func (*QueryEpochChainsInfoRequest) XXX_Marshal added in v0.6.0

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

func (*QueryEpochChainsInfoRequest) XXX_Merge added in v0.6.0

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

func (*QueryEpochChainsInfoRequest) XXX_Size added in v0.6.0

func (m *QueryEpochChainsInfoRequest) XXX_Size() int

func (*QueryEpochChainsInfoRequest) XXX_Unmarshal added in v0.6.0

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

type QueryEpochChainsInfoResponse added in v0.6.0

type QueryEpochChainsInfoResponse struct {
	// chain_info is the info of the CZ
	ChainsInfo []*ChainInfo `protobuf:"bytes,1,rep,name=chains_info,json=chainsInfo,proto3" json:"chains_info,omitempty"`
}

QueryEpochChainsInfoResponse is response type for the Query/EpochChainsInfo RPC method.

func (*QueryEpochChainsInfoResponse) Descriptor added in v0.6.0

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

func (*QueryEpochChainsInfoResponse) GetChainsInfo added in v0.6.0

func (m *QueryEpochChainsInfoResponse) GetChainsInfo() []*ChainInfo

func (*QueryEpochChainsInfoResponse) Marshal added in v0.6.0

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

func (*QueryEpochChainsInfoResponse) MarshalTo added in v0.6.0

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

func (*QueryEpochChainsInfoResponse) MarshalToSizedBuffer added in v0.6.0

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

func (*QueryEpochChainsInfoResponse) ProtoMessage added in v0.6.0

func (*QueryEpochChainsInfoResponse) ProtoMessage()

func (*QueryEpochChainsInfoResponse) Reset added in v0.6.0

func (m *QueryEpochChainsInfoResponse) Reset()

func (*QueryEpochChainsInfoResponse) Size added in v0.6.0

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

func (*QueryEpochChainsInfoResponse) String added in v0.6.0

func (*QueryEpochChainsInfoResponse) Unmarshal added in v0.6.0

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

func (*QueryEpochChainsInfoResponse) XXX_DiscardUnknown added in v0.6.0

func (m *QueryEpochChainsInfoResponse) XXX_DiscardUnknown()

func (*QueryEpochChainsInfoResponse) XXX_Marshal added in v0.6.0

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

func (*QueryEpochChainsInfoResponse) XXX_Merge added in v0.6.0

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

func (*QueryEpochChainsInfoResponse) XXX_Size added in v0.6.0

func (m *QueryEpochChainsInfoResponse) XXX_Size() int

func (*QueryEpochChainsInfoResponse) XXX_Unmarshal added in v0.6.0

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

type QueryFinalizedChainInfoUntilHeightRequest

type QueryFinalizedChainInfoUntilHeightRequest struct {
	// chain_id is the ID of the CZ
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// height is the height of the CZ chain
	// such that the returned finalised chain info will be no later than this
	// height
	Height uint64 `protobuf:"varint,2,opt,name=height,proto3" json:"height,omitempty"`
	// prove indicates whether the querier wants to get proofs of this timestamp
	Prove bool `protobuf:"varint,3,opt,name=prove,proto3" json:"prove,omitempty"`
}

QueryFinalizedChainInfoUntilHeightRequest is request type for the Query/FinalizedChainInfoUntilHeight RPC method.

func (*QueryFinalizedChainInfoUntilHeightRequest) Descriptor

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

func (*QueryFinalizedChainInfoUntilHeightRequest) GetChainId

func (*QueryFinalizedChainInfoUntilHeightRequest) GetHeight

func (*QueryFinalizedChainInfoUntilHeightRequest) GetProve

func (*QueryFinalizedChainInfoUntilHeightRequest) Marshal

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

func (*QueryFinalizedChainInfoUntilHeightRequest) MarshalTo

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

func (*QueryFinalizedChainInfoUntilHeightRequest) MarshalToSizedBuffer

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

func (*QueryFinalizedChainInfoUntilHeightRequest) ProtoMessage

func (*QueryFinalizedChainInfoUntilHeightRequest) Reset

func (*QueryFinalizedChainInfoUntilHeightRequest) Size

func (*QueryFinalizedChainInfoUntilHeightRequest) String

func (*QueryFinalizedChainInfoUntilHeightRequest) Unmarshal

func (*QueryFinalizedChainInfoUntilHeightRequest) XXX_DiscardUnknown

func (m *QueryFinalizedChainInfoUntilHeightRequest) XXX_DiscardUnknown()

func (*QueryFinalizedChainInfoUntilHeightRequest) XXX_Marshal

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

func (*QueryFinalizedChainInfoUntilHeightRequest) XXX_Merge

func (*QueryFinalizedChainInfoUntilHeightRequest) XXX_Size

func (*QueryFinalizedChainInfoUntilHeightRequest) XXX_Unmarshal

type QueryFinalizedChainInfoUntilHeightResponse

type QueryFinalizedChainInfoUntilHeightResponse struct {
	// finalized_chain_info is the info of the CZ
	FinalizedChainInfo *ChainInfo `protobuf:"bytes,1,opt,name=finalized_chain_info,json=finalizedChainInfo,proto3" json:"finalized_chain_info,omitempty"`
	// epoch_info is the metadata of the last BTC-finalised epoch
	EpochInfo *types.Epoch `protobuf:"bytes,2,opt,name=epoch_info,json=epochInfo,proto3" json:"epoch_info,omitempty"`
	// raw_checkpoint is the raw checkpoint of this epoch
	RawCheckpoint *types1.RawCheckpoint `protobuf:"bytes,3,opt,name=raw_checkpoint,json=rawCheckpoint,proto3" json:"raw_checkpoint,omitempty"`
	// btc_submission_key is position of two BTC txs that include the raw
	// checkpoint of this epoch
	BtcSubmissionKey *types2.SubmissionKey `protobuf:"bytes,4,opt,name=btc_submission_key,json=btcSubmissionKey,proto3" json:"btc_submission_key,omitempty"`
	// proof is the proof that the chain info is finalized
	Proof *ProofFinalizedChainInfo `protobuf:"bytes,5,opt,name=proof,proto3" json:"proof,omitempty"`
}

QueryFinalizedChainInfoUntilHeightResponse is response type for the Query/FinalizedChainInfoUntilHeight RPC method.

func (*QueryFinalizedChainInfoUntilHeightResponse) Descriptor

func (*QueryFinalizedChainInfoUntilHeightResponse) GetBtcSubmissionKey

func (*QueryFinalizedChainInfoUntilHeightResponse) GetEpochInfo

func (*QueryFinalizedChainInfoUntilHeightResponse) GetFinalizedChainInfo

func (m *QueryFinalizedChainInfoUntilHeightResponse) GetFinalizedChainInfo() *ChainInfo

func (*QueryFinalizedChainInfoUntilHeightResponse) GetProof

func (*QueryFinalizedChainInfoUntilHeightResponse) GetRawCheckpoint

func (*QueryFinalizedChainInfoUntilHeightResponse) Marshal

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

func (*QueryFinalizedChainInfoUntilHeightResponse) MarshalTo

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

func (*QueryFinalizedChainInfoUntilHeightResponse) MarshalToSizedBuffer

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

func (*QueryFinalizedChainInfoUntilHeightResponse) ProtoMessage

func (*QueryFinalizedChainInfoUntilHeightResponse) Reset

func (*QueryFinalizedChainInfoUntilHeightResponse) Size

func (*QueryFinalizedChainInfoUntilHeightResponse) String

func (*QueryFinalizedChainInfoUntilHeightResponse) Unmarshal

func (*QueryFinalizedChainInfoUntilHeightResponse) XXX_DiscardUnknown

func (m *QueryFinalizedChainInfoUntilHeightResponse) XXX_DiscardUnknown()

func (*QueryFinalizedChainInfoUntilHeightResponse) XXX_Marshal

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

func (*QueryFinalizedChainInfoUntilHeightResponse) XXX_Merge

func (*QueryFinalizedChainInfoUntilHeightResponse) XXX_Size

func (*QueryFinalizedChainInfoUntilHeightResponse) XXX_Unmarshal

type QueryFinalizedChainsInfoRequest added in v0.6.0

type QueryFinalizedChainsInfoRequest struct {
	// chain_ids is the list of ids of CZs
	ChainIds []string `protobuf:"bytes,1,rep,name=chain_ids,json=chainIds,proto3" json:"chain_ids,omitempty"`
	// prove indicates whether the querier wants to get proofs of this timestamp
	Prove bool `protobuf:"varint,2,opt,name=prove,proto3" json:"prove,omitempty"`
}

QueryFinalizedChainsInfoRequest is request type for the Query/FinalizedChainsInfo RPC method.

func (*QueryFinalizedChainsInfoRequest) Descriptor added in v0.6.0

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

func (*QueryFinalizedChainsInfoRequest) GetChainIds added in v0.6.0

func (m *QueryFinalizedChainsInfoRequest) GetChainIds() []string

func (*QueryFinalizedChainsInfoRequest) GetProve added in v0.6.0

func (m *QueryFinalizedChainsInfoRequest) GetProve() bool

func (*QueryFinalizedChainsInfoRequest) Marshal added in v0.6.0

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

func (*QueryFinalizedChainsInfoRequest) MarshalTo added in v0.6.0

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

func (*QueryFinalizedChainsInfoRequest) MarshalToSizedBuffer added in v0.6.0

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

func (*QueryFinalizedChainsInfoRequest) ProtoMessage added in v0.6.0

func (*QueryFinalizedChainsInfoRequest) ProtoMessage()

func (*QueryFinalizedChainsInfoRequest) Reset added in v0.6.0

func (*QueryFinalizedChainsInfoRequest) Size added in v0.6.0

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

func (*QueryFinalizedChainsInfoRequest) String added in v0.6.0

func (*QueryFinalizedChainsInfoRequest) Unmarshal added in v0.6.0

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

func (*QueryFinalizedChainsInfoRequest) XXX_DiscardUnknown added in v0.6.0

func (m *QueryFinalizedChainsInfoRequest) XXX_DiscardUnknown()

func (*QueryFinalizedChainsInfoRequest) XXX_Marshal added in v0.6.0

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

func (*QueryFinalizedChainsInfoRequest) XXX_Merge added in v0.6.0

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

func (*QueryFinalizedChainsInfoRequest) XXX_Size added in v0.6.0

func (m *QueryFinalizedChainsInfoRequest) XXX_Size() int

func (*QueryFinalizedChainsInfoRequest) XXX_Unmarshal added in v0.6.0

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

type QueryFinalizedChainsInfoResponse added in v0.6.0

type QueryFinalizedChainsInfoResponse struct {
	FinalizedChainsInfo []*FinalizedChainInfo `protobuf:"bytes,1,rep,name=finalized_chains_info,json=finalizedChainsInfo,proto3" json:"finalized_chains_info,omitempty"`
}

QueryFinalizedChainsInfoResponse is response type for the Query/FinalizedChainsInfo RPC method.

func (*QueryFinalizedChainsInfoResponse) Descriptor added in v0.6.0

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

func (*QueryFinalizedChainsInfoResponse) GetFinalizedChainsInfo added in v0.6.0

func (m *QueryFinalizedChainsInfoResponse) GetFinalizedChainsInfo() []*FinalizedChainInfo

func (*QueryFinalizedChainsInfoResponse) Marshal added in v0.6.0

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

func (*QueryFinalizedChainsInfoResponse) MarshalTo added in v0.6.0

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

func (*QueryFinalizedChainsInfoResponse) MarshalToSizedBuffer added in v0.6.0

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

func (*QueryFinalizedChainsInfoResponse) ProtoMessage added in v0.6.0

func (*QueryFinalizedChainsInfoResponse) ProtoMessage()

func (*QueryFinalizedChainsInfoResponse) Reset added in v0.6.0

func (*QueryFinalizedChainsInfoResponse) Size added in v0.6.0

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

func (*QueryFinalizedChainsInfoResponse) String added in v0.6.0

func (*QueryFinalizedChainsInfoResponse) Unmarshal added in v0.6.0

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

func (*QueryFinalizedChainsInfoResponse) XXX_DiscardUnknown added in v0.6.0

func (m *QueryFinalizedChainsInfoResponse) XXX_DiscardUnknown()

func (*QueryFinalizedChainsInfoResponse) XXX_Marshal added in v0.6.0

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

func (*QueryFinalizedChainsInfoResponse) XXX_Merge added in v0.6.0

func (*QueryFinalizedChainsInfoResponse) XXX_Size added in v0.6.0

func (m *QueryFinalizedChainsInfoResponse) XXX_Size() int

func (*QueryFinalizedChainsInfoResponse) XXX_Unmarshal added in v0.6.0

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

type QueryHeaderRequest

type QueryHeaderRequest struct {
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	Height  uint64 `protobuf:"varint,2,opt,name=height,proto3" json:"height,omitempty"`
}

QueryHeaderRequest is request type for the Query/Header RPC method.

func (*QueryHeaderRequest) Descriptor

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

func (*QueryHeaderRequest) GetChainId

func (m *QueryHeaderRequest) GetChainId() string

func (*QueryHeaderRequest) GetHeight

func (m *QueryHeaderRequest) GetHeight() uint64

func (*QueryHeaderRequest) Marshal

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

func (*QueryHeaderRequest) MarshalTo

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

func (*QueryHeaderRequest) MarshalToSizedBuffer

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

func (*QueryHeaderRequest) ProtoMessage

func (*QueryHeaderRequest) ProtoMessage()

func (*QueryHeaderRequest) Reset

func (m *QueryHeaderRequest) Reset()

func (*QueryHeaderRequest) Size

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

func (*QueryHeaderRequest) String

func (m *QueryHeaderRequest) String() string

func (*QueryHeaderRequest) Unmarshal

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

func (*QueryHeaderRequest) XXX_DiscardUnknown

func (m *QueryHeaderRequest) XXX_DiscardUnknown()

func (*QueryHeaderRequest) XXX_Marshal

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

func (*QueryHeaderRequest) XXX_Merge

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

func (*QueryHeaderRequest) XXX_Size

func (m *QueryHeaderRequest) XXX_Size() int

func (*QueryHeaderRequest) XXX_Unmarshal

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

type QueryHeaderResponse

type QueryHeaderResponse struct {
	Header      *IndexedHeader `protobuf:"bytes,1,opt,name=header,proto3" json:"header,omitempty"`
	ForkHeaders *Forks         `protobuf:"bytes,2,opt,name=fork_headers,json=forkHeaders,proto3" json:"fork_headers,omitempty"`
}

QueryHeaderResponse is response type for the Query/Header RPC method.

func (*QueryHeaderResponse) Descriptor

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

func (*QueryHeaderResponse) GetForkHeaders

func (m *QueryHeaderResponse) GetForkHeaders() *Forks

func (*QueryHeaderResponse) GetHeader

func (m *QueryHeaderResponse) GetHeader() *IndexedHeader

func (*QueryHeaderResponse) Marshal

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

func (*QueryHeaderResponse) MarshalTo

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

func (*QueryHeaderResponse) MarshalToSizedBuffer

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

func (*QueryHeaderResponse) ProtoMessage

func (*QueryHeaderResponse) ProtoMessage()

func (*QueryHeaderResponse) Reset

func (m *QueryHeaderResponse) Reset()

func (*QueryHeaderResponse) Size

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

func (*QueryHeaderResponse) String

func (m *QueryHeaderResponse) String() string

func (*QueryHeaderResponse) Unmarshal

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

func (*QueryHeaderResponse) XXX_DiscardUnknown

func (m *QueryHeaderResponse) XXX_DiscardUnknown()

func (*QueryHeaderResponse) XXX_Marshal

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

func (*QueryHeaderResponse) XXX_Merge

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

func (*QueryHeaderResponse) XXX_Size

func (m *QueryHeaderResponse) XXX_Size() int

func (*QueryHeaderResponse) XXX_Unmarshal

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

type QueryListEpochHeadersRequest

type QueryListEpochHeadersRequest struct {
	EpochNum uint64 `protobuf:"varint,1,opt,name=epoch_num,json=epochNum,proto3" json:"epoch_num,omitempty"`
	ChainId  string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

QueryListEpochHeadersRequest is request type for the Query/ListEpochHeaders RPC method.

func (*QueryListEpochHeadersRequest) Descriptor

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

func (*QueryListEpochHeadersRequest) GetChainId

func (m *QueryListEpochHeadersRequest) GetChainId() string

func (*QueryListEpochHeadersRequest) GetEpochNum

func (m *QueryListEpochHeadersRequest) GetEpochNum() uint64

func (*QueryListEpochHeadersRequest) Marshal

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

func (*QueryListEpochHeadersRequest) MarshalTo

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

func (*QueryListEpochHeadersRequest) MarshalToSizedBuffer

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

func (*QueryListEpochHeadersRequest) ProtoMessage

func (*QueryListEpochHeadersRequest) ProtoMessage()

func (*QueryListEpochHeadersRequest) Reset

func (m *QueryListEpochHeadersRequest) Reset()

func (*QueryListEpochHeadersRequest) Size

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

func (*QueryListEpochHeadersRequest) String

func (*QueryListEpochHeadersRequest) Unmarshal

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

func (*QueryListEpochHeadersRequest) XXX_DiscardUnknown

func (m *QueryListEpochHeadersRequest) XXX_DiscardUnknown()

func (*QueryListEpochHeadersRequest) XXX_Marshal

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

func (*QueryListEpochHeadersRequest) XXX_Merge

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

func (*QueryListEpochHeadersRequest) XXX_Size

func (m *QueryListEpochHeadersRequest) XXX_Size() int

func (*QueryListEpochHeadersRequest) XXX_Unmarshal

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

type QueryListEpochHeadersResponse

type QueryListEpochHeadersResponse struct {
	// headers is the list of headers
	Headers []*IndexedHeader `protobuf:"bytes,1,rep,name=headers,proto3" json:"headers,omitempty"`
}

QueryListEpochHeadersResponse is response type for the Query/ListEpochHeaders RPC method.

func (*QueryListEpochHeadersResponse) Descriptor

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

func (*QueryListEpochHeadersResponse) GetHeaders

func (m *QueryListEpochHeadersResponse) GetHeaders() []*IndexedHeader

func (*QueryListEpochHeadersResponse) Marshal

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

func (*QueryListEpochHeadersResponse) MarshalTo

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

func (*QueryListEpochHeadersResponse) MarshalToSizedBuffer

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

func (*QueryListEpochHeadersResponse) ProtoMessage

func (*QueryListEpochHeadersResponse) ProtoMessage()

func (*QueryListEpochHeadersResponse) Reset

func (m *QueryListEpochHeadersResponse) Reset()

func (*QueryListEpochHeadersResponse) Size

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

func (*QueryListEpochHeadersResponse) String

func (*QueryListEpochHeadersResponse) Unmarshal

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

func (*QueryListEpochHeadersResponse) XXX_DiscardUnknown

func (m *QueryListEpochHeadersResponse) XXX_DiscardUnknown()

func (*QueryListEpochHeadersResponse) XXX_Marshal

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

func (*QueryListEpochHeadersResponse) XXX_Merge

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

func (*QueryListEpochHeadersResponse) XXX_Size

func (m *QueryListEpochHeadersResponse) XXX_Size() int

func (*QueryListEpochHeadersResponse) XXX_Unmarshal

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

type QueryListHeadersRequest

type QueryListHeadersRequest struct {
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// pagination defines whether to have the pagination in the request
	Pagination *query.PageRequest `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

QueryListHeadersRequest is request type for the Query/ListHeaders RPC method.

func (*QueryListHeadersRequest) Descriptor

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

func (*QueryListHeadersRequest) GetChainId

func (m *QueryListHeadersRequest) GetChainId() string

func (*QueryListHeadersRequest) GetPagination

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

func (*QueryListHeadersRequest) Marshal

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

func (*QueryListHeadersRequest) MarshalTo

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

func (*QueryListHeadersRequest) MarshalToSizedBuffer

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

func (*QueryListHeadersRequest) ProtoMessage

func (*QueryListHeadersRequest) ProtoMessage()

func (*QueryListHeadersRequest) Reset

func (m *QueryListHeadersRequest) Reset()

func (*QueryListHeadersRequest) Size

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

func (*QueryListHeadersRequest) String

func (m *QueryListHeadersRequest) String() string

func (*QueryListHeadersRequest) Unmarshal

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

func (*QueryListHeadersRequest) XXX_DiscardUnknown

func (m *QueryListHeadersRequest) XXX_DiscardUnknown()

func (*QueryListHeadersRequest) XXX_Marshal

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

func (*QueryListHeadersRequest) XXX_Merge

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

func (*QueryListHeadersRequest) XXX_Size

func (m *QueryListHeadersRequest) XXX_Size() int

func (*QueryListHeadersRequest) XXX_Unmarshal

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

type QueryListHeadersResponse

type QueryListHeadersResponse struct {
	// headers is the list of headers
	Headers []*IndexedHeader `protobuf:"bytes,1,rep,name=headers,proto3" json:"headers,omitempty"`
	// pagination defines the pagination in the response
	Pagination *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

QueryListHeadersResponse is response type for the Query/ListHeaders RPC method.

func (*QueryListHeadersResponse) Descriptor

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

func (*QueryListHeadersResponse) GetHeaders

func (m *QueryListHeadersResponse) GetHeaders() []*IndexedHeader

func (*QueryListHeadersResponse) GetPagination

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

func (*QueryListHeadersResponse) Marshal

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

func (*QueryListHeadersResponse) MarshalTo

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

func (*QueryListHeadersResponse) MarshalToSizedBuffer

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

func (*QueryListHeadersResponse) ProtoMessage

func (*QueryListHeadersResponse) ProtoMessage()

func (*QueryListHeadersResponse) Reset

func (m *QueryListHeadersResponse) Reset()

func (*QueryListHeadersResponse) Size

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

func (*QueryListHeadersResponse) String

func (m *QueryListHeadersResponse) String() string

func (*QueryListHeadersResponse) Unmarshal

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

func (*QueryListHeadersResponse) XXX_DiscardUnknown

func (m *QueryListHeadersResponse) XXX_DiscardUnknown()

func (*QueryListHeadersResponse) XXX_Marshal

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

func (*QueryListHeadersResponse) XXX_Merge

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

func (*QueryListHeadersResponse) XXX_Size

func (m *QueryListHeadersResponse) XXX_Size() int

func (*QueryListHeadersResponse) XXX_Unmarshal

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

type QueryParamsRequest

type QueryParamsRequest struct {
}

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

func (*QueryParamsRequest) Descriptor

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

func (*QueryParamsRequest) Marshal

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

func (*QueryParamsRequest) MarshalTo

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

func (*QueryParamsRequest) MarshalToSizedBuffer

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

func (*QueryParamsRequest) ProtoMessage

func (*QueryParamsRequest) ProtoMessage()

func (*QueryParamsRequest) Reset

func (m *QueryParamsRequest) Reset()

func (*QueryParamsRequest) Size

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

func (*QueryParamsRequest) String

func (m *QueryParamsRequest) String() string

func (*QueryParamsRequest) Unmarshal

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

func (*QueryParamsRequest) XXX_DiscardUnknown

func (m *QueryParamsRequest) XXX_DiscardUnknown()

func (*QueryParamsRequest) XXX_Marshal

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

func (*QueryParamsRequest) XXX_Merge

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

func (*QueryParamsRequest) XXX_Size

func (m *QueryParamsRequest) XXX_Size() int

func (*QueryParamsRequest) XXX_Unmarshal

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

type QueryParamsResponse

type QueryParamsResponse struct {
	// params holds all the parameters of this module.
	Params Params `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
}

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

func (*QueryParamsResponse) Descriptor

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

func (*QueryParamsResponse) GetParams

func (m *QueryParamsResponse) GetParams() Params

func (*QueryParamsResponse) Marshal

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

func (*QueryParamsResponse) MarshalTo

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

func (*QueryParamsResponse) MarshalToSizedBuffer

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

func (*QueryParamsResponse) ProtoMessage

func (*QueryParamsResponse) ProtoMessage()

func (*QueryParamsResponse) Reset

func (m *QueryParamsResponse) Reset()

func (*QueryParamsResponse) Size

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

func (*QueryParamsResponse) String

func (m *QueryParamsResponse) String() string

func (*QueryParamsResponse) Unmarshal

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

func (*QueryParamsResponse) XXX_DiscardUnknown

func (m *QueryParamsResponse) XXX_DiscardUnknown()

func (*QueryParamsResponse) XXX_Marshal

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

func (*QueryParamsResponse) XXX_Merge

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

func (*QueryParamsResponse) XXX_Size

func (m *QueryParamsResponse) XXX_Size() int

func (*QueryParamsResponse) XXX_Unmarshal

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

type QueryServer

type QueryServer interface {
	// Params queries the parameters of the module.
	Params(context.Context, *QueryParamsRequest) (*QueryParamsResponse, error)
	// Header queries the CZ header and fork headers at a given height.
	Header(context.Context, *QueryHeaderRequest) (*QueryHeaderResponse, error)
	// ChainList queries the list of chains that checkpoint to Babylon
	ChainList(context.Context, *QueryChainListRequest) (*QueryChainListResponse, error)
	// ChainsInfo queries the latest info for a given list of chains in Babylon's view
	ChainsInfo(context.Context, *QueryChainsInfoRequest) (*QueryChainsInfoResponse, error)
	// EpochChainsInfo queries the latest info for a list of chains
	// in a given epoch in Babylon's view
	EpochChainsInfo(context.Context, *QueryEpochChainsInfoRequest) (*QueryEpochChainsInfoResponse, error)
	// ListHeaders queries the headers of a chain in Babylon's view, with
	// pagination support
	ListHeaders(context.Context, *QueryListHeadersRequest) (*QueryListHeadersResponse, error)
	// ListEpochHeaders queries the headers of a chain timestamped in a given
	// epoch of Babylon, with pagination support
	ListEpochHeaders(context.Context, *QueryListEpochHeadersRequest) (*QueryListEpochHeadersResponse, error)
	// FinalizedChainsInfo queries the BTC-finalised info of chains with given IDs, with proofs
	FinalizedChainsInfo(context.Context, *QueryFinalizedChainsInfoRequest) (*QueryFinalizedChainsInfoResponse, error)
	// FinalizedChainInfoUntilHeight queries the BTC-finalised info no later than
	// the provided CZ height, with proofs
	FinalizedChainInfoUntilHeight(context.Context, *QueryFinalizedChainInfoUntilHeightRequest) (*QueryFinalizedChainInfoUntilHeightResponse, error)
}

QueryServer is the server API for Query service.

type ScopedKeeper

type ScopedKeeper interface {
	GetCapability(ctx sdk.Context, name string) (*capabilitytypes.Capability, bool)
	AuthenticateCapability(ctx sdk.Context, cap *capabilitytypes.Capability, name string) bool
	LookupModules(ctx sdk.Context, name string) ([]string, *capabilitytypes.Capability, error)
	ClaimCapability(ctx sdk.Context, cap *capabilitytypes.Capability, name string) error
}

ScopedKeeper defines the expected x/capability scoped keeper interface

type TMClient

type TMClient interface {
	Tx(ctx context.Context, hash []byte, prove bool) (*ctypes.ResultTx, error)
}

TMClient is a Tendermint client that allows to query tx inclusion proofs

type UnimplementedMsgServer

type UnimplementedMsgServer struct {
}

UnimplementedMsgServer can be embedded to have forward compatible implementations.

func (*UnimplementedMsgServer) UpdateParams added in v0.7.0

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) ChainList

func (*UnimplementedQueryServer) ChainsInfo added in v0.6.0

func (*UnimplementedQueryServer) EpochChainsInfo added in v0.6.0

func (*UnimplementedQueryServer) FinalizedChainsInfo added in v0.6.0

func (*UnimplementedQueryServer) Header

func (*UnimplementedQueryServer) ListEpochHeaders

func (*UnimplementedQueryServer) ListHeaders

func (*UnimplementedQueryServer) Params

type ZoneconciergePacketData

type ZoneconciergePacketData struct {
	// packet is the actual message carried in the IBC packet
	//
	// Types that are valid to be assigned to Packet:
	//	*ZoneconciergePacketData_BtcTimestamp
	Packet isZoneconciergePacketData_Packet `protobuf_oneof:"packet"`
}

ZoneconciergePacketData is the message that defines the IBC packets of ZoneConcierge

func NewBTCTimestampPacketData added in v0.7.0

func NewBTCTimestampPacketData(btcTimestamp *BTCTimestamp) *ZoneconciergePacketData

func (*ZoneconciergePacketData) Descriptor

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

func (*ZoneconciergePacketData) GetBtcTimestamp added in v0.7.0

func (m *ZoneconciergePacketData) GetBtcTimestamp() *BTCTimestamp

func (*ZoneconciergePacketData) GetPacket

func (m *ZoneconciergePacketData) GetPacket() isZoneconciergePacketData_Packet

func (*ZoneconciergePacketData) Marshal

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

func (*ZoneconciergePacketData) MarshalTo

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

func (*ZoneconciergePacketData) MarshalToSizedBuffer

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

func (*ZoneconciergePacketData) ProtoMessage

func (*ZoneconciergePacketData) ProtoMessage()

func (*ZoneconciergePacketData) Reset

func (m *ZoneconciergePacketData) Reset()

func (*ZoneconciergePacketData) Size

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

func (*ZoneconciergePacketData) String

func (m *ZoneconciergePacketData) String() string

func (*ZoneconciergePacketData) Unmarshal

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

func (*ZoneconciergePacketData) XXX_DiscardUnknown

func (m *ZoneconciergePacketData) XXX_DiscardUnknown()

func (*ZoneconciergePacketData) XXX_Marshal

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

func (*ZoneconciergePacketData) XXX_Merge

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

func (*ZoneconciergePacketData) XXX_OneofWrappers

func (*ZoneconciergePacketData) XXX_OneofWrappers() []interface{}

XXX_OneofWrappers is for the internal use of the proto package.

func (*ZoneconciergePacketData) XXX_Size

func (m *ZoneconciergePacketData) XXX_Size() int

func (*ZoneconciergePacketData) XXX_Unmarshal

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

type ZoneconciergePacketData_BtcTimestamp added in v0.7.0

type ZoneconciergePacketData_BtcTimestamp struct {
	BtcTimestamp *BTCTimestamp `protobuf:"bytes,1,opt,name=btc_timestamp,json=btcTimestamp,proto3,oneof" json:"btc_timestamp,omitempty"`
}

func (*ZoneconciergePacketData_BtcTimestamp) MarshalTo added in v0.7.0

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

func (*ZoneconciergePacketData_BtcTimestamp) MarshalToSizedBuffer added in v0.7.0

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

func (*ZoneconciergePacketData_BtcTimestamp) Size added in v0.7.0

Jump to

Keyboard shortcuts

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