types

package
v0.5.0 Latest Latest
Warning

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

Go to latest
Published: Feb 3, 2023 License: Apache-2.0 Imports: 42 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 (
	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"

	// PortID is the default port id that module binds to
	PortID = "zoneconcierge"
)
View Source
const DefaultIndex uint64 = 1

DefaultIndex is the default global index

Variables

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

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
)
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 (
	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 ParamKeyTable

func ParamKeyTable() paramtypes.KeyTable

ParamKeyTable the param key table for launch module

func RegisterCodec

func RegisterCodec(cdc *codec.LegacyAmino)

func RegisterInterfaces

func RegisterInterfaces(registry cdctypes.InterfaceRegistry)

func RegisterMsgServer

func RegisterMsgServer(s grpc1.Server, srv MsgServer)

func RegisterQueryHandler

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

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

func RegisterQueryHandlerClient

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

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

func RegisterQueryHandlerFromEndpoint

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

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

func RegisterQueryHandlerServer

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

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

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

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 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 {
	GetBestSubmission(ctx sdk.Context, e uint64) (btcctypes.BtcStatus, *btcctypes.SubmissionKey, error)
	GetSubmissionData(ctx sdk.Context, sk btcctypes.SubmissionKey) *btcctypes.SubmissionData
}

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

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 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 {
	Params Params `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
	PortId string `protobuf:"bytes,2,opt,name=port_id,json=portId,proto3" json:"port_id,omitempty"`
}

GenesisState defines the zoneconcierge module's genesis state.

func DefaultGenesis

func DefaultGenesis() *GenesisState

DefaultGenesis returns the default genesis state

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 Heartbeat

type Heartbeat struct {
	Msg string `protobuf:"bytes,1,opt,name=msg,proto3" json:"msg,omitempty"`
}

func (*Heartbeat) Descriptor

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

func (*Heartbeat) GetMsg

func (m *Heartbeat) GetMsg() string

func (*Heartbeat) Marshal

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

func (*Heartbeat) MarshalTo

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

func (*Heartbeat) MarshalToSizedBuffer

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

func (*Heartbeat) ProtoMessage

func (*Heartbeat) ProtoMessage()

func (*Heartbeat) Reset

func (m *Heartbeat) Reset()

func (*Heartbeat) Size

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

func (*Heartbeat) String

func (m *Heartbeat) String() string

func (*Heartbeat) Unmarshal

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

func (*Heartbeat) XXX_DiscardUnknown

func (m *Heartbeat) XXX_DiscardUnknown()

func (*Heartbeat) XXX_Marshal

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

func (*Heartbeat) XXX_Merge

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

func (*Heartbeat) XXX_Size

func (m *Heartbeat) XXX_Size() int

func (*Heartbeat) XXX_Unmarshal

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

type ICS4Wrapper

type ICS4Wrapper interface {
	SendPacket(ctx sdk.Context, channelCap *capabilitytypes.Capability, packet ibcexported.PacketI) 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"`
	// babylon_header is the header of the babylon block that includes this CZ header
	BabylonHeader *types.Header `protobuf:"bytes,4,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,5,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,6,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) 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 types2.Context, name string) types3.ModuleAccountI

GetModuleAccount mocks base method.

func (*MockAccountKeeper) GetModuleAddress

func (m *MockAccountKeeper) GetModuleAddress(name string) types2.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 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 types2.AccAddress) bool

BlockedAddr mocks base method.

func (*MockBankKeeper) BurnCoins

func (m *MockBankKeeper) BurnCoins(ctx types2.Context, moduleName string, amt types2.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 types2.Context, moduleName string, amt types2.Coins) error

MintCoins mocks base method.

func (*MockBankKeeper) SendCoins

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

SendCoins mocks base method.

func (*MockBankKeeper) SendCoinsFromAccountToModule

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

SendCoinsFromAccountToModule mocks base method.

func (*MockBankKeeper) SendCoinsFromModuleToAccount

func (m *MockBankKeeper) SendCoinsFromModuleToAccount(ctx types2.Context, senderModule string, recipientAddr types2.AccAddress, amt types2.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) 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) 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 types2.Context) []types6.IdentifiedChannel

GetAllChannels mocks base method.

func (*MockChannelKeeper) GetChannel

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

GetChannel mocks base method.

func (*MockChannelKeeper) GetNextSequenceSend

func (m *MockChannelKeeper) GetNextSequenceSend(ctx types2.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) 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 types2.Context, epochNumber uint64) ([]*types0.ValidatorWithBlsKey, error)

GetBLSPubKeySet mocks base method.

func (*MockCheckpointingKeeper) GetRawCheckpoint

func (m *MockCheckpointingKeeper) GetRawCheckpoint(ctx types2.Context, epochNumber uint64) (*types0.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 types2.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 types2.Context, connectionID string) (types5.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 types2.Context) *types1.Epoch

GetEpoch mocks base method.

func (*MockEpochingKeeper) GetHistoricalEpoch

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

GetHistoricalEpoch mocks base method.

func (*MockEpochingKeeper) ProveAppHashInEpoch

func (m *MockEpochingKeeper) ProveAppHashInEpoch(ctx types2.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 types2.Context, channelCap *types4.Capability, packet exported.PacketI) 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, packet 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 types2.Context, portID string) *types4.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 types2.Context, cap *types4.Capability, name string) bool

AuthenticateCapability mocks base method.

func (*MockScopedKeeper) ClaimCapability

func (m *MockScopedKeeper) ClaimCapability(ctx types2.Context, cap *types4.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 types2.Context, name string) (*types4.Capability, bool)

GetCapability mocks base method.

func (*MockScopedKeeper) LookupModules

func (m *MockScopedKeeper) LookupModules(ctx types2.Context, name string) ([]string, *types4.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 {
}

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 {
}

MsgServer is the server API for Msg service.

type Params

type Params struct {
}

Params defines the parameters for the module.

func DefaultParams

func DefaultParams() Params

DefaultParams returns a default set of parameters

func NewParams

func NewParams() Params

NewParams creates a new Params instance

func (*Params) Descriptor

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

func (*Params) Marshal

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

func (*Params) MarshalTo

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

func (*Params) MarshalToSizedBuffer

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

func (*Params) ParamSetPairs

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

ParamSetPairs get the params.ParamSet

func (*Params) ProtoMessage

func (*Params) ProtoMessage()

func (*Params) Reset

func (m *Params) Reset()

func (*Params) Size

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

func (Params) String

func (p Params) String() string

String implements the Stringer interface.

func (*Params) Unmarshal

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

func (Params) Validate

func (p Params) Validate() error

Validate validates the set of params

func (*Params) XXX_DiscardUnknown

func (m *Params) XXX_DiscardUnknown()

func (*Params) XXX_Marshal

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

func (*Params) XXX_Merge

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

func (*Params) XXX_Size

func (m *Params) XXX_Size() int

func (*Params) XXX_Unmarshal

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

type 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 []*types1.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() []*types1.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 []*types2.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() []*types2.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 QueryChainInfoRequest

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

QueryChainInfoRequest is request type for the Query/ChainInfo RPC method.

func (*QueryChainInfoRequest) Descriptor

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

func (*QueryChainInfoRequest) GetChainId

func (m *QueryChainInfoRequest) GetChainId() string

func (*QueryChainInfoRequest) Marshal

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

func (*QueryChainInfoRequest) MarshalTo

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

func (*QueryChainInfoRequest) MarshalToSizedBuffer

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

func (*QueryChainInfoRequest) ProtoMessage

func (*QueryChainInfoRequest) ProtoMessage()

func (*QueryChainInfoRequest) Reset

func (m *QueryChainInfoRequest) Reset()

func (*QueryChainInfoRequest) Size

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

func (*QueryChainInfoRequest) String

func (m *QueryChainInfoRequest) String() string

func (*QueryChainInfoRequest) Unmarshal

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

func (*QueryChainInfoRequest) XXX_DiscardUnknown

func (m *QueryChainInfoRequest) XXX_DiscardUnknown()

func (*QueryChainInfoRequest) XXX_Marshal

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

func (*QueryChainInfoRequest) XXX_Merge

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

func (*QueryChainInfoRequest) XXX_Size

func (m *QueryChainInfoRequest) XXX_Size() int

func (*QueryChainInfoRequest) XXX_Unmarshal

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

type QueryChainInfoResponse

type QueryChainInfoResponse struct {
	// chain_info is the info of the CZ
	ChainInfo *ChainInfo `protobuf:"bytes,1,opt,name=chain_info,json=chainInfo,proto3" json:"chain_info,omitempty"`
}

QueryChainInfoResponse is response type for the Query/ChainInfo RPC method.

func (*QueryChainInfoResponse) Descriptor

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

func (*QueryChainInfoResponse) GetChainInfo

func (m *QueryChainInfoResponse) GetChainInfo() *ChainInfo

func (*QueryChainInfoResponse) Marshal

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

func (*QueryChainInfoResponse) MarshalTo

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

func (*QueryChainInfoResponse) MarshalToSizedBuffer

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

func (*QueryChainInfoResponse) ProtoMessage

func (*QueryChainInfoResponse) ProtoMessage()

func (*QueryChainInfoResponse) Reset

func (m *QueryChainInfoResponse) Reset()

func (*QueryChainInfoResponse) Size

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

func (*QueryChainInfoResponse) String

func (m *QueryChainInfoResponse) String() string

func (*QueryChainInfoResponse) Unmarshal

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

func (*QueryChainInfoResponse) XXX_DiscardUnknown

func (m *QueryChainInfoResponse) XXX_DiscardUnknown()

func (*QueryChainInfoResponse) XXX_Marshal

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

func (*QueryChainInfoResponse) XXX_Merge

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

func (*QueryChainInfoResponse) XXX_Size

func (m *QueryChainInfoResponse) XXX_Size() int

func (*QueryChainInfoResponse) XXX_Unmarshal

func (m *QueryChainInfoResponse) 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 QueryClient

type QueryClient interface {
	// Parameters 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)
	// ChainInfo queries the latest info of a chain in Babylon's view
	ChainInfo(ctx context.Context, in *QueryChainInfoRequest, opts ...grpc.CallOption) (*QueryChainInfoResponse, error)
	// EpochChainInfo queries the latest info of a chain in a given epoch of Babylon's view
	EpochChainInfo(ctx context.Context, in *QueryEpochChainInfoRequest, opts ...grpc.CallOption) (*QueryEpochChainInfoResponse, 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)
	// FinalizedChainInfo queries the BTC-finalised info of a chain, with proofs
	FinalizedChainInfo(ctx context.Context, in *QueryFinalizedChainInfoRequest, opts ...grpc.CallOption) (*QueryFinalizedChainInfoResponse, 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 QueryEpochChainInfoRequest

type QueryEpochChainInfoRequest 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"`
}

QueryEpochChainInfoRequest is request type for the Query/EpochChainInfo RPC method.

func (*QueryEpochChainInfoRequest) Descriptor

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

func (*QueryEpochChainInfoRequest) GetChainId

func (m *QueryEpochChainInfoRequest) GetChainId() string

func (*QueryEpochChainInfoRequest) GetEpochNum

func (m *QueryEpochChainInfoRequest) GetEpochNum() uint64

func (*QueryEpochChainInfoRequest) Marshal

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

func (*QueryEpochChainInfoRequest) MarshalTo

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

func (*QueryEpochChainInfoRequest) MarshalToSizedBuffer

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

func (*QueryEpochChainInfoRequest) ProtoMessage

func (*QueryEpochChainInfoRequest) ProtoMessage()

func (*QueryEpochChainInfoRequest) Reset

func (m *QueryEpochChainInfoRequest) Reset()

func (*QueryEpochChainInfoRequest) Size

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

func (*QueryEpochChainInfoRequest) String

func (m *QueryEpochChainInfoRequest) String() string

func (*QueryEpochChainInfoRequest) Unmarshal

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

func (*QueryEpochChainInfoRequest) XXX_DiscardUnknown

func (m *QueryEpochChainInfoRequest) XXX_DiscardUnknown()

func (*QueryEpochChainInfoRequest) XXX_Marshal

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

func (*QueryEpochChainInfoRequest) XXX_Merge

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

func (*QueryEpochChainInfoRequest) XXX_Size

func (m *QueryEpochChainInfoRequest) XXX_Size() int

func (*QueryEpochChainInfoRequest) XXX_Unmarshal

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

type QueryEpochChainInfoResponse

type QueryEpochChainInfoResponse struct {
	// chain_info is the info of the CZ
	ChainInfo *ChainInfo `protobuf:"bytes,1,opt,name=chain_info,json=chainInfo,proto3" json:"chain_info,omitempty"`
}

QueryEpochChainInfoResponse is response type for the Query/EpochChainInfo RPC method.

func (*QueryEpochChainInfoResponse) Descriptor

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

func (*QueryEpochChainInfoResponse) GetChainInfo

func (m *QueryEpochChainInfoResponse) GetChainInfo() *ChainInfo

func (*QueryEpochChainInfoResponse) Marshal

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

func (*QueryEpochChainInfoResponse) MarshalTo

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

func (*QueryEpochChainInfoResponse) MarshalToSizedBuffer

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

func (*QueryEpochChainInfoResponse) ProtoMessage

func (*QueryEpochChainInfoResponse) ProtoMessage()

func (*QueryEpochChainInfoResponse) Reset

func (m *QueryEpochChainInfoResponse) Reset()

func (*QueryEpochChainInfoResponse) Size

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

func (*QueryEpochChainInfoResponse) String

func (m *QueryEpochChainInfoResponse) String() string

func (*QueryEpochChainInfoResponse) Unmarshal

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

func (*QueryEpochChainInfoResponse) XXX_DiscardUnknown

func (m *QueryEpochChainInfoResponse) XXX_DiscardUnknown()

func (*QueryEpochChainInfoResponse) XXX_Marshal

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

func (*QueryEpochChainInfoResponse) XXX_Merge

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

func (*QueryEpochChainInfoResponse) XXX_Size

func (m *QueryEpochChainInfoResponse) XXX_Size() int

func (*QueryEpochChainInfoResponse) XXX_Unmarshal

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

type QueryFinalizedChainInfoRequest

type QueryFinalizedChainInfoRequest 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"`
	// prove indicates whether the querier wants to get proofs of this timestamp
	Prove bool `protobuf:"varint,2,opt,name=prove,proto3" json:"prove,omitempty"`
}

QueryFinalizedChainInfoRequest is request type for the Query/FinalizedChainInfo RPC method.

func (*QueryFinalizedChainInfoRequest) Descriptor

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

func (*QueryFinalizedChainInfoRequest) GetChainId

func (m *QueryFinalizedChainInfoRequest) GetChainId() string

func (*QueryFinalizedChainInfoRequest) GetProve

func (m *QueryFinalizedChainInfoRequest) GetProve() bool

func (*QueryFinalizedChainInfoRequest) Marshal

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

func (*QueryFinalizedChainInfoRequest) MarshalTo

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

func (*QueryFinalizedChainInfoRequest) MarshalToSizedBuffer

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

func (*QueryFinalizedChainInfoRequest) ProtoMessage

func (*QueryFinalizedChainInfoRequest) ProtoMessage()

func (*QueryFinalizedChainInfoRequest) Reset

func (m *QueryFinalizedChainInfoRequest) Reset()

func (*QueryFinalizedChainInfoRequest) Size

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

func (*QueryFinalizedChainInfoRequest) String

func (*QueryFinalizedChainInfoRequest) Unmarshal

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

func (*QueryFinalizedChainInfoRequest) XXX_DiscardUnknown

func (m *QueryFinalizedChainInfoRequest) XXX_DiscardUnknown()

func (*QueryFinalizedChainInfoRequest) XXX_Marshal

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

func (*QueryFinalizedChainInfoRequest) XXX_Merge

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

func (*QueryFinalizedChainInfoRequest) XXX_Size

func (m *QueryFinalizedChainInfoRequest) XXX_Size() int

func (*QueryFinalizedChainInfoRequest) XXX_Unmarshal

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

type QueryFinalizedChainInfoResponse

type QueryFinalizedChainInfoResponse 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"`
}

QueryFinalizedChainInfoResponse is response type for the Query/FinalizedChainInfo RPC method.

func (*QueryFinalizedChainInfoResponse) Descriptor

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

func (*QueryFinalizedChainInfoResponse) GetBtcSubmissionKey

func (m *QueryFinalizedChainInfoResponse) GetBtcSubmissionKey() *types2.SubmissionKey

func (*QueryFinalizedChainInfoResponse) GetEpochInfo

func (m *QueryFinalizedChainInfoResponse) GetEpochInfo() *types.Epoch

func (*QueryFinalizedChainInfoResponse) GetFinalizedChainInfo

func (m *QueryFinalizedChainInfoResponse) GetFinalizedChainInfo() *ChainInfo

func (*QueryFinalizedChainInfoResponse) GetProof

func (*QueryFinalizedChainInfoResponse) GetRawCheckpoint

func (m *QueryFinalizedChainInfoResponse) GetRawCheckpoint() *types1.RawCheckpoint

func (*QueryFinalizedChainInfoResponse) Marshal

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

func (*QueryFinalizedChainInfoResponse) MarshalTo

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

func (*QueryFinalizedChainInfoResponse) MarshalToSizedBuffer

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

func (*QueryFinalizedChainInfoResponse) ProtoMessage

func (*QueryFinalizedChainInfoResponse) ProtoMessage()

func (*QueryFinalizedChainInfoResponse) Reset

func (*QueryFinalizedChainInfoResponse) Size

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

func (*QueryFinalizedChainInfoResponse) String

func (*QueryFinalizedChainInfoResponse) Unmarshal

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

func (*QueryFinalizedChainInfoResponse) XXX_DiscardUnknown

func (m *QueryFinalizedChainInfoResponse) XXX_DiscardUnknown()

func (*QueryFinalizedChainInfoResponse) XXX_Marshal

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

func (*QueryFinalizedChainInfoResponse) XXX_Merge

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

func (*QueryFinalizedChainInfoResponse) XXX_Size

func (m *QueryFinalizedChainInfoResponse) XXX_Size() int

func (*QueryFinalizedChainInfoResponse) XXX_Unmarshal

func (m *QueryFinalizedChainInfoResponse) 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 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"`
}

QueryParamsResponse 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 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 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 {
	// Parameters 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)
	// ChainInfo queries the latest info of a chain in Babylon's view
	ChainInfo(context.Context, *QueryChainInfoRequest) (*QueryChainInfoResponse, error)
	// EpochChainInfo queries the latest info of a chain in a given epoch of Babylon's view
	EpochChainInfo(context.Context, *QueryEpochChainInfoRequest) (*QueryEpochChainInfoResponse, 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)
	// FinalizedChainInfo queries the BTC-finalised info of a chain, with proofs
	FinalizedChainInfo(context.Context, *QueryFinalizedChainInfoRequest) (*QueryFinalizedChainInfoResponse, 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.

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) ChainInfo

func (*UnimplementedQueryServer) ChainList

func (*UnimplementedQueryServer) EpochChainInfo

func (*UnimplementedQueryServer) FinalizedChainInfo

func (*UnimplementedQueryServer) Header

func (*UnimplementedQueryServer) ListEpochHeaders

func (*UnimplementedQueryServer) ListHeaders

func (*UnimplementedQueryServer) Params

type ZoneconciergePacketData

type ZoneconciergePacketData struct {
	// Types that are valid to be assigned to Packet:
	//	*ZoneconciergePacketData_Heartbeart
	Packet isZoneconciergePacketData_Packet `protobuf_oneof:"packet"`
}

func (*ZoneconciergePacketData) Descriptor

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

func (*ZoneconciergePacketData) GetHeartbeart

func (m *ZoneconciergePacketData) GetHeartbeart() *Heartbeat

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_Heartbeart

type ZoneconciergePacketData_Heartbeart struct {
	Heartbeart *Heartbeat `protobuf:"bytes,1,opt,name=heartbeart,proto3,oneof" json:"heartbeart,omitempty"`
}

func (*ZoneconciergePacketData_Heartbeart) MarshalTo

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

func (*ZoneconciergePacketData_Heartbeart) MarshalToSizedBuffer

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

func (*ZoneconciergePacketData_Heartbeart) Size

Jump to

Keyboard shortcuts

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