types

package
v1.2.1 Latest Latest
Warning

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

Go to latest
Published: Apr 25, 2023 License: Apache-2.0 Imports: 45 Imported by: 28

Documentation

Overview

Package types is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

Index

Constants

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

	// StoreKey is the store key string for IBC transfer
	StoreKey = ModuleName

	// RouterKey is the message route for IBC transfer
	RouterKey = ModuleName

	// QuerierRoute is the querier route for IBC transfer
	QuerierRoute = ModuleName

	// Default validator set update ID
	DefaultValsetUpdateID = 1
)
View Source
const (

	// PortKey defines the key to store the port ID in store
	PortByteKey byte = iota

	// MaturedUnbondingOpsByteKey is the byte key that stores the list of all unbonding operations ids
	// that have matured from a consumer chain perspective,
	// i.e., no longer waiting on the unbonding period to elapse on any consumer chain
	MaturedUnbondingOpsByteKey

	// ValidatorSetUpdateIdByteKey is the byte key that stores the current validator set update id
	ValidatorSetUpdateIdByteKey

	// SlashMeterByteKey is the byte key for storing the slash meter
	SlashMeterByteKey

	// SlashMeterReplenishTimeCandidateByteKey is the byte key for storing the slash meter replenish time candidate
	SlashMeterReplenishTimeCandidateByteKey

	// ChainToChannelBytePrefix is the byte prefix for storing mapping
	// from chainID to the channel ID that is used to send over validator set changes.
	ChainToChannelBytePrefix

	// ChannelToChainBytePrefix is the byte prefix for storing mapping
	// from the CCV channel ID to the consumer chain ID.
	ChannelToChainBytePrefix

	// ChainToClientBytePrefix is the byte prefix for storing the client ID for a given consumer chainID.
	ChainToClientBytePrefix

	// InitTimeoutTimestampBytePrefix is the byte prefix for storing
	// the init timeout timestamp for a given consumer chainID.
	InitTimeoutTimestampBytePrefix

	// PendingCAPBytePrefix is the byte prefix for storing pending consumer addition proposals before the spawn time occurs.
	// The key includes the BigEndian timestamp to allow for efficient chronological iteration
	PendingCAPBytePrefix

	// PendingCRPBytePrefix is the byte prefix for storing pending consumer removal proposals before the stop time occurs.
	// The key includes the BigEndian timestamp to allow for efficient chronological iteration
	PendingCRPBytePrefix

	// UnbondingOpBytePrefix is the byte prefix that stores a record of all the ids of consumer chains that
	// need to unbond before a given unbonding operation can unbond on this chain.
	UnbondingOpBytePrefix

	// UnbondingOpIndexBytePrefix is byte prefix of the index for looking up which unbonding
	// operations are waiting for a given consumer chain to unbond
	UnbondingOpIndexBytePrefix

	// ValsetUpdateBlockHeightBytePrefix is the byte prefix that will store the mapping from vscIDs to block heights
	ValsetUpdateBlockHeightBytePrefix

	// ConsumerGenesisBytePrefix stores consumer genesis state material (consensus state and client state) indexed by consumer chain id
	ConsumerGenesisBytePrefix

	// SlashAcksBytePrefix is the byte prefix that will store consensus address of consumer chain validators successfully slashed on the provider chain
	SlashAcksBytePrefix

	// InitChainHeightBytePrefix is the byte prefix that will store the mapping from a chain id to the corresponding block height on the provider
	// this consumer chain was initialized
	InitChainHeightBytePrefix

	// PendingVSCsBytePrefix is the byte prefix that will store pending ValidatorSetChangePacket data
	PendingVSCsBytePrefix

	// VscSendTimestampBytePrefix is the byte prefix for storing
	// the list of VSC sending timestamps for a given consumer chainID.
	VscSendTimestampBytePrefix

	// ThrottledPacketDataSizeBytePrefix is the byte prefix for storing the size of chain-specific throttled packet data queues
	ThrottledPacketDataSizeBytePrefix

	// ThrottledPacketDataBytePrefix is the byte prefix storing throttled packet data
	ThrottledPacketDataBytePrefix

	// GlobalSlashEntryBytePrefix is the byte prefix storing global slash queue entries
	GlobalSlashEntryBytePrefix

	// ConsumerValidatorsBytePrefix is the byte prefix that will store the validator assigned keys for every consumer chain
	ConsumerValidatorsBytePrefix

	// ValidatorsByConsumerAddrBytePrefix is the byte prefix that will store the mapping from validator addresses
	// on consumer chains to validator addresses on the provider chain
	ValidatorsByConsumerAddrBytePrefix

	// KeyAssignmentReplacementsBytePrefix is the byte prefix that will store the key assignments that need to be replaced in the current block
	KeyAssignmentReplacementsBytePrefix

	// ConsumerAddrsToPruneBytePrefix is the byte prefix that will store the mapping from VSC ids
	// to consumer validators addresses needed for pruning
	ConsumerAddrsToPruneBytePrefix

	// SlashLogBytePrefix is the byte prefix that will store the mapping from provider address to boolean
	// denoting whether the provider address has commited any double signign infractions
	SlashLogBytePrefix
)

Iota generated keys/byte prefixes (as a byte), supports 256 possible values

View Source
const (
	// DefaultMaxClockDrift defines how much new (untrusted) header's Time can drift into the future.
	// This default is only used in the default template client param.
	DefaultMaxClockDrift = 10 * time.Second

	// DefaultTrustingPeriodFraction is the default fraction used to compute TrustingPeriod
	// as UnbondingPeriod * TrustingPeriodFraction
	DefaultTrustingPeriodFraction = "0.66"

	// DefaultInitTimeoutPeriod defines the init timeout period
	DefaultInitTimeoutPeriod = 7 * 24 * time.Hour

	// DefaultVscTimeoutPeriod defines the VSC timeout period
	DefaultVscTimeoutPeriod = 5 * 7 * 24 * time.Hour

	// DefaultSlashMeterReplenishPeriod defines the default period for which the slash gas meter is replenished
	DefaultSlashMeterReplenishPeriod = time.Hour

	// DefaultSlashMeterReplenishFraction defines the default fraction of total voting power
	// that is replenished to the slash meter every replenish period. This param also serves as a maximum
	// fraction of total voting power that the slash meter can hold.
	DefaultSlashMeterReplenishFraction = "0.05"

	// DefaultMaxThrottledPackets defines the default amount of throttled slash or vsc matured packets
	// that can be queued for a single consumer before the provider chain halts.
	DefaultMaxThrottledPackets = 100000
)
View Source
const (
	ProposalTypeConsumerAddition = "ConsumerAddition"
	ProposalTypeConsumerRemoval  = "ConsumerRemoval"
	ProposalTypeEquivocation     = "Equivocation"
)
View Source
const (
	TypeMsgAssignConsumerKey = "assign_consumer_key"
)

provider message types

Variables

View Source
var (

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

	// AminoCdc is a amino codec created to support amino json compatible msgs.
	AminoCdc = codec.NewAminoCodec(amino)
)
View Source
var (
	ErrInvalidConsumerAdditionProposal = sdkerrors.Register(ModuleName, 1, "invalid consumer addition proposal")
	ErrInvalidConsumerRemovalProp      = sdkerrors.Register(ModuleName, 2, "invalid consumer removal proposal")
	ErrUnknownConsumerChainId          = sdkerrors.Register(ModuleName, 3, "no consumer chain with this chain id")
	ErrUnknownConsumerChannelId        = sdkerrors.Register(ModuleName, 4, "no consumer chain with this channel id")
	ErrInvalidConsumerConsensusPubKey  = sdkerrors.Register(ModuleName, 5, "empty consumer consensus public key")
	ErrBlankConsumerChainID            = sdkerrors.Register(ModuleName, 6, "consumer chain id must not be blank")
	ErrConsumerKeyNotFound             = sdkerrors.Register(ModuleName, 7, "consumer key not found")
	ErrNoValidatorConsumerAddress      = sdkerrors.Register(ModuleName, 8, "error getting validator consumer address")
	ErrNoValidatorProviderAddress      = sdkerrors.Register(ModuleName, 9, "error getting validator provider address")
	ErrConsumerKeyInUse                = sdkerrors.Register(ModuleName, 10, "consumer key is already in use by a validator")
	ErrInvalidConsumerParams           = sdkerrors.Register(ModuleName, 11, "invalid consumer params")
	ErrInvalidProviderAddress          = sdkerrors.Register(ModuleName, 12, "invalid provider address")
)

Provider 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 (
	KeyTemplateClient              = []byte("TemplateClient")
	KeyTrustingPeriodFraction      = []byte("TrustingPeriodFraction")
	KeyInitTimeoutPeriod           = []byte("InitTimeoutPeriod")
	KeyVscTimeoutPeriod            = []byte("VscTimeoutPeriod")
	KeySlashMeterReplenishPeriod   = []byte("SlashMeterReplenishPeriod")
	KeySlashMeterReplenishFraction = []byte("SlashMeterReplenishFraction")
	KeyMaxThrottledPackets         = []byte("MaxThrottledPackets")
)

Reflection based keys for params subspace

View Source
var (
	ErrInvalidLengthProvider        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowProvider          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupProvider = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthQuery        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowQuery          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupQuery = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthTx        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowTx          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupTx = fmt.Errorf("proto: unexpected end of group")
)

Functions

func ChainIdAndConsAddrKey added in v1.0.0

func ChainIdAndConsAddrKey(prefix byte, chainID string, addr sdk.ConsAddress) []byte

ChainIdAndConsAddrKey returns the key with the following format: bytePrefix | len(chainID) | chainID | ConsAddress

func ChainIdAndTsKey added in v1.0.0

func ChainIdAndTsKey(prefix byte, chainID string, timestamp time.Time) []byte

ChainIdAndTsKey returns the key with the following format: bytePrefix | len(chainID) | chainID | timestamp

func ChainIdAndUintIdKey added in v1.0.0

func ChainIdAndUintIdKey(prefix byte, chainID string, uintId uint64) []byte

ChainIdAndUintIdKey returns the key with the following format: bytePrefix | len(chainID) | chainID | uint64(ID)

func ChainIdWithLenKey added in v0.2.0

func ChainIdWithLenKey(prefix byte, chainID string) []byte

ChainIdWithLenKey returns the key with the following format: bytePrefix | len(chainID) | chainID

func ChainToChannelKey

func ChainToChannelKey(chainID string) []byte

ChainToChannelKey returns the key under which the CCV channel ID will be stored for the given consumer chain.

func ChainToClientKey

func ChainToClientKey(chainID string) []byte

ChainToClientKey returns the key under which the clientID for the given chainID is stored.

func ChannelToChainKey

func ChannelToChainKey(channelID string) []byte

ChannelToChainKey returns the key under which the consumer chain ID will be stored for the given channelID.

func ConsumerAddrsToPruneKey added in v1.0.0

func ConsumerAddrsToPruneKey(chainID string, vscID uint64) []byte

ConsumerAddrsToPruneKey returns the key under which the mapping from VSC ids to consumer validators addresses is stored

func ConsumerGenesisKey

func ConsumerGenesisKey(chainID string) []byte

ConsumerGenesisKey returns the key corresponding to consumer genesis state material (consensus state and client state) indexed by consumer chain id

func ConsumerValidatorsKey added in v1.0.0

func ConsumerValidatorsKey(chainID string, addr ProviderConsAddress) []byte

ConsumerValidatorsKey returns the key under which the validator assigned keys for every consumer chain are stored

func GlobalSlashEntryKey added in v1.0.0

func GlobalSlashEntryKey(entry GlobalSlashEntry) []byte

GlobalSlashEntryKey returns the key for storing a global slash queue entry.

func InitChainHeightKey

func InitChainHeightKey(chainID string) []byte

InitChainHeightKey returns the key under which the block height for a given chain ID is stored

func InitTimeoutTimestampKey added in v0.2.0

func InitTimeoutTimestampKey(chainID string) []byte

InitTimeoutTimestampKey returns the key under which the init timeout timestamp for the given chainID is stored.

func KeyAssignmentReplacementsKey added in v1.0.0

func KeyAssignmentReplacementsKey(chainID string, addr ProviderConsAddress) []byte

KeyAssignmentReplacementsKey returns the key under which the key assignments that need to be replaced in the current block are stored

func KeyAssignmentValidateBasic added in v1.0.0

func KeyAssignmentValidateBasic(
	assignedKeys []ValidatorConsumerPubKey,
	byConsumerAddrs []ValidatorByConsumerAddr,
	consumerAddrsToPrune []ConsumerAddrsToPrune,
) error

KeyAssignmentValidateBasic validates all the genesis state for key assignment This is a utility. Key Assignment does not define any new proto types, but has a lot of nested data.

func MaturedUnbondingOpsKey

func MaturedUnbondingOpsKey() []byte

MaturedUnbondingOpsKey returns the key for storing the list of matured unbonding operations.

func MustParseGlobalSlashEntryKey added in v1.0.0

func MustParseGlobalSlashEntryKey(bz []byte) (
	recvTime time.Time, consumerChainID string, ibcSeqNum uint64)

MustParseGlobalSlashEntryKey returns the received time and chainID for a global slash queue entry key, or panics if the key is invalid.

func MustParseThrottledPacketDataKey added in v1.0.0

func MustParseThrottledPacketDataKey(key []byte) (string, uint64)

MustParseThrottledPacketDataKey parses a throttled packet data key or panics upon failure

func NewConsumerAdditionProposal added in v0.2.0

func NewConsumerAdditionProposal(title, description, chainID string,
	initialHeight clienttypes.Height, genesisHash, binaryHash []byte,
	spawnTime time.Time,
	consumerRedistributionFraction string,
	blocksPerDistributionTransmission,
	historicalEntries int64,
	ccvTimeoutPeriod time.Duration,
	transferTimeoutPeriod time.Duration,
	unbondingPeriod time.Duration,
) govtypes.Content

NewConsumerAdditionProposal creates a new consumer addition proposal.

func NewConsumerRemovalProposal added in v0.2.0

func NewConsumerRemovalProposal(title, description, chainID string, stopTime time.Time) govtypes.Content

NewConsumerRemovalProposal creates a new consumer removal proposal.

func NewEquivocationProposal added in v1.0.0

func NewEquivocationProposal(title, description string, equivocations []*evidencetypes.Equivocation) govtypes.Content

NewEquivocationProposal creates a new equivocation proposal.

func ParamKeyTable

func ParamKeyTable() paramtypes.KeyTable

ParamKeyTable returns a key table with the necessary registered provider params

func ParseChainIdAndConsAddrKey added in v1.0.0

func ParseChainIdAndConsAddrKey(prefix byte, bz []byte) (string, sdk.ConsAddress, error)

ParseChainIdAndConsAddrKey returns the chain ID and ConsAddress for a ChainIdAndConsAddrKey key

func ParseChainIdAndTsKey added in v1.0.0

func ParseChainIdAndTsKey(prefix byte, bz []byte) (string, time.Time, error)

ParseChainIdAndTsKey returns the chain ID and time for a ChainIdAndTs key

func ParseChainIdAndUintIdKey added in v1.0.0

func ParseChainIdAndUintIdKey(prefix byte, bz []byte) (string, uint64, error)

ParseChainIdAndUintIdKey returns the chain ID and uint ID for a ChainIdAndUintId key

func ParseThrottledPacketDataKey added in v1.0.0

func ParseThrottledPacketDataKey(key []byte) (chainId string, ibcSeqNum uint64, err error)

ParseThrottledPacketDataKey parses a throttled packet data key

func ParseUnbondingOpIndexKey

func ParseUnbondingOpIndexKey(key []byte) (string, uint64, error)

ParseUnbondingOpIndexKey parses an unbonding op index key for VSC ID Removes the prefix + chainID from index key and returns only the key part.

func ParseVscSendingTimestampKey added in v0.2.0

func ParseVscSendingTimestampKey(bz []byte) (string, uint64, error)

ParseVscTimeoutTimestampKey returns chain ID and vsc ID for a VscSendingTimestampKey or an error if unparsable

func PendingCAPKey added in v0.2.0

func PendingCAPKey(timestamp time.Time, chainID string) []byte

PendingCAPKey returns the key under which a pending consumer addition proposal is stored. The key has the following format: PendingCAPBytePrefix | timestamp.UnixNano() | chainID

func PendingCRPKey added in v0.2.0

func PendingCRPKey(timestamp time.Time, chainID string) []byte

PendingCRPKey returns the key under which pending consumer removal proposals are stored. The key has the following format: PendingCRPBytePrefix | timestamp.UnixNano() | chainID

func PendingVSCsKey

func PendingVSCsKey(chainID string) []byte

PendingVSCsKey returns the key under which pending ValidatorSetChangePacket data is stored for a given chain ID

func PortKey

func PortKey() []byte

PortKey returns the key to the port ID in the store

func RegisterInterfaces

func RegisterInterfaces(registry codectypes.InterfaceRegistry)

RegisterInterfaces registers the provider proposal structs to the interface registry

func RegisterLegacyAminoCodec

func RegisterLegacyAminoCodec(cdc *codec.LegacyAmino)

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

func RegisterMsgServer added in v1.0.0

func RegisterMsgServer(s grpc1.Server, srv MsgServer)

func RegisterQueryHandler

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

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

func RegisterQueryHandlerClient

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

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

func RegisterQueryHandlerFromEndpoint

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

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

func RegisterQueryHandlerServer

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

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

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

func SlashAcksKey

func SlashAcksKey(chainID string) []byte

SlashAcksKey returns the key under which slashing acks are stored for a given chain ID

func SlashLogKey added in v1.0.0

func SlashLogKey(providerAddr ProviderConsAddress) []byte

SlashLogKey returns the key to a validator's slash log

func SlashMeterKey added in v1.0.0

func SlashMeterKey() []byte

SlashMeterKey returns the key storing the slash meter

func SlashMeterReplenishTimeCandidateKey added in v1.0.0

func SlashMeterReplenishTimeCandidateKey() []byte

SlashMeterReplenishTimeCandidateKey returns the key storing the slash meter replenish time candidate

func ThrottledPacketDataKey added in v1.0.0

func ThrottledPacketDataKey(consumerChainID string, ibcSeqNum uint64) []byte

ThrottledPacketDataKey returns the key storing the throttled packet data queue for a given chain ID and ibc seq num

func ThrottledPacketDataSizeKey added in v1.0.0

func ThrottledPacketDataSizeKey(consumerChainID string) []byte

ThrottledPacketDataSizeKey returns the key storing the size of the throttled packet data queue for a given chain ID

func UnbondingOpIndexKey

func UnbondingOpIndexKey(chainID string, vscID uint64) []byte

UnbondingOpIndexKey returns an unbonding op index key Note: chainId is hashed to a fixed length sequence of bytes here to prevent injection attack between chainIDs.

func UnbondingOpKey

func UnbondingOpKey(id uint64) []byte

UnbondingOpKey returns the key that stores a record of all the ids of consumer chains that need to unbond before a given unbonding operation can unbond on this chain.

func ValidatorSetUpdateIdKey

func ValidatorSetUpdateIdKey() []byte

ValidatorSetUpdateIdKey is the key that stores the current validator set update id

func ValidatorsByConsumerAddrKey added in v1.0.0

func ValidatorsByConsumerAddrKey(chainID string, addr ConsumerConsAddress) []byte

ValidatorsByConsumerAddrKey returns the key under which the mapping from validator addresses on consumer chains to validator addresses on the provider chain is stored

func ValsetUpdateBlockHeightKey

func ValsetUpdateBlockHeightKey(valsetUpdateId uint64) []byte

ValsetUpdateBlockHeightKey returns the key that storing the mapping from valset update ID to block height

func VscSendingTimestampKey added in v0.2.0

func VscSendingTimestampKey(chainID string, vscID uint64) []byte

VscSendingTimestampKey returns the key under which the sending timestamp of the VSCPacket with vsc ID is stored

Types

type Chain added in v0.2.0

type Chain struct {
	ChainId  string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	ClientId string `protobuf:"bytes,2,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"`
}

func (*Chain) Descriptor added in v0.2.0

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

func (*Chain) GetChainId added in v0.2.0

func (m *Chain) GetChainId() string

func (*Chain) GetClientId added in v0.2.0

func (m *Chain) GetClientId() string

func (*Chain) Marshal added in v0.2.0

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

func (*Chain) MarshalTo added in v0.2.0

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

func (*Chain) MarshalToSizedBuffer added in v0.2.0

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

func (*Chain) ProtoMessage added in v0.2.0

func (*Chain) ProtoMessage()

func (*Chain) Reset added in v0.2.0

func (m *Chain) Reset()

func (*Chain) Size added in v0.2.0

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

func (*Chain) String added in v0.2.0

func (m *Chain) String() string

func (*Chain) Unmarshal added in v0.2.0

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

func (*Chain) XXX_DiscardUnknown added in v0.2.0

func (m *Chain) XXX_DiscardUnknown()

func (*Chain) XXX_Marshal added in v0.2.0

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

func (*Chain) XXX_Merge added in v0.2.0

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

func (*Chain) XXX_Size added in v0.2.0

func (m *Chain) XXX_Size() int

func (*Chain) XXX_Unmarshal added in v0.2.0

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

type ChannelToChain added in v1.0.0

type ChannelToChain struct {
	ChannelId string `protobuf:"bytes,1,opt,name=channel_id,json=channelId,proto3" json:"channel_id,omitempty"`
	ChainId   string `protobuf:"bytes,2,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
}

func (*ChannelToChain) Descriptor added in v1.0.0

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

func (*ChannelToChain) GetChainId added in v1.0.0

func (m *ChannelToChain) GetChainId() string

func (*ChannelToChain) GetChannelId added in v1.0.0

func (m *ChannelToChain) GetChannelId() string

func (*ChannelToChain) Marshal added in v1.0.0

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

func (*ChannelToChain) MarshalTo added in v1.0.0

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

func (*ChannelToChain) MarshalToSizedBuffer added in v1.0.0

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

func (*ChannelToChain) ProtoMessage added in v1.0.0

func (*ChannelToChain) ProtoMessage()

func (*ChannelToChain) Reset added in v1.0.0

func (m *ChannelToChain) Reset()

func (*ChannelToChain) Size added in v1.0.0

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

func (*ChannelToChain) String added in v1.0.0

func (m *ChannelToChain) String() string

func (*ChannelToChain) Unmarshal added in v1.0.0

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

func (*ChannelToChain) XXX_DiscardUnknown added in v1.0.0

func (m *ChannelToChain) XXX_DiscardUnknown()

func (*ChannelToChain) XXX_Marshal added in v1.0.0

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

func (*ChannelToChain) XXX_Merge added in v1.0.0

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

func (*ChannelToChain) XXX_Size added in v1.0.0

func (m *ChannelToChain) XXX_Size() int

func (*ChannelToChain) XXX_Unmarshal added in v1.0.0

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

type ConsumerAdditionProposal added in v0.2.0

type ConsumerAdditionProposal struct {
	// the title of the proposal
	Title string `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	// the description of the proposal
	Description string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	// the proposed chain-id of the new consumer chain, must be different from all other consumer chain ids of the executing
	// provider chain.
	ChainId string `protobuf:"bytes,3,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// the proposed initial height of new consumer chain.
	// For a completely new chain, this will be {0,1}. However, it may be different if this is a chain that is converting to a consumer chain.
	InitialHeight types.Height `protobuf:"bytes,4,opt,name=initial_height,json=initialHeight,proto3" json:"initial_height"`
	// The hash of the consumer chain genesis state without the consumer CCV module genesis params.
	// It is used for off-chain confirmation of genesis.json validity by validators and other parties.
	GenesisHash []byte `protobuf:"bytes,5,opt,name=genesis_hash,json=genesisHash,proto3" json:"genesis_hash,omitempty"`
	// The hash of the consumer chain binary that should be run by validators on chain initialization.
	// It is used for off-chain confirmation of binary validity by validators and other parties.
	BinaryHash []byte `protobuf:"bytes,6,opt,name=binary_hash,json=binaryHash,proto3" json:"binary_hash,omitempty"`
	// spawn time is the time on the provider chain at which the consumer chain genesis is finalized and all validators
	// will be responsible for starting their consumer chain validator node.
	SpawnTime time.Time `protobuf:"bytes,7,opt,name=spawn_time,json=spawnTime,proto3,stdtime" json:"spawn_time"`
	// Unbonding period for the consumer,
	// which should be smaller than that of the provider in general.
	UnbondingPeriod time.Duration `protobuf:"bytes,8,opt,name=unbonding_period,json=unbondingPeriod,proto3,stdduration" json:"unbonding_period"`
	// Sent CCV related IBC packets will timeout after this duration
	CcvTimeoutPeriod time.Duration `protobuf:"bytes,9,opt,name=ccv_timeout_period,json=ccvTimeoutPeriod,proto3,stdduration" json:"ccv_timeout_period"`
	// Sent transfer related IBC packets will timeout after this duration
	TransferTimeoutPeriod time.Duration `` /* 129-byte string literal not displayed */
	// The fraction of tokens allocated to the consumer redistribution address
	// during distribution events. The fraction is a string representing a
	// decimal number. For example "0.75" would represent 75%.
	ConsumerRedistributionFraction string `` /* 154-byte string literal not displayed */
	// BlocksPerDistributionTransmission is the number of blocks between ibc-token-transfers from the consumer chain to the provider chain.
	// On sending transmission event, `consumer_redistribution_fraction` of the accumulated tokens are sent to the consumer redistribution address.
	BlocksPerDistributionTransmission int64 `` /* 166-byte string literal not displayed */
	// The number of historical info entries to persist in store.
	// This param is a part of the cosmos sdk staking module. In the case of
	// a ccv enabled consumer chain, the ccv module acts as the staking module.
	HistoricalEntries int64 `protobuf:"varint,13,opt,name=historical_entries,json=historicalEntries,proto3" json:"historical_entries,omitempty"`
}

ConsumerAdditionProposal is a governance proposal on the provider chain to spawn a new consumer chain. If it passes, then all validators on the provider chain are expected to validate the consumer chain at spawn time or get slashed. It is recommended that spawn time occurs after the proposal end time.

func (*ConsumerAdditionProposal) Descriptor added in v0.2.0

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

func (*ConsumerAdditionProposal) GetDescription added in v0.2.0

func (cccp *ConsumerAdditionProposal) GetDescription() string

GetDescription returns the description of a consumer addition proposal.

func (*ConsumerAdditionProposal) GetTitle added in v0.2.0

func (cccp *ConsumerAdditionProposal) GetTitle() string

GetTitle returns the title of a consumer addition proposal.

func (*ConsumerAdditionProposal) Marshal added in v0.2.0

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

func (*ConsumerAdditionProposal) MarshalTo added in v0.2.0

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

func (*ConsumerAdditionProposal) MarshalToSizedBuffer added in v0.2.0

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

func (*ConsumerAdditionProposal) ProposalRoute added in v0.2.0

func (cccp *ConsumerAdditionProposal) ProposalRoute() string

ProposalRoute returns the routing key of a consumer addition proposal.

func (*ConsumerAdditionProposal) ProposalType added in v0.2.0

func (cccp *ConsumerAdditionProposal) ProposalType() string

ProposalType returns the type of a consumer addition proposal.

func (*ConsumerAdditionProposal) ProtoMessage added in v0.2.0

func (*ConsumerAdditionProposal) ProtoMessage()

func (*ConsumerAdditionProposal) Reset added in v0.2.0

func (m *ConsumerAdditionProposal) Reset()

func (*ConsumerAdditionProposal) Size added in v0.2.0

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

func (*ConsumerAdditionProposal) String added in v0.2.0

func (cccp *ConsumerAdditionProposal) String() string

String returns the string representation of the ConsumerAdditionProposal.

func (*ConsumerAdditionProposal) Unmarshal added in v0.2.0

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

func (*ConsumerAdditionProposal) ValidateBasic added in v0.2.0

func (cccp *ConsumerAdditionProposal) ValidateBasic() error

ValidateBasic runs basic stateless validity checks

func (*ConsumerAdditionProposal) XXX_DiscardUnknown added in v0.2.0

func (m *ConsumerAdditionProposal) XXX_DiscardUnknown()

func (*ConsumerAdditionProposal) XXX_Marshal added in v0.2.0

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

func (*ConsumerAdditionProposal) XXX_Merge added in v0.2.0

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

func (*ConsumerAdditionProposal) XXX_Size added in v0.2.0

func (m *ConsumerAdditionProposal) XXX_Size() int

func (*ConsumerAdditionProposal) XXX_Unmarshal added in v0.2.0

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

type ConsumerAdditionProposals added in v0.2.0

type ConsumerAdditionProposals struct {
	// proposals waiting for spawn_time to pass
	Pending []*ConsumerAdditionProposal `protobuf:"bytes,1,rep,name=pending,proto3" json:"pending,omitempty"`
}

ConsumerAdditionProposals holds pending governance proposals on the provider chain to spawn a new chain.

func (*ConsumerAdditionProposals) Descriptor added in v0.2.0

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

func (*ConsumerAdditionProposals) GetPending added in v0.2.0

func (*ConsumerAdditionProposals) Marshal added in v0.2.0

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

func (*ConsumerAdditionProposals) MarshalTo added in v0.2.0

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

func (*ConsumerAdditionProposals) MarshalToSizedBuffer added in v0.2.0

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

func (*ConsumerAdditionProposals) ProtoMessage added in v0.2.0

func (*ConsumerAdditionProposals) ProtoMessage()

func (*ConsumerAdditionProposals) Reset added in v0.2.0

func (m *ConsumerAdditionProposals) Reset()

func (*ConsumerAdditionProposals) Size added in v0.2.0

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

func (*ConsumerAdditionProposals) String added in v0.2.0

func (m *ConsumerAdditionProposals) String() string

func (*ConsumerAdditionProposals) Unmarshal added in v0.2.0

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

func (*ConsumerAdditionProposals) XXX_DiscardUnknown added in v0.2.0

func (m *ConsumerAdditionProposals) XXX_DiscardUnknown()

func (*ConsumerAdditionProposals) XXX_Marshal added in v0.2.0

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

func (*ConsumerAdditionProposals) XXX_Merge added in v0.2.0

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

func (*ConsumerAdditionProposals) XXX_Size added in v0.2.0

func (m *ConsumerAdditionProposals) XXX_Size() int

func (*ConsumerAdditionProposals) XXX_Unmarshal added in v0.2.0

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

type ConsumerAddressList added in v1.1.1

type ConsumerAddressList struct {
	Addresses []*ConsumerConsAddress `protobuf:"bytes,1,rep,name=addresses,proto3" json:"addresses,omitempty"`
}

ConsumerAddressList contains a list of consumer consensus addresses

func (*ConsumerAddressList) Descriptor added in v1.1.1

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

func (*ConsumerAddressList) GetAddresses added in v1.1.1

func (m *ConsumerAddressList) GetAddresses() []*ConsumerConsAddress

func (*ConsumerAddressList) Marshal added in v1.1.1

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

func (*ConsumerAddressList) MarshalTo added in v1.1.1

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

func (*ConsumerAddressList) MarshalToSizedBuffer added in v1.1.1

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

func (*ConsumerAddressList) ProtoMessage added in v1.1.1

func (*ConsumerAddressList) ProtoMessage()

func (*ConsumerAddressList) Reset added in v1.1.1

func (m *ConsumerAddressList) Reset()

func (*ConsumerAddressList) Size added in v1.1.1

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

func (*ConsumerAddressList) String added in v1.1.1

func (m *ConsumerAddressList) String() string

func (*ConsumerAddressList) Unmarshal added in v1.1.1

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

func (*ConsumerAddressList) XXX_DiscardUnknown added in v1.1.1

func (m *ConsumerAddressList) XXX_DiscardUnknown()

func (*ConsumerAddressList) XXX_Marshal added in v1.1.1

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

func (*ConsumerAddressList) XXX_Merge added in v1.1.1

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

func (*ConsumerAddressList) XXX_Size added in v1.1.1

func (m *ConsumerAddressList) XXX_Size() int

func (*ConsumerAddressList) XXX_Unmarshal added in v1.1.1

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

type ConsumerAddrsToPrune added in v1.0.0

type ConsumerAddrsToPrune struct {
	ChainId       string               `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	VscId         uint64               `protobuf:"varint,2,opt,name=vsc_id,json=vscId,proto3" json:"vsc_id,omitempty"`
	ConsumerAddrs *ConsumerAddressList `protobuf:"bytes,3,opt,name=consumer_addrs,json=consumerAddrs,proto3" json:"consumer_addrs,omitempty"`
}

Used to serialize the ConsumerAddrsToPrune index from key assignment ConsumerAddrsToPrune: (chainID, vscID uint64) -> consumerAddrs AddressList

func (*ConsumerAddrsToPrune) Descriptor added in v1.0.0

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

func (*ConsumerAddrsToPrune) GetChainId added in v1.0.0

func (m *ConsumerAddrsToPrune) GetChainId() string

func (*ConsumerAddrsToPrune) GetConsumerAddrs added in v1.0.0

func (m *ConsumerAddrsToPrune) GetConsumerAddrs() *ConsumerAddressList

func (*ConsumerAddrsToPrune) GetVscId added in v1.0.0

func (m *ConsumerAddrsToPrune) GetVscId() uint64

func (*ConsumerAddrsToPrune) Marshal added in v1.0.0

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

func (*ConsumerAddrsToPrune) MarshalTo added in v1.0.0

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

func (*ConsumerAddrsToPrune) MarshalToSizedBuffer added in v1.0.0

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

func (*ConsumerAddrsToPrune) ProtoMessage added in v1.0.0

func (*ConsumerAddrsToPrune) ProtoMessage()

func (*ConsumerAddrsToPrune) Reset added in v1.0.0

func (m *ConsumerAddrsToPrune) Reset()

func (*ConsumerAddrsToPrune) Size added in v1.0.0

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

func (*ConsumerAddrsToPrune) String added in v1.0.0

func (m *ConsumerAddrsToPrune) String() string

func (*ConsumerAddrsToPrune) Unmarshal added in v1.0.0

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

func (*ConsumerAddrsToPrune) XXX_DiscardUnknown added in v1.0.0

func (m *ConsumerAddrsToPrune) XXX_DiscardUnknown()

func (*ConsumerAddrsToPrune) XXX_Marshal added in v1.0.0

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

func (*ConsumerAddrsToPrune) XXX_Merge added in v1.0.0

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

func (*ConsumerAddrsToPrune) XXX_Size added in v1.0.0

func (m *ConsumerAddrsToPrune) XXX_Size() int

func (*ConsumerAddrsToPrune) XXX_Unmarshal added in v1.0.0

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

type ConsumerConsAddress added in v1.1.1

type ConsumerConsAddress struct {
	Address []byte `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"`
}

A validator's assigned consensus address for a consumer chain. Note this type is for type safety within provider code, consumer code uses normal sdk.ConsAddress, since there's no notion of provider vs consumer address.

func NewConsumerConsAddress added in v1.1.1

func NewConsumerConsAddress(addr sdk.ConsAddress) ConsumerConsAddress

NewConsumerConsAddress creates a new ConsumerConsAddress, a validator's assigned consensus address for a consumer chain. Note this type is for type safety within provider code, consumer code uses normal sdk.ConsAddress, since there's no notion of provider vs consumer address.

func (*ConsumerConsAddress) Descriptor added in v1.1.1

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

func (*ConsumerConsAddress) GetAddress added in v1.1.1

func (m *ConsumerConsAddress) GetAddress() []byte

func (*ConsumerConsAddress) Marshal added in v1.1.1

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

func (*ConsumerConsAddress) MarshalTo added in v1.1.1

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

func (*ConsumerConsAddress) MarshalToSizedBuffer added in v1.1.1

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

func (*ConsumerConsAddress) ProtoMessage added in v1.1.1

func (*ConsumerConsAddress) ProtoMessage()

func (*ConsumerConsAddress) Reset added in v1.1.1

func (m *ConsumerConsAddress) Reset()

func (*ConsumerConsAddress) Size added in v1.1.1

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

func (*ConsumerConsAddress) String added in v1.1.1

func (c *ConsumerConsAddress) String() string

String implements the Stringer interface for ConsumerConsAddress, in the same format as sdk.ConsAddress

func (*ConsumerConsAddress) ToSdkConsAddr added in v1.1.1

func (c *ConsumerConsAddress) ToSdkConsAddr() sdk.ConsAddress

func (*ConsumerConsAddress) Unmarshal added in v1.1.1

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

func (*ConsumerConsAddress) XXX_DiscardUnknown added in v1.1.1

func (m *ConsumerConsAddress) XXX_DiscardUnknown()

func (*ConsumerConsAddress) XXX_Marshal added in v1.1.1

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

func (*ConsumerConsAddress) XXX_Merge added in v1.1.1

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

func (*ConsumerConsAddress) XXX_Size added in v1.1.1

func (m *ConsumerConsAddress) XXX_Size() int

func (*ConsumerConsAddress) XXX_Unmarshal added in v1.1.1

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

type ConsumerRemovalProposal added in v0.2.0

type ConsumerRemovalProposal struct {
	// the title of the proposal
	Title string `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	// the description of the proposal
	Description string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	// the chain-id of the consumer chain to be stopped
	ChainId string `protobuf:"bytes,3,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// the time on the provider chain at which all validators are responsible to stop their consumer chain validator node
	StopTime time.Time `protobuf:"bytes,4,opt,name=stop_time,json=stopTime,proto3,stdtime" json:"stop_time"`
}

ConsumerRemovalProposal is a governance proposal on the provider chain to remove (and stop) a consumer chain. If it passes, all the consumer chain's state is removed from the provider chain. The outstanding unbonding operation funds are released.

func (*ConsumerRemovalProposal) Descriptor added in v0.2.0

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

func (*ConsumerRemovalProposal) GetChainId added in v0.2.0

func (m *ConsumerRemovalProposal) GetChainId() string

func (*ConsumerRemovalProposal) GetDescription added in v0.2.0

func (m *ConsumerRemovalProposal) GetDescription() string

func (*ConsumerRemovalProposal) GetStopTime added in v0.2.0

func (m *ConsumerRemovalProposal) GetStopTime() time.Time

func (*ConsumerRemovalProposal) GetTitle added in v0.2.0

func (m *ConsumerRemovalProposal) GetTitle() string

func (*ConsumerRemovalProposal) Marshal added in v0.2.0

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

func (*ConsumerRemovalProposal) MarshalTo added in v0.2.0

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

func (*ConsumerRemovalProposal) MarshalToSizedBuffer added in v0.2.0

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

func (*ConsumerRemovalProposal) ProposalRoute added in v0.2.0

func (sccp *ConsumerRemovalProposal) ProposalRoute() string

ProposalRoute returns the routing key of a consumer removal proposal.

func (*ConsumerRemovalProposal) ProposalType added in v0.2.0

func (sccp *ConsumerRemovalProposal) ProposalType() string

ProposalType returns the type of a consumer removal proposal.

func (*ConsumerRemovalProposal) ProtoMessage added in v0.2.0

func (*ConsumerRemovalProposal) ProtoMessage()

func (*ConsumerRemovalProposal) Reset added in v0.2.0

func (m *ConsumerRemovalProposal) Reset()

func (*ConsumerRemovalProposal) Size added in v0.2.0

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

func (*ConsumerRemovalProposal) String added in v0.2.0

func (m *ConsumerRemovalProposal) String() string

func (*ConsumerRemovalProposal) Unmarshal added in v0.2.0

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

func (*ConsumerRemovalProposal) ValidateBasic added in v0.2.0

func (sccp *ConsumerRemovalProposal) ValidateBasic() error

ValidateBasic runs basic stateless validity checks

func (*ConsumerRemovalProposal) XXX_DiscardUnknown added in v0.2.0

func (m *ConsumerRemovalProposal) XXX_DiscardUnknown()

func (*ConsumerRemovalProposal) XXX_Marshal added in v0.2.0

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

func (*ConsumerRemovalProposal) XXX_Merge added in v0.2.0

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

func (*ConsumerRemovalProposal) XXX_Size added in v0.2.0

func (m *ConsumerRemovalProposal) XXX_Size() int

func (*ConsumerRemovalProposal) XXX_Unmarshal added in v0.2.0

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

type ConsumerRemovalProposals added in v0.2.0

type ConsumerRemovalProposals struct {
	// proposals waiting for stop_time to pass
	Pending []*ConsumerRemovalProposal `protobuf:"bytes,1,rep,name=pending,proto3" json:"pending,omitempty"`
}

ConsumerRemovalProposals holds pending governance proposals on the provider chain to remove (and stop) a consumer chain.

func (*ConsumerRemovalProposals) Descriptor added in v0.2.0

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

func (*ConsumerRemovalProposals) GetPending added in v0.2.0

func (*ConsumerRemovalProposals) Marshal added in v0.2.0

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

func (*ConsumerRemovalProposals) MarshalTo added in v0.2.0

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

func (*ConsumerRemovalProposals) MarshalToSizedBuffer added in v0.2.0

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

func (*ConsumerRemovalProposals) ProtoMessage added in v0.2.0

func (*ConsumerRemovalProposals) ProtoMessage()

func (*ConsumerRemovalProposals) Reset added in v0.2.0

func (m *ConsumerRemovalProposals) Reset()

func (*ConsumerRemovalProposals) Size added in v0.2.0

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

func (*ConsumerRemovalProposals) String added in v0.2.0

func (m *ConsumerRemovalProposals) String() string

func (*ConsumerRemovalProposals) Unmarshal added in v0.2.0

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

func (*ConsumerRemovalProposals) XXX_DiscardUnknown added in v0.2.0

func (m *ConsumerRemovalProposals) XXX_DiscardUnknown()

func (*ConsumerRemovalProposals) XXX_Marshal added in v0.2.0

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

func (*ConsumerRemovalProposals) XXX_Merge added in v0.2.0

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

func (*ConsumerRemovalProposals) XXX_Size added in v0.2.0

func (m *ConsumerRemovalProposals) XXX_Size() int

func (*ConsumerRemovalProposals) XXX_Unmarshal added in v0.2.0

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

type ConsumerState

type ConsumerState struct {
	// ChainID defines the chain ID for the consumer chain
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// ChannelID defines the IBC channel ID for the consumer chain
	ChannelId string `protobuf:"bytes,2,opt,name=channel_id,json=channelId,proto3" json:"channel_id,omitempty"`
	// ClientID defines the IBC client ID for the consumer chain
	ClientId string `protobuf:"bytes,3,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"`
	// InitalHeight defines the initial block height for the consumer chain
	InitialHeight uint64 `protobuf:"varint,4,opt,name=initial_height,json=initialHeight,proto3" json:"initial_height,omitempty"`
	// ConsumerGenesis defines the initial consumer chain genesis states
	ConsumerGenesis types1.GenesisState `protobuf:"bytes,5,opt,name=consumer_genesis,json=consumerGenesis,proto3" json:"consumer_genesis"`
	// PendingValsetChanges defines the pending validator set changes for the consumer chain
	PendingValsetChanges []types.ValidatorSetChangePacketData `protobuf:"bytes,6,rep,name=pending_valset_changes,json=pendingValsetChanges,proto3" json:"pending_valset_changes"`
	SlashDowntimeAck     []string                             `protobuf:"bytes,7,rep,name=slash_downtime_ack,json=slashDowntimeAck,proto3" json:"slash_downtime_ack,omitempty"`
	// UnbondingOpsIndex defines the unbonding operations waiting on this consumer chain
	UnbondingOpsIndex []VscUnbondingOps `protobuf:"bytes,8,rep,name=unbonding_ops_index,json=unbondingOpsIndex,proto3" json:"unbonding_ops_index"`
}

consumer chain

func NewConsumerStates added in v0.2.0

func NewConsumerStates(
	chainID,
	clientID,
	channelID string,
	initialHeight uint64,
	genesis consumertypes.GenesisState,
	unbondingOpsIndexes []VscUnbondingOps,
	pendingValsetChanges []ccv.ValidatorSetChangePacketData,
	slashDowntimeAck []string,
) ConsumerState

func (*ConsumerState) Descriptor

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

func (*ConsumerState) GetChainId

func (m *ConsumerState) GetChainId() string

func (*ConsumerState) GetChannelId

func (m *ConsumerState) GetChannelId() string

func (*ConsumerState) GetClientId added in v0.2.0

func (m *ConsumerState) GetClientId() string

func (*ConsumerState) GetConsumerGenesis added in v0.2.0

func (m *ConsumerState) GetConsumerGenesis() types1.GenesisState

func (*ConsumerState) GetInitialHeight added in v0.2.0

func (m *ConsumerState) GetInitialHeight() uint64

func (*ConsumerState) GetPendingValsetChanges added in v0.2.0

func (m *ConsumerState) GetPendingValsetChanges() []types.ValidatorSetChangePacketData

func (*ConsumerState) GetSlashDowntimeAck added in v0.2.0

func (m *ConsumerState) GetSlashDowntimeAck() []string

func (*ConsumerState) GetUnbondingOpsIndex added in v0.2.0

func (m *ConsumerState) GetUnbondingOpsIndex() []VscUnbondingOps

func (*ConsumerState) Marshal

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

func (*ConsumerState) MarshalTo

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

func (*ConsumerState) MarshalToSizedBuffer

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

func (*ConsumerState) ProtoMessage

func (*ConsumerState) ProtoMessage()

func (*ConsumerState) Reset

func (m *ConsumerState) Reset()

func (*ConsumerState) Size

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

func (*ConsumerState) String

func (m *ConsumerState) String() string

func (*ConsumerState) Unmarshal

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

func (ConsumerState) Validate

func (cs ConsumerState) Validate() error

Validate performs a consumer state validation returning an error upon any failure. It ensures that the chain id, client id and consumer genesis states are valid and non-empty.

func (*ConsumerState) XXX_DiscardUnknown

func (m *ConsumerState) XXX_DiscardUnknown()

func (*ConsumerState) XXX_Marshal

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

func (*ConsumerState) XXX_Merge

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

func (*ConsumerState) XXX_Size

func (m *ConsumerState) XXX_Size() int

func (*ConsumerState) XXX_Unmarshal

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

type EquivocationProposal added in v1.0.0

type EquivocationProposal struct {
	// the title of the proposal
	Title string `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	// the description of the proposal
	Description string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	// the list of equivocations that will be processed
	Equivocations []*types1.Equivocation `protobuf:"bytes,3,rep,name=equivocations,proto3" json:"equivocations,omitempty"`
}

func (*EquivocationProposal) Descriptor added in v1.0.0

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

func (*EquivocationProposal) GetDescription added in v1.0.0

func (m *EquivocationProposal) GetDescription() string

func (*EquivocationProposal) GetEquivocations added in v1.0.0

func (m *EquivocationProposal) GetEquivocations() []*types1.Equivocation

func (*EquivocationProposal) GetTitle added in v1.0.0

func (m *EquivocationProposal) GetTitle() string

func (*EquivocationProposal) Marshal added in v1.0.0

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

func (*EquivocationProposal) MarshalTo added in v1.0.0

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

func (*EquivocationProposal) MarshalToSizedBuffer added in v1.0.0

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

func (*EquivocationProposal) ProposalRoute added in v1.0.0

func (sp *EquivocationProposal) ProposalRoute() string

ProposalRoute returns the routing key of an equivocation proposal.

func (*EquivocationProposal) ProposalType added in v1.0.0

func (sp *EquivocationProposal) ProposalType() string

ProposalType returns the type of a equivocation proposal.

func (*EquivocationProposal) ProtoMessage added in v1.0.0

func (*EquivocationProposal) ProtoMessage()

func (*EquivocationProposal) Reset added in v1.0.0

func (m *EquivocationProposal) Reset()

func (*EquivocationProposal) Size added in v1.0.0

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

func (*EquivocationProposal) String added in v1.0.0

func (m *EquivocationProposal) String() string

func (*EquivocationProposal) Unmarshal added in v1.0.0

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

func (*EquivocationProposal) ValidateBasic added in v1.0.0

func (sp *EquivocationProposal) ValidateBasic() error

ValidateBasic runs basic stateless validity checks

func (*EquivocationProposal) XXX_DiscardUnknown added in v1.0.0

func (m *EquivocationProposal) XXX_DiscardUnknown()

func (*EquivocationProposal) XXX_Marshal added in v1.0.0

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

func (*EquivocationProposal) XXX_Merge added in v1.0.0

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

func (*EquivocationProposal) XXX_Size added in v1.0.0

func (m *EquivocationProposal) XXX_Size() int

func (*EquivocationProposal) XXX_Unmarshal added in v1.0.0

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

type GenesisState

type GenesisState struct {
	// strictly positive and set to 1 (DefaultValsetUpdateID) for a new chain
	ValsetUpdateId uint64 `protobuf:"varint,1,opt,name=valset_update_id,json=valsetUpdateId,proto3" json:"valset_update_id,omitempty"`
	// empty for a new chain
	ConsumerStates []ConsumerState `protobuf:"bytes,2,rep,name=consumer_states,json=consumerStates,proto3" json:"consumer_states" yaml:"consumer_states"`
	// empty for a new chain
	UnbondingOps []UnbondingOp `protobuf:"bytes,3,rep,name=unbonding_ops,json=unbondingOps,proto3" json:"unbonding_ops"`
	// empty for a new chain
	MatureUnbondingOps *types.MaturedUnbondingOps `protobuf:"bytes,4,opt,name=mature_unbonding_ops,json=matureUnbondingOps,proto3" json:"mature_unbonding_ops,omitempty"`
	// empty for a new chain
	ValsetUpdateIdToHeight []ValsetUpdateIdToHeight `protobuf:"bytes,5,rep,name=valset_update_id_to_height,json=valsetUpdateIdToHeight,proto3" json:"valset_update_id_to_height"`
	// empty for a new chain
	ConsumerAdditionProposals []ConsumerAdditionProposal `` /* 128-byte string literal not displayed */
	// empty for a new chain
	ConsumerRemovalProposals []ConsumerRemovalProposal `protobuf:"bytes,7,rep,name=consumer_removal_proposals,json=consumerRemovalProposals,proto3" json:"consumer_removal_proposals"`
	Params                   Params                    `protobuf:"bytes,8,opt,name=params,proto3" json:"params"`
	// empty for a new chain
	ValidatorConsumerPubkeys []ValidatorConsumerPubKey `protobuf:"bytes,9,rep,name=validator_consumer_pubkeys,json=validatorConsumerPubkeys,proto3" json:"validator_consumer_pubkeys"`
	// empty for a new chain
	ValidatorsByConsumerAddr []ValidatorByConsumerAddr `` /* 128-byte string literal not displayed */
	// empty for a new chain
	ConsumerAddrsToPrune []ConsumerAddrsToPrune `protobuf:"bytes,11,rep,name=consumer_addrs_to_prune,json=consumerAddrsToPrune,proto3" json:"consumer_addrs_to_prune"`
}

GenesisState defines the CCV provider chain genesis state

func DefaultGenesisState

func DefaultGenesisState() *GenesisState

func NewGenesisState

func NewGenesisState(
	vscID uint64,
	vscIdToHeights []ValsetUpdateIdToHeight,
	consumerStates []ConsumerState,
	unbondingOps []UnbondingOp,
	matureUbdOps *ccv.MaturedUnbondingOps,
	additionProposals []ConsumerAdditionProposal,
	removalProposals []ConsumerRemovalProposal,
	params Params,
	validatorConsumerPubkeys []ValidatorConsumerPubKey,
	validatorsByConsumerAddr []ValidatorByConsumerAddr,
	consumerAddrsToPrune []ConsumerAddrsToPrune,
) *GenesisState

func (*GenesisState) Descriptor

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

func (*GenesisState) GetConsumerAdditionProposals added in v0.2.0

func (m *GenesisState) GetConsumerAdditionProposals() []ConsumerAdditionProposal

func (*GenesisState) GetConsumerAddrsToPrune added in v1.0.0

func (m *GenesisState) GetConsumerAddrsToPrune() []ConsumerAddrsToPrune

func (*GenesisState) GetConsumerRemovalProposals added in v0.2.0

func (m *GenesisState) GetConsumerRemovalProposals() []ConsumerRemovalProposal

func (*GenesisState) GetConsumerStates

func (m *GenesisState) GetConsumerStates() []ConsumerState

func (*GenesisState) GetMatureUnbondingOps added in v0.2.0

func (m *GenesisState) GetMatureUnbondingOps() *types.MaturedUnbondingOps

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() Params

func (*GenesisState) GetUnbondingOps added in v0.2.0

func (m *GenesisState) GetUnbondingOps() []UnbondingOp

func (*GenesisState) GetValidatorConsumerPubkeys added in v1.0.0

func (m *GenesisState) GetValidatorConsumerPubkeys() []ValidatorConsumerPubKey

func (*GenesisState) GetValidatorsByConsumerAddr added in v1.0.0

func (m *GenesisState) GetValidatorsByConsumerAddr() []ValidatorByConsumerAddr

func (*GenesisState) GetValsetUpdateId added in v0.2.0

func (m *GenesisState) GetValsetUpdateId() uint64

func (*GenesisState) GetValsetUpdateIdToHeight added in v0.2.0

func (m *GenesisState) GetValsetUpdateIdToHeight() []ValsetUpdateIdToHeight

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

func (GenesisState) ValidateUnbondingOp added in v1.0.0

func (gs GenesisState) ValidateUnbondingOp(ubdOp UnbondingOp) error

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 GlobalSlashEntry added in v1.0.0

type GlobalSlashEntry struct {
	// Block time that slash packet was received by provider chain.
	// This field is used for store key iteration ordering.
	RecvTime time.Time `protobuf:"bytes,1,opt,name=recv_time,json=recvTime,proto3,stdtime" json:"recv_time"`
	// The consumer that sent a slash packet.
	ConsumerChainID string `protobuf:"bytes,2,opt,name=consumer_chain_id,json=consumerChainId,proto3" json:"consumer_chain_id,omitempty"`
	// The IBC sequence number of the recv packet.
	// This field is used in the store key to ensure uniqueness.
	IbcSeqNum uint64 `protobuf:"varint,3,opt,name=ibc_seq_num,json=ibcSeqNum,proto3" json:"ibc_seq_num,omitempty"`
	// The provider's consensus address of the validator being slashed.
	// This field is used to obtain validator power in HandleThrottleQueues.
	//
	// This field is not used in the store key, but is persisted in value bytes, see QueueGlobalSlashEntry.
	ProviderValConsAddr *ProviderConsAddress `protobuf:"bytes,4,opt,name=provider_val_cons_addr,json=providerValConsAddr,proto3" json:"provider_val_cons_addr,omitempty"`
}

A persisted queue entry indicating that a slash packet data instance needs to be handled. This type belongs in the "global" queue, to coordinate slash packet handling times between consumers.

func NewGlobalSlashEntry added in v1.0.0

func NewGlobalSlashEntry(recvTime time.Time, consumerChainID string,
	ibcSeqNum uint64, providerValConsAddr ProviderConsAddress) GlobalSlashEntry

NewGlobalSlashEntry creates a new GlobalSlashEntry.

func (*GlobalSlashEntry) Descriptor added in v1.0.0

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

func (*GlobalSlashEntry) GetConsumerChainID added in v1.0.0

func (m *GlobalSlashEntry) GetConsumerChainID() string

func (*GlobalSlashEntry) GetIbcSeqNum added in v1.0.0

func (m *GlobalSlashEntry) GetIbcSeqNum() uint64

func (*GlobalSlashEntry) GetProviderValConsAddr added in v1.0.0

func (m *GlobalSlashEntry) GetProviderValConsAddr() *ProviderConsAddress

func (*GlobalSlashEntry) GetRecvTime added in v1.0.0

func (m *GlobalSlashEntry) GetRecvTime() time.Time

func (*GlobalSlashEntry) Marshal added in v1.0.0

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

func (*GlobalSlashEntry) MarshalTo added in v1.0.0

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

func (*GlobalSlashEntry) MarshalToSizedBuffer added in v1.0.0

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

func (*GlobalSlashEntry) ProtoMessage added in v1.0.0

func (*GlobalSlashEntry) ProtoMessage()

func (*GlobalSlashEntry) Reset added in v1.0.0

func (m *GlobalSlashEntry) Reset()

func (*GlobalSlashEntry) Size added in v1.0.0

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

func (*GlobalSlashEntry) String added in v1.0.0

func (m *GlobalSlashEntry) String() string

func (*GlobalSlashEntry) Unmarshal added in v1.0.0

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

func (*GlobalSlashEntry) XXX_DiscardUnknown added in v1.0.0

func (m *GlobalSlashEntry) XXX_DiscardUnknown()

func (*GlobalSlashEntry) XXX_Marshal added in v1.0.0

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

func (*GlobalSlashEntry) XXX_Merge added in v1.0.0

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

func (*GlobalSlashEntry) XXX_Size added in v1.0.0

func (m *GlobalSlashEntry) XXX_Size() int

func (*GlobalSlashEntry) XXX_Unmarshal added in v1.0.0

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

type HandshakeMetadata

type HandshakeMetadata struct {
	ProviderFeePoolAddr string `protobuf:"bytes,1,opt,name=provider_fee_pool_addr,json=providerFeePoolAddr,proto3" json:"provider_fee_pool_addr,omitempty"`
	Version             string `protobuf:"bytes,2,opt,name=version,proto3" json:"version,omitempty"`
}

func (*HandshakeMetadata) Descriptor

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

func (*HandshakeMetadata) GetProviderFeePoolAddr

func (m *HandshakeMetadata) GetProviderFeePoolAddr() string

func (*HandshakeMetadata) GetVersion

func (m *HandshakeMetadata) GetVersion() string

func (*HandshakeMetadata) Marshal

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

func (*HandshakeMetadata) MarshalTo

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

func (*HandshakeMetadata) MarshalToSizedBuffer

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

func (*HandshakeMetadata) ProtoMessage

func (*HandshakeMetadata) ProtoMessage()

func (*HandshakeMetadata) Reset

func (m *HandshakeMetadata) Reset()

func (*HandshakeMetadata) Size

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

func (*HandshakeMetadata) String

func (m *HandshakeMetadata) String() string

func (*HandshakeMetadata) Unmarshal

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

func (*HandshakeMetadata) XXX_DiscardUnknown

func (m *HandshakeMetadata) XXX_DiscardUnknown()

func (*HandshakeMetadata) XXX_Marshal

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

func (*HandshakeMetadata) XXX_Merge

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

func (*HandshakeMetadata) XXX_Size

func (m *HandshakeMetadata) XXX_Size() int

func (*HandshakeMetadata) XXX_Unmarshal

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

type InitTimeoutTimestamp added in v1.0.0

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

func (*InitTimeoutTimestamp) Descriptor added in v1.0.0

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

func (*InitTimeoutTimestamp) GetChainId added in v1.0.0

func (m *InitTimeoutTimestamp) GetChainId() string

func (*InitTimeoutTimestamp) GetTimestamp added in v1.0.0

func (m *InitTimeoutTimestamp) GetTimestamp() uint64

func (*InitTimeoutTimestamp) Marshal added in v1.0.0

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

func (*InitTimeoutTimestamp) MarshalTo added in v1.0.0

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

func (*InitTimeoutTimestamp) MarshalToSizedBuffer added in v1.0.0

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

func (*InitTimeoutTimestamp) ProtoMessage added in v1.0.0

func (*InitTimeoutTimestamp) ProtoMessage()

func (*InitTimeoutTimestamp) Reset added in v1.0.0

func (m *InitTimeoutTimestamp) Reset()

func (*InitTimeoutTimestamp) Size added in v1.0.0

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

func (*InitTimeoutTimestamp) String added in v1.0.0

func (m *InitTimeoutTimestamp) String() string

func (*InitTimeoutTimestamp) Unmarshal added in v1.0.0

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

func (*InitTimeoutTimestamp) XXX_DiscardUnknown added in v1.0.0

func (m *InitTimeoutTimestamp) XXX_DiscardUnknown()

func (*InitTimeoutTimestamp) XXX_Marshal added in v1.0.0

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

func (*InitTimeoutTimestamp) XXX_Merge added in v1.0.0

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

func (*InitTimeoutTimestamp) XXX_Size added in v1.0.0

func (m *InitTimeoutTimestamp) XXX_Size() int

func (*InitTimeoutTimestamp) XXX_Unmarshal added in v1.0.0

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

type KeyAssignmentReplacement added in v1.0.0

type KeyAssignmentReplacement struct {
	ProviderAddr *ProviderConsAddress `protobuf:"bytes,1,opt,name=provider_addr,json=providerAddr,proto3" json:"provider_addr,omitempty"`
	PrevCKey     *crypto.PublicKey    `protobuf:"bytes,2,opt,name=prev_c_key,json=prevCKey,proto3" json:"prev_c_key,omitempty"`
	Power        int64                `protobuf:"varint,3,opt,name=power,proto3" json:"power,omitempty"`
}

func (*KeyAssignmentReplacement) Descriptor added in v1.0.0

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

func (*KeyAssignmentReplacement) GetPower added in v1.0.0

func (m *KeyAssignmentReplacement) GetPower() int64

func (*KeyAssignmentReplacement) GetPrevCKey added in v1.0.0

func (m *KeyAssignmentReplacement) GetPrevCKey() *crypto.PublicKey

func (*KeyAssignmentReplacement) GetProviderAddr added in v1.0.0

func (m *KeyAssignmentReplacement) GetProviderAddr() *ProviderConsAddress

func (*KeyAssignmentReplacement) Marshal added in v1.0.0

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

func (*KeyAssignmentReplacement) MarshalTo added in v1.0.0

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

func (*KeyAssignmentReplacement) MarshalToSizedBuffer added in v1.0.0

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

func (*KeyAssignmentReplacement) ProtoMessage added in v1.0.0

func (*KeyAssignmentReplacement) ProtoMessage()

func (*KeyAssignmentReplacement) Reset added in v1.0.0

func (m *KeyAssignmentReplacement) Reset()

func (*KeyAssignmentReplacement) Size added in v1.0.0

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

func (*KeyAssignmentReplacement) String added in v1.0.0

func (m *KeyAssignmentReplacement) String() string

func (*KeyAssignmentReplacement) Unmarshal added in v1.0.0

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

func (*KeyAssignmentReplacement) XXX_DiscardUnknown added in v1.0.0

func (m *KeyAssignmentReplacement) XXX_DiscardUnknown()

func (*KeyAssignmentReplacement) XXX_Marshal added in v1.0.0

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

func (*KeyAssignmentReplacement) XXX_Merge added in v1.0.0

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

func (*KeyAssignmentReplacement) XXX_Size added in v1.0.0

func (m *KeyAssignmentReplacement) XXX_Size() int

func (*KeyAssignmentReplacement) XXX_Unmarshal added in v1.0.0

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

type MsgAssignConsumerKey added in v1.0.0

type MsgAssignConsumerKey struct {
	// The chain id of the consumer chain to assign a consensus public key to
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// The validator address on the provider
	ProviderAddr string `protobuf:"bytes,2,opt,name=provider_addr,json=providerAddr,proto3" json:"provider_addr,omitempty" yaml:"address"`
	// The consensus public key to use on the consumer
	ConsumerKey *types.Any `protobuf:"bytes,3,opt,name=consumer_key,json=consumerKey,proto3" json:"consumer_key,omitempty"`
}

func NewMsgAssignConsumerKey added in v1.0.0

func NewMsgAssignConsumerKey(chainID string, providerValidatorAddress sdk.ValAddress,
	consumerConsensusPubKey cryptotypes.PubKey) (*MsgAssignConsumerKey, error)

NewMsgAssignConsumerKey creates a new MsgAssignConsumerKey instance. Delegator address and validator address are the same.

func (*MsgAssignConsumerKey) Descriptor added in v1.0.0

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

func (MsgAssignConsumerKey) GetSignBytes added in v1.0.0

func (msg MsgAssignConsumerKey) GetSignBytes() []byte

GetSignBytes returns the message bytes to sign over.

func (MsgAssignConsumerKey) GetSigners added in v1.0.0

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

GetSigners implements the sdk.Msg interface. It returns the address(es) that must sign over msg.GetSignBytes(). If the validator address is not same as delegator's, then the validator must sign the msg as well.

func (*MsgAssignConsumerKey) Marshal added in v1.0.0

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

func (*MsgAssignConsumerKey) MarshalTo added in v1.0.0

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

func (*MsgAssignConsumerKey) MarshalToSizedBuffer added in v1.0.0

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

func (*MsgAssignConsumerKey) ProtoMessage added in v1.0.0

func (*MsgAssignConsumerKey) ProtoMessage()

func (*MsgAssignConsumerKey) Reset added in v1.0.0

func (m *MsgAssignConsumerKey) Reset()

func (MsgAssignConsumerKey) Route added in v1.0.0

func (msg MsgAssignConsumerKey) Route() string

Route implements the sdk.Msg interface.

func (*MsgAssignConsumerKey) Size added in v1.0.0

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

func (*MsgAssignConsumerKey) String added in v1.0.0

func (m *MsgAssignConsumerKey) String() string

func (MsgAssignConsumerKey) Type added in v1.0.0

func (msg MsgAssignConsumerKey) Type() string

Type implements the sdk.Msg interface.

func (*MsgAssignConsumerKey) Unmarshal added in v1.0.0

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

func (MsgAssignConsumerKey) UnpackInterfaces added in v1.0.0

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

UnpackInterfaces implements UnpackInterfacesMessage.UnpackInterfaces

func (MsgAssignConsumerKey) ValidateBasic added in v1.0.0

func (msg MsgAssignConsumerKey) ValidateBasic() error

ValidateBasic implements the sdk.Msg interface.

func (*MsgAssignConsumerKey) XXX_DiscardUnknown added in v1.0.0

func (m *MsgAssignConsumerKey) XXX_DiscardUnknown()

func (*MsgAssignConsumerKey) XXX_Marshal added in v1.0.0

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

func (*MsgAssignConsumerKey) XXX_Merge added in v1.0.0

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

func (*MsgAssignConsumerKey) XXX_Size added in v1.0.0

func (m *MsgAssignConsumerKey) XXX_Size() int

func (*MsgAssignConsumerKey) XXX_Unmarshal added in v1.0.0

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

type MsgAssignConsumerKeyResponse added in v1.0.0

type MsgAssignConsumerKeyResponse struct {
}

func (*MsgAssignConsumerKeyResponse) Descriptor added in v1.0.0

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

func (*MsgAssignConsumerKeyResponse) Marshal added in v1.0.0

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

func (*MsgAssignConsumerKeyResponse) MarshalTo added in v1.0.0

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

func (*MsgAssignConsumerKeyResponse) MarshalToSizedBuffer added in v1.0.0

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

func (*MsgAssignConsumerKeyResponse) ProtoMessage added in v1.0.0

func (*MsgAssignConsumerKeyResponse) ProtoMessage()

func (*MsgAssignConsumerKeyResponse) Reset added in v1.0.0

func (m *MsgAssignConsumerKeyResponse) Reset()

func (*MsgAssignConsumerKeyResponse) Size added in v1.0.0

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

func (*MsgAssignConsumerKeyResponse) String added in v1.0.0

func (*MsgAssignConsumerKeyResponse) Unmarshal added in v1.0.0

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

func (*MsgAssignConsumerKeyResponse) XXX_DiscardUnknown added in v1.0.0

func (m *MsgAssignConsumerKeyResponse) XXX_DiscardUnknown()

func (*MsgAssignConsumerKeyResponse) XXX_Marshal added in v1.0.0

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

func (*MsgAssignConsumerKeyResponse) XXX_Merge added in v1.0.0

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

func (*MsgAssignConsumerKeyResponse) XXX_Size added in v1.0.0

func (m *MsgAssignConsumerKeyResponse) XXX_Size() int

func (*MsgAssignConsumerKeyResponse) XXX_Unmarshal added in v1.0.0

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

type MsgClient added in v1.0.0

type MsgClient interface {
	AssignConsumerKey(ctx context.Context, in *MsgAssignConsumerKey, opts ...grpc.CallOption) (*MsgAssignConsumerKeyResponse, error)
}

MsgClient is the client API for Msg service.

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

func NewMsgClient added in v1.0.0

func NewMsgClient(cc grpc1.ClientConn) MsgClient

type MsgServer added in v1.0.0

type MsgServer interface {
	AssignConsumerKey(context.Context, *MsgAssignConsumerKey) (*MsgAssignConsumerKeyResponse, error)
}

MsgServer is the server API for Msg service.

type Params

type Params struct {
	TemplateClient *types2.ClientState `protobuf:"bytes,1,opt,name=template_client,json=templateClient,proto3" json:"template_client,omitempty"`
	// TrustingPeriodFraction is used to compute the consumer and provider IBC client's TrustingPeriod from the chain defined UnbondingPeriod
	TrustingPeriodFraction string `` /* 129-byte string literal not displayed */
	// Sent IBC packets will timeout after this duration
	CcvTimeoutPeriod time.Duration `protobuf:"bytes,3,opt,name=ccv_timeout_period,json=ccvTimeoutPeriod,proto3,stdduration" json:"ccv_timeout_period"`
	// The channel initialization (IBC channel opening handshake) will timeout after this duration
	InitTimeoutPeriod time.Duration `protobuf:"bytes,4,opt,name=init_timeout_period,json=initTimeoutPeriod,proto3,stdduration" json:"init_timeout_period"`
	// The VSC packets sent by the provider will timeout after this duration.
	// Note that unlike ccv_timeout_period which is an IBC param,
	// the vsc_timeout_period is a provider-side param that enables the provider
	// to timeout VSC packets even when a consumer chain is not live.
	VscTimeoutPeriod time.Duration `protobuf:"bytes,5,opt,name=vsc_timeout_period,json=vscTimeoutPeriod,proto3,stdduration" json:"vsc_timeout_period"`
	// The period for which the slash meter is replenished
	SlashMeterReplenishPeriod time.Duration `` /* 142-byte string literal not displayed */
	// The fraction of total voting power that is replenished to the slash meter every replenish period.
	// This param also serves as a maximum fraction of total voting power that the slash meter can hold.
	SlashMeterReplenishFraction string `` /* 146-byte string literal not displayed */
	// The maximum amount of throttled slash or vsc matured packets
	// that can be queued for a single consumer before the provider chain halts.
	MaxThrottledPackets int64 `protobuf:"varint,8,opt,name=max_throttled_packets,json=maxThrottledPackets,proto3" json:"max_throttled_packets,omitempty"`
}

Params defines the parameters for CCV Provider module

func DefaultParams

func DefaultParams() Params

DefaultParams is the default params for the provider module

func NewParams

func NewParams(
	cs *ibctmtypes.ClientState,
	trustingPeriodFraction string,
	ccvTimeoutPeriod time.Duration,
	initTimeoutPeriod time.Duration,
	vscTimeoutPeriod time.Duration,
	slashMeterReplenishPeriod time.Duration,
	slashMeterReplenishFraction string,
	maxThrottledPackets int64,
) Params

NewParams creates new provider parameters with provided arguments

func (*Params) Descriptor

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

func (*Params) GetCcvTimeoutPeriod added in v0.2.0

func (m *Params) GetCcvTimeoutPeriod() time.Duration

func (*Params) GetInitTimeoutPeriod added in v0.2.0

func (m *Params) GetInitTimeoutPeriod() time.Duration

func (*Params) GetMaxThrottledPackets added in v1.0.0

func (m *Params) GetMaxThrottledPackets() int64

func (*Params) GetSlashMeterReplenishFraction added in v1.0.0

func (m *Params) GetSlashMeterReplenishFraction() string

func (*Params) GetSlashMeterReplenishPeriod added in v1.0.0

func (m *Params) GetSlashMeterReplenishPeriod() time.Duration

func (*Params) GetTemplateClient

func (m *Params) GetTemplateClient() *types2.ClientState

func (*Params) GetTrustingPeriodFraction added in v0.2.0

func (m *Params) GetTrustingPeriodFraction() string

func (*Params) GetVscTimeoutPeriod added in v0.2.0

func (m *Params) GetVscTimeoutPeriod() time.Duration

func (*Params) Marshal

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

func (*Params) MarshalTo

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

func (*Params) MarshalToSizedBuffer

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

func (*Params) ParamSetPairs

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

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

func (*Params) Unmarshal

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

func (Params) Validate

func (p Params) Validate() error

Validate all ccv-provider module parameters

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 ProviderConsAddress added in v1.1.1

type ProviderConsAddress struct {
	Address []byte `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"`
}

A validator's consensus address on the provider chain

func NewProviderConsAddress added in v1.1.1

func NewProviderConsAddress(addr sdk.ConsAddress) ProviderConsAddress

NewProviderConsAddress creates a new ProviderConsAddress, a validator's consensus address on the provider chain.

func (*ProviderConsAddress) Descriptor added in v1.1.1

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

func (*ProviderConsAddress) GetAddress added in v1.1.1

func (m *ProviderConsAddress) GetAddress() []byte

func (*ProviderConsAddress) Marshal added in v1.1.1

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

func (*ProviderConsAddress) MarshalTo added in v1.1.1

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

func (*ProviderConsAddress) MarshalToSizedBuffer added in v1.1.1

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

func (*ProviderConsAddress) ProtoMessage added in v1.1.1

func (*ProviderConsAddress) ProtoMessage()

func (*ProviderConsAddress) Reset added in v1.1.1

func (m *ProviderConsAddress) Reset()

func (*ProviderConsAddress) Size added in v1.1.1

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

func (*ProviderConsAddress) String added in v1.1.1

func (p *ProviderConsAddress) String() string

String implements the Stringer interface for ProviderConsAddress, in the same format as sdk.ConsAddress

func (*ProviderConsAddress) ToSdkConsAddr added in v1.1.1

func (p *ProviderConsAddress) ToSdkConsAddr() sdk.ConsAddress

func (*ProviderConsAddress) Unmarshal added in v1.1.1

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

func (*ProviderConsAddress) XXX_DiscardUnknown added in v1.1.1

func (m *ProviderConsAddress) XXX_DiscardUnknown()

func (*ProviderConsAddress) XXX_Marshal added in v1.1.1

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

func (*ProviderConsAddress) XXX_Merge added in v1.1.1

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

func (*ProviderConsAddress) XXX_Size added in v1.1.1

func (m *ProviderConsAddress) XXX_Size() int

func (*ProviderConsAddress) XXX_Unmarshal added in v1.1.1

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

type QueryClient

type QueryClient interface {
	// ConsumerGenesis queries the genesis state needed to start a consumer chain
	// whose proposal has been accepted
	QueryConsumerGenesis(ctx context.Context, in *QueryConsumerGenesisRequest, opts ...grpc.CallOption) (*QueryConsumerGenesisResponse, error)
	// ConsumerChains queries active consumer chains supported by the provider
	// chain
	QueryConsumerChains(ctx context.Context, in *QueryConsumerChainsRequest, opts ...grpc.CallOption) (*QueryConsumerChainsResponse, error)
	// QueryConsumerChainStarts queries consumer chain start proposals.
	QueryConsumerChainStarts(ctx context.Context, in *QueryConsumerChainStartProposalsRequest, opts ...grpc.CallOption) (*QueryConsumerChainStartProposalsResponse, error)
	// QueryConsumerChainStops queries consumer chain stop proposals.
	QueryConsumerChainStops(ctx context.Context, in *QueryConsumerChainStopProposalsRequest, opts ...grpc.CallOption) (*QueryConsumerChainStopProposalsResponse, error)
	// QueryValidatorConsumerAddr queries the address
	// assigned by a validator for a consumer chain.
	QueryValidatorConsumerAddr(ctx context.Context, in *QueryValidatorConsumerAddrRequest, opts ...grpc.CallOption) (*QueryValidatorConsumerAddrResponse, error)
	// QueryProviderAddr returns the provider chain validator
	// given a consumer chain validator address
	QueryValidatorProviderAddr(ctx context.Context, in *QueryValidatorProviderAddrRequest, opts ...grpc.CallOption) (*QueryValidatorProviderAddrResponse, error)
	// QueryThrottleState returns the main on-chain state relevant to currently throttled slash packets
	QueryThrottleState(ctx context.Context, in *QueryThrottleStateRequest, opts ...grpc.CallOption) (*QueryThrottleStateResponse, error)
	// QueryThrottledConsumerPacketData returns a list of pending packet data instances
	// (slash packet and vsc matured) for a single consumer chain
	QueryThrottledConsumerPacketData(ctx context.Context, in *QueryThrottledConsumerPacketDataRequest, opts ...grpc.CallOption) (*QueryThrottledConsumerPacketDataResponse, 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 QueryConsumerChainStartProposalsRequest added in v0.2.0

type QueryConsumerChainStartProposalsRequest struct {
}

func (*QueryConsumerChainStartProposalsRequest) Descriptor added in v0.2.0

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

func (*QueryConsumerChainStartProposalsRequest) Marshal added in v0.2.0

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

func (*QueryConsumerChainStartProposalsRequest) MarshalTo added in v0.2.0

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

func (*QueryConsumerChainStartProposalsRequest) MarshalToSizedBuffer added in v0.2.0

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

func (*QueryConsumerChainStartProposalsRequest) ProtoMessage added in v0.2.0

func (*QueryConsumerChainStartProposalsRequest) Reset added in v0.2.0

func (*QueryConsumerChainStartProposalsRequest) Size added in v0.2.0

func (*QueryConsumerChainStartProposalsRequest) String added in v0.2.0

func (*QueryConsumerChainStartProposalsRequest) Unmarshal added in v0.2.0

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

func (*QueryConsumerChainStartProposalsRequest) XXX_DiscardUnknown added in v0.2.0

func (m *QueryConsumerChainStartProposalsRequest) XXX_DiscardUnknown()

func (*QueryConsumerChainStartProposalsRequest) XXX_Marshal added in v0.2.0

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

func (*QueryConsumerChainStartProposalsRequest) XXX_Merge added in v0.2.0

func (*QueryConsumerChainStartProposalsRequest) XXX_Size added in v0.2.0

func (*QueryConsumerChainStartProposalsRequest) XXX_Unmarshal added in v0.2.0

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

type QueryConsumerChainStartProposalsResponse added in v0.2.0

type QueryConsumerChainStartProposalsResponse struct {
	Proposals *ConsumerAdditionProposals `protobuf:"bytes,1,opt,name=proposals,proto3" json:"proposals,omitempty"`
}

func (*QueryConsumerChainStartProposalsResponse) Descriptor added in v0.2.0

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

func (*QueryConsumerChainStartProposalsResponse) GetProposals added in v0.2.0

func (*QueryConsumerChainStartProposalsResponse) Marshal added in v0.2.0

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

func (*QueryConsumerChainStartProposalsResponse) MarshalTo added in v0.2.0

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

func (*QueryConsumerChainStartProposalsResponse) MarshalToSizedBuffer added in v0.2.0

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

func (*QueryConsumerChainStartProposalsResponse) ProtoMessage added in v0.2.0

func (*QueryConsumerChainStartProposalsResponse) Reset added in v0.2.0

func (*QueryConsumerChainStartProposalsResponse) Size added in v0.2.0

func (*QueryConsumerChainStartProposalsResponse) String added in v0.2.0

func (*QueryConsumerChainStartProposalsResponse) Unmarshal added in v0.2.0

func (*QueryConsumerChainStartProposalsResponse) XXX_DiscardUnknown added in v0.2.0

func (m *QueryConsumerChainStartProposalsResponse) XXX_DiscardUnknown()

func (*QueryConsumerChainStartProposalsResponse) XXX_Marshal added in v0.2.0

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

func (*QueryConsumerChainStartProposalsResponse) XXX_Merge added in v0.2.0

func (*QueryConsumerChainStartProposalsResponse) XXX_Size added in v0.2.0

func (*QueryConsumerChainStartProposalsResponse) XXX_Unmarshal added in v0.2.0

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

type QueryConsumerChainStopProposalsRequest added in v0.2.0

type QueryConsumerChainStopProposalsRequest struct {
}

func (*QueryConsumerChainStopProposalsRequest) Descriptor added in v0.2.0

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

func (*QueryConsumerChainStopProposalsRequest) Marshal added in v0.2.0

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

func (*QueryConsumerChainStopProposalsRequest) MarshalTo added in v0.2.0

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

func (*QueryConsumerChainStopProposalsRequest) MarshalToSizedBuffer added in v0.2.0

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

func (*QueryConsumerChainStopProposalsRequest) ProtoMessage added in v0.2.0

func (*QueryConsumerChainStopProposalsRequest) Reset added in v0.2.0

func (*QueryConsumerChainStopProposalsRequest) Size added in v0.2.0

func (*QueryConsumerChainStopProposalsRequest) String added in v0.2.0

func (*QueryConsumerChainStopProposalsRequest) Unmarshal added in v0.2.0

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

func (*QueryConsumerChainStopProposalsRequest) XXX_DiscardUnknown added in v0.2.0

func (m *QueryConsumerChainStopProposalsRequest) XXX_DiscardUnknown()

func (*QueryConsumerChainStopProposalsRequest) XXX_Marshal added in v0.2.0

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

func (*QueryConsumerChainStopProposalsRequest) XXX_Merge added in v0.2.0

func (*QueryConsumerChainStopProposalsRequest) XXX_Size added in v0.2.0

func (*QueryConsumerChainStopProposalsRequest) XXX_Unmarshal added in v0.2.0

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

type QueryConsumerChainStopProposalsResponse added in v0.2.0

type QueryConsumerChainStopProposalsResponse struct {
	Proposals *ConsumerRemovalProposals `protobuf:"bytes,1,opt,name=proposals,proto3" json:"proposals,omitempty"`
}

func (*QueryConsumerChainStopProposalsResponse) Descriptor added in v0.2.0

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

func (*QueryConsumerChainStopProposalsResponse) GetProposals added in v0.2.0

func (*QueryConsumerChainStopProposalsResponse) Marshal added in v0.2.0

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

func (*QueryConsumerChainStopProposalsResponse) MarshalTo added in v0.2.0

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

func (*QueryConsumerChainStopProposalsResponse) MarshalToSizedBuffer added in v0.2.0

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

func (*QueryConsumerChainStopProposalsResponse) ProtoMessage added in v0.2.0

func (*QueryConsumerChainStopProposalsResponse) Reset added in v0.2.0

func (*QueryConsumerChainStopProposalsResponse) Size added in v0.2.0

func (*QueryConsumerChainStopProposalsResponse) String added in v0.2.0

func (*QueryConsumerChainStopProposalsResponse) Unmarshal added in v0.2.0

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

func (*QueryConsumerChainStopProposalsResponse) XXX_DiscardUnknown added in v0.2.0

func (m *QueryConsumerChainStopProposalsResponse) XXX_DiscardUnknown()

func (*QueryConsumerChainStopProposalsResponse) XXX_Marshal added in v0.2.0

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

func (*QueryConsumerChainStopProposalsResponse) XXX_Merge added in v0.2.0

func (*QueryConsumerChainStopProposalsResponse) XXX_Size added in v0.2.0

func (*QueryConsumerChainStopProposalsResponse) XXX_Unmarshal added in v0.2.0

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

type QueryConsumerChainsRequest added in v0.2.0

type QueryConsumerChainsRequest struct {
}

func (*QueryConsumerChainsRequest) Descriptor added in v0.2.0

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

func (*QueryConsumerChainsRequest) Marshal added in v0.2.0

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

func (*QueryConsumerChainsRequest) MarshalTo added in v0.2.0

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

func (*QueryConsumerChainsRequest) MarshalToSizedBuffer added in v0.2.0

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

func (*QueryConsumerChainsRequest) ProtoMessage added in v0.2.0

func (*QueryConsumerChainsRequest) ProtoMessage()

func (*QueryConsumerChainsRequest) Reset added in v0.2.0

func (m *QueryConsumerChainsRequest) Reset()

func (*QueryConsumerChainsRequest) Size added in v0.2.0

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

func (*QueryConsumerChainsRequest) String added in v0.2.0

func (m *QueryConsumerChainsRequest) String() string

func (*QueryConsumerChainsRequest) Unmarshal added in v0.2.0

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

func (*QueryConsumerChainsRequest) XXX_DiscardUnknown added in v0.2.0

func (m *QueryConsumerChainsRequest) XXX_DiscardUnknown()

func (*QueryConsumerChainsRequest) XXX_Marshal added in v0.2.0

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

func (*QueryConsumerChainsRequest) XXX_Merge added in v0.2.0

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

func (*QueryConsumerChainsRequest) XXX_Size added in v0.2.0

func (m *QueryConsumerChainsRequest) XXX_Size() int

func (*QueryConsumerChainsRequest) XXX_Unmarshal added in v0.2.0

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

type QueryConsumerChainsResponse added in v0.2.0

type QueryConsumerChainsResponse struct {
	Chains []*Chain `protobuf:"bytes,1,rep,name=chains,proto3" json:"chains,omitempty"`
}

func (*QueryConsumerChainsResponse) Descriptor added in v0.2.0

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

func (*QueryConsumerChainsResponse) GetChains added in v0.2.0

func (m *QueryConsumerChainsResponse) GetChains() []*Chain

func (*QueryConsumerChainsResponse) Marshal added in v0.2.0

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

func (*QueryConsumerChainsResponse) MarshalTo added in v0.2.0

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

func (*QueryConsumerChainsResponse) MarshalToSizedBuffer added in v0.2.0

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

func (*QueryConsumerChainsResponse) ProtoMessage added in v0.2.0

func (*QueryConsumerChainsResponse) ProtoMessage()

func (*QueryConsumerChainsResponse) Reset added in v0.2.0

func (m *QueryConsumerChainsResponse) Reset()

func (*QueryConsumerChainsResponse) Size added in v0.2.0

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

func (*QueryConsumerChainsResponse) String added in v0.2.0

func (m *QueryConsumerChainsResponse) String() string

func (*QueryConsumerChainsResponse) Unmarshal added in v0.2.0

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

func (*QueryConsumerChainsResponse) XXX_DiscardUnknown added in v0.2.0

func (m *QueryConsumerChainsResponse) XXX_DiscardUnknown()

func (*QueryConsumerChainsResponse) XXX_Marshal added in v0.2.0

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

func (*QueryConsumerChainsResponse) XXX_Merge added in v0.2.0

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

func (*QueryConsumerChainsResponse) XXX_Size added in v0.2.0

func (m *QueryConsumerChainsResponse) XXX_Size() int

func (*QueryConsumerChainsResponse) XXX_Unmarshal added in v0.2.0

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

type QueryConsumerGenesisRequest

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

func (*QueryConsumerGenesisRequest) Descriptor

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

func (*QueryConsumerGenesisRequest) GetChainId

func (m *QueryConsumerGenesisRequest) GetChainId() string

func (*QueryConsumerGenesisRequest) Marshal

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

func (*QueryConsumerGenesisRequest) MarshalTo

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

func (*QueryConsumerGenesisRequest) MarshalToSizedBuffer

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

func (*QueryConsumerGenesisRequest) ProtoMessage

func (*QueryConsumerGenesisRequest) ProtoMessage()

func (*QueryConsumerGenesisRequest) Reset

func (m *QueryConsumerGenesisRequest) Reset()

func (*QueryConsumerGenesisRequest) Size

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

func (*QueryConsumerGenesisRequest) String

func (m *QueryConsumerGenesisRequest) String() string

func (*QueryConsumerGenesisRequest) Unmarshal

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

func (*QueryConsumerGenesisRequest) XXX_DiscardUnknown

func (m *QueryConsumerGenesisRequest) XXX_DiscardUnknown()

func (*QueryConsumerGenesisRequest) XXX_Marshal

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

func (*QueryConsumerGenesisRequest) XXX_Merge

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

func (*QueryConsumerGenesisRequest) XXX_Size

func (m *QueryConsumerGenesisRequest) XXX_Size() int

func (*QueryConsumerGenesisRequest) XXX_Unmarshal

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

type QueryConsumerGenesisResponse

type QueryConsumerGenesisResponse struct {
	GenesisState types.GenesisState `protobuf:"bytes,1,opt,name=genesis_state,json=genesisState,proto3" json:"genesis_state"`
}

func (*QueryConsumerGenesisResponse) Descriptor

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

func (*QueryConsumerGenesisResponse) GetGenesisState

func (m *QueryConsumerGenesisResponse) GetGenesisState() types.GenesisState

func (*QueryConsumerGenesisResponse) Marshal

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

func (*QueryConsumerGenesisResponse) MarshalTo

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

func (*QueryConsumerGenesisResponse) MarshalToSizedBuffer

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

func (*QueryConsumerGenesisResponse) ProtoMessage

func (*QueryConsumerGenesisResponse) ProtoMessage()

func (*QueryConsumerGenesisResponse) Reset

func (m *QueryConsumerGenesisResponse) Reset()

func (*QueryConsumerGenesisResponse) Size

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

func (*QueryConsumerGenesisResponse) String

func (*QueryConsumerGenesisResponse) Unmarshal

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

func (*QueryConsumerGenesisResponse) XXX_DiscardUnknown

func (m *QueryConsumerGenesisResponse) XXX_DiscardUnknown()

func (*QueryConsumerGenesisResponse) XXX_Marshal

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

func (*QueryConsumerGenesisResponse) XXX_Merge

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

func (*QueryConsumerGenesisResponse) XXX_Size

func (m *QueryConsumerGenesisResponse) XXX_Size() int

func (*QueryConsumerGenesisResponse) XXX_Unmarshal

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

type QueryServer

type QueryServer interface {
	// ConsumerGenesis queries the genesis state needed to start a consumer chain
	// whose proposal has been accepted
	QueryConsumerGenesis(context.Context, *QueryConsumerGenesisRequest) (*QueryConsumerGenesisResponse, error)
	// ConsumerChains queries active consumer chains supported by the provider
	// chain
	QueryConsumerChains(context.Context, *QueryConsumerChainsRequest) (*QueryConsumerChainsResponse, error)
	// QueryConsumerChainStarts queries consumer chain start proposals.
	QueryConsumerChainStarts(context.Context, *QueryConsumerChainStartProposalsRequest) (*QueryConsumerChainStartProposalsResponse, error)
	// QueryConsumerChainStops queries consumer chain stop proposals.
	QueryConsumerChainStops(context.Context, *QueryConsumerChainStopProposalsRequest) (*QueryConsumerChainStopProposalsResponse, error)
	// QueryValidatorConsumerAddr queries the address
	// assigned by a validator for a consumer chain.
	QueryValidatorConsumerAddr(context.Context, *QueryValidatorConsumerAddrRequest) (*QueryValidatorConsumerAddrResponse, error)
	// QueryProviderAddr returns the provider chain validator
	// given a consumer chain validator address
	QueryValidatorProviderAddr(context.Context, *QueryValidatorProviderAddrRequest) (*QueryValidatorProviderAddrResponse, error)
	// QueryThrottleState returns the main on-chain state relevant to currently throttled slash packets
	QueryThrottleState(context.Context, *QueryThrottleStateRequest) (*QueryThrottleStateResponse, error)
	// QueryThrottledConsumerPacketData returns a list of pending packet data instances
	// (slash packet and vsc matured) for a single consumer chain
	QueryThrottledConsumerPacketData(context.Context, *QueryThrottledConsumerPacketDataRequest) (*QueryThrottledConsumerPacketDataResponse, error)
}

QueryServer is the server API for Query service.

type QueryThrottleStateRequest added in v1.0.0

type QueryThrottleStateRequest struct {
}

func (*QueryThrottleStateRequest) Descriptor added in v1.0.0

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

func (*QueryThrottleStateRequest) Marshal added in v1.0.0

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

func (*QueryThrottleStateRequest) MarshalTo added in v1.0.0

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

func (*QueryThrottleStateRequest) MarshalToSizedBuffer added in v1.0.0

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

func (*QueryThrottleStateRequest) ProtoMessage added in v1.0.0

func (*QueryThrottleStateRequest) ProtoMessage()

func (*QueryThrottleStateRequest) Reset added in v1.0.0

func (m *QueryThrottleStateRequest) Reset()

func (*QueryThrottleStateRequest) Size added in v1.0.0

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

func (*QueryThrottleStateRequest) String added in v1.0.0

func (m *QueryThrottleStateRequest) String() string

func (*QueryThrottleStateRequest) Unmarshal added in v1.0.0

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

func (*QueryThrottleStateRequest) XXX_DiscardUnknown added in v1.0.0

func (m *QueryThrottleStateRequest) XXX_DiscardUnknown()

func (*QueryThrottleStateRequest) XXX_Marshal added in v1.0.0

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

func (*QueryThrottleStateRequest) XXX_Merge added in v1.0.0

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

func (*QueryThrottleStateRequest) XXX_Size added in v1.0.0

func (m *QueryThrottleStateRequest) XXX_Size() int

func (*QueryThrottleStateRequest) XXX_Unmarshal added in v1.0.0

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

type QueryThrottleStateResponse added in v1.0.0

type QueryThrottleStateResponse struct {
	// current slash_meter state
	SlashMeter int64 `protobuf:"varint,1,opt,name=slash_meter,json=slashMeter,proto3" json:"slash_meter,omitempty"`
	// allowance of voting power units (int) that the slash meter is given per replenish period
	// this also serves as the max value for the meter.
	SlashMeterAllowance int64 `protobuf:"varint,2,opt,name=slash_meter_allowance,json=slashMeterAllowance,proto3" json:"slash_meter_allowance,omitempty"`
	// next time the slash meter could potentially be replenished, iff it's not full
	NextReplenishCandidate time.Time `` /* 127-byte string literal not displayed */
	// data relevant to currently throttled slash packets
	Packets []*ThrottledSlashPacket `protobuf:"bytes,4,rep,name=packets,proto3" json:"packets,omitempty"`
}

func (*QueryThrottleStateResponse) Descriptor added in v1.0.0

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

func (*QueryThrottleStateResponse) GetNextReplenishCandidate added in v1.0.0

func (m *QueryThrottleStateResponse) GetNextReplenishCandidate() time.Time

func (*QueryThrottleStateResponse) GetPackets added in v1.0.0

func (*QueryThrottleStateResponse) GetSlashMeter added in v1.0.0

func (m *QueryThrottleStateResponse) GetSlashMeter() int64

func (*QueryThrottleStateResponse) GetSlashMeterAllowance added in v1.0.0

func (m *QueryThrottleStateResponse) GetSlashMeterAllowance() int64

func (*QueryThrottleStateResponse) Marshal added in v1.0.0

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

func (*QueryThrottleStateResponse) MarshalTo added in v1.0.0

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

func (*QueryThrottleStateResponse) MarshalToSizedBuffer added in v1.0.0

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

func (*QueryThrottleStateResponse) ProtoMessage added in v1.0.0

func (*QueryThrottleStateResponse) ProtoMessage()

func (*QueryThrottleStateResponse) Reset added in v1.0.0

func (m *QueryThrottleStateResponse) Reset()

func (*QueryThrottleStateResponse) Size added in v1.0.0

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

func (*QueryThrottleStateResponse) String added in v1.0.0

func (m *QueryThrottleStateResponse) String() string

func (*QueryThrottleStateResponse) Unmarshal added in v1.0.0

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

func (*QueryThrottleStateResponse) XXX_DiscardUnknown added in v1.0.0

func (m *QueryThrottleStateResponse) XXX_DiscardUnknown()

func (*QueryThrottleStateResponse) XXX_Marshal added in v1.0.0

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

func (*QueryThrottleStateResponse) XXX_Merge added in v1.0.0

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

func (*QueryThrottleStateResponse) XXX_Size added in v1.0.0

func (m *QueryThrottleStateResponse) XXX_Size() int

func (*QueryThrottleStateResponse) XXX_Unmarshal added in v1.0.0

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

type QueryThrottledConsumerPacketDataRequest added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataRequest) Descriptor added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataRequest) GetChainId added in v1.0.0

func (*QueryThrottledConsumerPacketDataRequest) Marshal added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataRequest) MarshalTo added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataRequest) MarshalToSizedBuffer added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataRequest) ProtoMessage added in v1.0.0

func (*QueryThrottledConsumerPacketDataRequest) Reset added in v1.0.0

func (*QueryThrottledConsumerPacketDataRequest) Size added in v1.0.0

func (*QueryThrottledConsumerPacketDataRequest) String added in v1.0.0

func (*QueryThrottledConsumerPacketDataRequest) Unmarshal added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataRequest) XXX_DiscardUnknown added in v1.0.0

func (m *QueryThrottledConsumerPacketDataRequest) XXX_DiscardUnknown()

func (*QueryThrottledConsumerPacketDataRequest) XXX_Marshal added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataRequest) XXX_Merge added in v1.0.0

func (*QueryThrottledConsumerPacketDataRequest) XXX_Size added in v1.0.0

func (*QueryThrottledConsumerPacketDataRequest) XXX_Unmarshal added in v1.0.0

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

type QueryThrottledConsumerPacketDataResponse added in v1.0.0

type QueryThrottledConsumerPacketDataResponse struct {
	ChainId             string                       `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	Size_               uint64                       `protobuf:"varint,2,opt,name=size,proto3" json:"size,omitempty"`
	PacketDataInstances []ThrottledPacketDataWrapper `protobuf:"bytes,3,rep,name=packetDataInstances,proto3" json:"packetDataInstances"`
}

func (*QueryThrottledConsumerPacketDataResponse) Descriptor added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataResponse) GetChainId added in v1.0.0

func (*QueryThrottledConsumerPacketDataResponse) GetPacketDataInstances added in v1.0.0

func (*QueryThrottledConsumerPacketDataResponse) GetSize_ added in v1.0.0

func (*QueryThrottledConsumerPacketDataResponse) Marshal added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataResponse) MarshalTo added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataResponse) MarshalToSizedBuffer added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataResponse) ProtoMessage added in v1.0.0

func (*QueryThrottledConsumerPacketDataResponse) Reset added in v1.0.0

func (*QueryThrottledConsumerPacketDataResponse) Size added in v1.0.0

func (*QueryThrottledConsumerPacketDataResponse) String added in v1.0.0

func (*QueryThrottledConsumerPacketDataResponse) Unmarshal added in v1.0.0

func (*QueryThrottledConsumerPacketDataResponse) XXX_DiscardUnknown added in v1.0.0

func (m *QueryThrottledConsumerPacketDataResponse) XXX_DiscardUnknown()

func (*QueryThrottledConsumerPacketDataResponse) XXX_Marshal added in v1.0.0

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

func (*QueryThrottledConsumerPacketDataResponse) XXX_Merge added in v1.0.0

func (*QueryThrottledConsumerPacketDataResponse) XXX_Size added in v1.0.0

func (*QueryThrottledConsumerPacketDataResponse) XXX_Unmarshal added in v1.0.0

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

type QueryValidatorConsumerAddrRequest added in v1.0.0

type QueryValidatorConsumerAddrRequest struct {
	// The id of the consumer chain
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// The consensus address of the validator on the provider chain
	ProviderAddress string `protobuf:"bytes,2,opt,name=provider_address,json=providerAddress,proto3" json:"provider_address,omitempty" yaml:"address"`
}

func (*QueryValidatorConsumerAddrRequest) Descriptor added in v1.0.0

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

func (*QueryValidatorConsumerAddrRequest) Marshal added in v1.0.0

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

func (*QueryValidatorConsumerAddrRequest) MarshalTo added in v1.0.0

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

func (*QueryValidatorConsumerAddrRequest) MarshalToSizedBuffer added in v1.0.0

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

func (*QueryValidatorConsumerAddrRequest) ProtoMessage added in v1.0.0

func (*QueryValidatorConsumerAddrRequest) ProtoMessage()

func (*QueryValidatorConsumerAddrRequest) Reset added in v1.0.0

func (*QueryValidatorConsumerAddrRequest) Size added in v1.0.0

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

func (*QueryValidatorConsumerAddrRequest) String added in v1.0.0

func (*QueryValidatorConsumerAddrRequest) Unmarshal added in v1.0.0

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

func (*QueryValidatorConsumerAddrRequest) XXX_DiscardUnknown added in v1.0.0

func (m *QueryValidatorConsumerAddrRequest) XXX_DiscardUnknown()

func (*QueryValidatorConsumerAddrRequest) XXX_Marshal added in v1.0.0

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

func (*QueryValidatorConsumerAddrRequest) XXX_Merge added in v1.0.0

func (*QueryValidatorConsumerAddrRequest) XXX_Size added in v1.0.0

func (m *QueryValidatorConsumerAddrRequest) XXX_Size() int

func (*QueryValidatorConsumerAddrRequest) XXX_Unmarshal added in v1.0.0

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

type QueryValidatorConsumerAddrResponse added in v1.0.0

type QueryValidatorConsumerAddrResponse struct {
	// The address of the validator on the consumer chain
	ConsumerAddress string `protobuf:"bytes,1,opt,name=consumer_address,json=consumerAddress,proto3" json:"consumer_address,omitempty"`
}

func (*QueryValidatorConsumerAddrResponse) Descriptor added in v1.0.0

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

func (*QueryValidatorConsumerAddrResponse) GetConsumerAddress added in v1.0.0

func (m *QueryValidatorConsumerAddrResponse) GetConsumerAddress() string

func (*QueryValidatorConsumerAddrResponse) Marshal added in v1.0.0

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

func (*QueryValidatorConsumerAddrResponse) MarshalTo added in v1.0.0

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

func (*QueryValidatorConsumerAddrResponse) MarshalToSizedBuffer added in v1.0.0

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

func (*QueryValidatorConsumerAddrResponse) ProtoMessage added in v1.0.0

func (*QueryValidatorConsumerAddrResponse) ProtoMessage()

func (*QueryValidatorConsumerAddrResponse) Reset added in v1.0.0

func (*QueryValidatorConsumerAddrResponse) Size added in v1.0.0

func (*QueryValidatorConsumerAddrResponse) String added in v1.0.0

func (*QueryValidatorConsumerAddrResponse) Unmarshal added in v1.0.0

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

func (*QueryValidatorConsumerAddrResponse) XXX_DiscardUnknown added in v1.0.0

func (m *QueryValidatorConsumerAddrResponse) XXX_DiscardUnknown()

func (*QueryValidatorConsumerAddrResponse) XXX_Marshal added in v1.0.0

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

func (*QueryValidatorConsumerAddrResponse) XXX_Merge added in v1.0.0

func (*QueryValidatorConsumerAddrResponse) XXX_Size added in v1.0.0

func (*QueryValidatorConsumerAddrResponse) XXX_Unmarshal added in v1.0.0

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

type QueryValidatorProviderAddrRequest added in v1.0.0

type QueryValidatorProviderAddrRequest struct {
	// The id of the provider chain
	ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	// The consensus address of the validator on the consumer chain
	ConsumerAddress string `protobuf:"bytes,2,opt,name=consumer_address,json=consumerAddress,proto3" json:"consumer_address,omitempty" yaml:"address"`
}

func (*QueryValidatorProviderAddrRequest) Descriptor added in v1.0.0

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

func (*QueryValidatorProviderAddrRequest) Marshal added in v1.0.0

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

func (*QueryValidatorProviderAddrRequest) MarshalTo added in v1.0.0

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

func (*QueryValidatorProviderAddrRequest) MarshalToSizedBuffer added in v1.0.0

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

func (*QueryValidatorProviderAddrRequest) ProtoMessage added in v1.0.0

func (*QueryValidatorProviderAddrRequest) ProtoMessage()

func (*QueryValidatorProviderAddrRequest) Reset added in v1.0.0

func (*QueryValidatorProviderAddrRequest) Size added in v1.0.0

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

func (*QueryValidatorProviderAddrRequest) String added in v1.0.0

func (*QueryValidatorProviderAddrRequest) Unmarshal added in v1.0.0

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

func (*QueryValidatorProviderAddrRequest) XXX_DiscardUnknown added in v1.0.0

func (m *QueryValidatorProviderAddrRequest) XXX_DiscardUnknown()

func (*QueryValidatorProviderAddrRequest) XXX_Marshal added in v1.0.0

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

func (*QueryValidatorProviderAddrRequest) XXX_Merge added in v1.0.0

func (*QueryValidatorProviderAddrRequest) XXX_Size added in v1.0.0

func (m *QueryValidatorProviderAddrRequest) XXX_Size() int

func (*QueryValidatorProviderAddrRequest) XXX_Unmarshal added in v1.0.0

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

type QueryValidatorProviderAddrResponse added in v1.0.0

type QueryValidatorProviderAddrResponse struct {
	// The address of the validator on the provider chain
	ProviderAddress string `protobuf:"bytes,1,opt,name=provider_address,json=providerAddress,proto3" json:"provider_address,omitempty"`
}

func (*QueryValidatorProviderAddrResponse) Descriptor added in v1.0.0

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

func (*QueryValidatorProviderAddrResponse) GetProviderAddress added in v1.0.0

func (m *QueryValidatorProviderAddrResponse) GetProviderAddress() string

func (*QueryValidatorProviderAddrResponse) Marshal added in v1.0.0

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

func (*QueryValidatorProviderAddrResponse) MarshalTo added in v1.0.0

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

func (*QueryValidatorProviderAddrResponse) MarshalToSizedBuffer added in v1.0.0

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

func (*QueryValidatorProviderAddrResponse) ProtoMessage added in v1.0.0

func (*QueryValidatorProviderAddrResponse) ProtoMessage()

func (*QueryValidatorProviderAddrResponse) Reset added in v1.0.0

func (*QueryValidatorProviderAddrResponse) Size added in v1.0.0

func (*QueryValidatorProviderAddrResponse) String added in v1.0.0

func (*QueryValidatorProviderAddrResponse) Unmarshal added in v1.0.0

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

func (*QueryValidatorProviderAddrResponse) XXX_DiscardUnknown added in v1.0.0

func (m *QueryValidatorProviderAddrResponse) XXX_DiscardUnknown()

func (*QueryValidatorProviderAddrResponse) XXX_Marshal added in v1.0.0

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

func (*QueryValidatorProviderAddrResponse) XXX_Merge added in v1.0.0

func (*QueryValidatorProviderAddrResponse) XXX_Size added in v1.0.0

func (*QueryValidatorProviderAddrResponse) XXX_Unmarshal added in v1.0.0

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

type SlashAcks added in v0.2.0

type SlashAcks struct {
	Addresses []string `protobuf:"bytes,1,rep,name=addresses,proto3" json:"addresses,omitempty"`
}

SlashAcks contains cons addresses of consumer chain validators successfully slashed on the provider chain

func (*SlashAcks) Descriptor added in v0.2.0

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

func (*SlashAcks) GetAddresses added in v0.2.0

func (m *SlashAcks) GetAddresses() []string

func (*SlashAcks) Marshal added in v0.2.0

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

func (*SlashAcks) MarshalTo added in v0.2.0

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

func (*SlashAcks) MarshalToSizedBuffer added in v0.2.0

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

func (*SlashAcks) ProtoMessage added in v0.2.0

func (*SlashAcks) ProtoMessage()

func (*SlashAcks) Reset added in v0.2.0

func (m *SlashAcks) Reset()

func (*SlashAcks) Size added in v0.2.0

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

func (*SlashAcks) String added in v0.2.0

func (m *SlashAcks) String() string

func (*SlashAcks) Unmarshal added in v0.2.0

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

func (*SlashAcks) XXX_DiscardUnknown added in v0.2.0

func (m *SlashAcks) XXX_DiscardUnknown()

func (*SlashAcks) XXX_Marshal added in v0.2.0

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

func (*SlashAcks) XXX_Merge added in v0.2.0

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

func (*SlashAcks) XXX_Size added in v0.2.0

func (m *SlashAcks) XXX_Size() int

func (*SlashAcks) XXX_Unmarshal added in v0.2.0

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

type Status

type Status int

type ThrottledPacketDataWrapper added in v1.0.0

type ThrottledPacketDataWrapper struct {
	// Types that are valid to be assigned to Data:
	//	*ThrottledPacketDataWrapper_SlashPacket
	//	*ThrottledPacketDataWrapper_VscMaturedPacket
	Data isThrottledPacketDataWrapper_Data `protobuf_oneof:"data"`
}

ThrottledPacketDataWrapper contains either SlashPacketData or VSCMaturedPacketData

func (*ThrottledPacketDataWrapper) Descriptor added in v1.0.0

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

func (*ThrottledPacketDataWrapper) GetData added in v1.0.0

func (m *ThrottledPacketDataWrapper) GetData() isThrottledPacketDataWrapper_Data

func (*ThrottledPacketDataWrapper) GetSlashPacket added in v1.0.0

func (m *ThrottledPacketDataWrapper) GetSlashPacket() *types1.SlashPacketData

func (*ThrottledPacketDataWrapper) GetVscMaturedPacket added in v1.0.0

func (m *ThrottledPacketDataWrapper) GetVscMaturedPacket() *types1.VSCMaturedPacketData

func (*ThrottledPacketDataWrapper) Marshal added in v1.0.0

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

func (*ThrottledPacketDataWrapper) MarshalTo added in v1.0.0

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

func (*ThrottledPacketDataWrapper) MarshalToSizedBuffer added in v1.0.0

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

func (*ThrottledPacketDataWrapper) ProtoMessage added in v1.0.0

func (*ThrottledPacketDataWrapper) ProtoMessage()

func (*ThrottledPacketDataWrapper) Reset added in v1.0.0

func (m *ThrottledPacketDataWrapper) Reset()

func (*ThrottledPacketDataWrapper) Size added in v1.0.0

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

func (*ThrottledPacketDataWrapper) String added in v1.0.0

func (m *ThrottledPacketDataWrapper) String() string

func (*ThrottledPacketDataWrapper) Unmarshal added in v1.0.0

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

func (*ThrottledPacketDataWrapper) XXX_DiscardUnknown added in v1.0.0

func (m *ThrottledPacketDataWrapper) XXX_DiscardUnknown()

func (*ThrottledPacketDataWrapper) XXX_Marshal added in v1.0.0

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

func (*ThrottledPacketDataWrapper) XXX_Merge added in v1.0.0

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

func (*ThrottledPacketDataWrapper) XXX_OneofWrappers added in v1.0.0

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

XXX_OneofWrappers is for the internal use of the proto package.

func (*ThrottledPacketDataWrapper) XXX_Size added in v1.0.0

func (m *ThrottledPacketDataWrapper) XXX_Size() int

func (*ThrottledPacketDataWrapper) XXX_Unmarshal added in v1.0.0

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

type ThrottledPacketDataWrapper_SlashPacket added in v1.0.0

type ThrottledPacketDataWrapper_SlashPacket struct {
	SlashPacket *types1.SlashPacketData `protobuf:"bytes,1,opt,name=slash_packet,json=slashPacket,proto3,oneof" json:"slash_packet,omitempty"`
}

func (*ThrottledPacketDataWrapper_SlashPacket) MarshalTo added in v1.0.0

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

func (*ThrottledPacketDataWrapper_SlashPacket) MarshalToSizedBuffer added in v1.0.0

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

func (*ThrottledPacketDataWrapper_SlashPacket) Size added in v1.0.0

type ThrottledPacketDataWrapper_VscMaturedPacket added in v1.0.0

type ThrottledPacketDataWrapper_VscMaturedPacket struct {
	VscMaturedPacket *types1.VSCMaturedPacketData `protobuf:"bytes,2,opt,name=vsc_matured_packet,json=vscMaturedPacket,proto3,oneof" json:"vsc_matured_packet,omitempty"`
}

func (*ThrottledPacketDataWrapper_VscMaturedPacket) MarshalTo added in v1.0.0

func (*ThrottledPacketDataWrapper_VscMaturedPacket) MarshalToSizedBuffer added in v1.0.0

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

func (*ThrottledPacketDataWrapper_VscMaturedPacket) Size added in v1.0.0

type ThrottledSlashPacket added in v1.0.0

type ThrottledSlashPacket struct {
	GlobalEntry GlobalSlashEntry       `protobuf:"bytes,1,opt,name=global_entry,json=globalEntry,proto3" json:"global_entry"`
	Data        types1.SlashPacketData `protobuf:"bytes,2,opt,name=data,proto3" json:"data"`
}

A query wrapper type for the global entry and data relevant to a throttled slash packet.

func (*ThrottledSlashPacket) Descriptor added in v1.0.0

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

func (*ThrottledSlashPacket) GetData added in v1.0.0

func (*ThrottledSlashPacket) GetGlobalEntry added in v1.0.0

func (m *ThrottledSlashPacket) GetGlobalEntry() GlobalSlashEntry

func (*ThrottledSlashPacket) Marshal added in v1.0.0

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

func (*ThrottledSlashPacket) MarshalTo added in v1.0.0

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

func (*ThrottledSlashPacket) MarshalToSizedBuffer added in v1.0.0

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

func (*ThrottledSlashPacket) ProtoMessage added in v1.0.0

func (*ThrottledSlashPacket) ProtoMessage()

func (*ThrottledSlashPacket) Reset added in v1.0.0

func (m *ThrottledSlashPacket) Reset()

func (*ThrottledSlashPacket) Size added in v1.0.0

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

func (*ThrottledSlashPacket) String added in v1.0.0

func (m *ThrottledSlashPacket) String() string

func (*ThrottledSlashPacket) Unmarshal added in v1.0.0

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

func (*ThrottledSlashPacket) XXX_DiscardUnknown added in v1.0.0

func (m *ThrottledSlashPacket) XXX_DiscardUnknown()

func (*ThrottledSlashPacket) XXX_Marshal added in v1.0.0

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

func (*ThrottledSlashPacket) XXX_Merge added in v1.0.0

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

func (*ThrottledSlashPacket) XXX_Size added in v1.0.0

func (m *ThrottledSlashPacket) XXX_Size() int

func (*ThrottledSlashPacket) XXX_Unmarshal added in v1.0.0

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

type UnbondingOp added in v1.0.0

type UnbondingOp struct {
	Id uint64 `protobuf:"varint,1,opt,name=id,proto3" json:"id,omitempty"`
	// consumer chains that are still unbonding
	UnbondingConsumerChains []string `` /* 132-byte string literal not displayed */
}

UnbondingOp contains the ids of consumer chains that need to unbond before the unbonding operation with the given ID can unbond

func (*UnbondingOp) Descriptor added in v1.0.0

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

func (*UnbondingOp) GetId added in v1.0.0

func (m *UnbondingOp) GetId() uint64

func (*UnbondingOp) GetUnbondingConsumerChains added in v1.0.0

func (m *UnbondingOp) GetUnbondingConsumerChains() []string

func (*UnbondingOp) Marshal added in v1.0.0

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

func (*UnbondingOp) MarshalTo added in v1.0.0

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

func (*UnbondingOp) MarshalToSizedBuffer added in v1.0.0

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

func (*UnbondingOp) ProtoMessage added in v1.0.0

func (*UnbondingOp) ProtoMessage()

func (*UnbondingOp) Reset added in v1.0.0

func (m *UnbondingOp) Reset()

func (*UnbondingOp) Size added in v1.0.0

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

func (*UnbondingOp) String added in v1.0.0

func (m *UnbondingOp) String() string

func (*UnbondingOp) Unmarshal added in v1.0.0

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

func (*UnbondingOp) XXX_DiscardUnknown added in v1.0.0

func (m *UnbondingOp) XXX_DiscardUnknown()

func (*UnbondingOp) XXX_Marshal added in v1.0.0

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

func (*UnbondingOp) XXX_Merge added in v1.0.0

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

func (*UnbondingOp) XXX_Size added in v1.0.0

func (m *UnbondingOp) XXX_Size() int

func (*UnbondingOp) XXX_Unmarshal added in v1.0.0

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

type UnimplementedMsgServer added in v1.0.0

type UnimplementedMsgServer struct {
}

UnimplementedMsgServer can be embedded to have forward compatible implementations.

func (*UnimplementedMsgServer) AssignConsumerKey added in v1.0.0

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) QueryConsumerChainStarts added in v0.2.0

func (*UnimplementedQueryServer) QueryConsumerChainStops added in v0.2.0

func (*UnimplementedQueryServer) QueryConsumerChains added in v0.2.0

func (*UnimplementedQueryServer) QueryConsumerGenesis added in v0.2.0

func (*UnimplementedQueryServer) QueryThrottleState added in v1.0.0

func (*UnimplementedQueryServer) QueryThrottledConsumerPacketData added in v1.0.0

func (*UnimplementedQueryServer) QueryValidatorConsumerAddr added in v1.0.0

func (*UnimplementedQueryServer) QueryValidatorProviderAddr added in v1.0.0

type ValidatorByConsumerAddr added in v1.0.0

type ValidatorByConsumerAddr struct {
	ChainId      string               `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	ConsumerAddr *ConsumerConsAddress `protobuf:"bytes,2,opt,name=consumer_addr,json=consumerAddr,proto3" json:"consumer_addr,omitempty"`
	ProviderAddr *ProviderConsAddress `protobuf:"bytes,3,opt,name=provider_addr,json=providerAddr,proto3" json:"provider_addr,omitempty"`
}

Used to serialize the ValidatorConsumerAddr index from key assignment ValidatorByConsumerAddr: (chainID, consumerAddr consAddr) -> providerAddr consAddr

func (*ValidatorByConsumerAddr) Descriptor added in v1.0.0

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

func (*ValidatorByConsumerAddr) GetChainId added in v1.0.0

func (m *ValidatorByConsumerAddr) GetChainId() string

func (*ValidatorByConsumerAddr) GetConsumerAddr added in v1.0.0

func (m *ValidatorByConsumerAddr) GetConsumerAddr() *ConsumerConsAddress

func (*ValidatorByConsumerAddr) GetProviderAddr added in v1.0.0

func (m *ValidatorByConsumerAddr) GetProviderAddr() *ProviderConsAddress

func (*ValidatorByConsumerAddr) Marshal added in v1.0.0

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

func (*ValidatorByConsumerAddr) MarshalTo added in v1.0.0

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

func (*ValidatorByConsumerAddr) MarshalToSizedBuffer added in v1.0.0

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

func (*ValidatorByConsumerAddr) ProtoMessage added in v1.0.0

func (*ValidatorByConsumerAddr) ProtoMessage()

func (*ValidatorByConsumerAddr) Reset added in v1.0.0

func (m *ValidatorByConsumerAddr) Reset()

func (*ValidatorByConsumerAddr) Size added in v1.0.0

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

func (*ValidatorByConsumerAddr) String added in v1.0.0

func (m *ValidatorByConsumerAddr) String() string

func (*ValidatorByConsumerAddr) Unmarshal added in v1.0.0

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

func (*ValidatorByConsumerAddr) XXX_DiscardUnknown added in v1.0.0

func (m *ValidatorByConsumerAddr) XXX_DiscardUnknown()

func (*ValidatorByConsumerAddr) XXX_Marshal added in v1.0.0

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

func (*ValidatorByConsumerAddr) XXX_Merge added in v1.0.0

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

func (*ValidatorByConsumerAddr) XXX_Size added in v1.0.0

func (m *ValidatorByConsumerAddr) XXX_Size() int

func (*ValidatorByConsumerAddr) XXX_Unmarshal added in v1.0.0

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

type ValidatorConsumerPubKey added in v1.0.0

type ValidatorConsumerPubKey struct {
	ChainId      string               `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	ProviderAddr *ProviderConsAddress `protobuf:"bytes,2,opt,name=provider_addr,json=providerAddr,proto3" json:"provider_addr,omitempty"`
	ConsumerKey  *crypto.PublicKey    `protobuf:"bytes,3,opt,name=consumer_key,json=consumerKey,proto3" json:"consumer_key,omitempty"`
}

Used to serialize the ValidatorConsumerPubKey index from key assignment ValidatorConsumerPubKey: (chainID, providerAddr consAddr) -> consumerKey tmprotocrypto.PublicKey

func (*ValidatorConsumerPubKey) Descriptor added in v1.0.0

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

func (*ValidatorConsumerPubKey) GetChainId added in v1.0.0

func (m *ValidatorConsumerPubKey) GetChainId() string

func (*ValidatorConsumerPubKey) GetConsumerKey added in v1.0.0

func (m *ValidatorConsumerPubKey) GetConsumerKey() *crypto.PublicKey

func (*ValidatorConsumerPubKey) GetProviderAddr added in v1.0.0

func (m *ValidatorConsumerPubKey) GetProviderAddr() *ProviderConsAddress

func (*ValidatorConsumerPubKey) Marshal added in v1.0.0

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

func (*ValidatorConsumerPubKey) MarshalTo added in v1.0.0

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

func (*ValidatorConsumerPubKey) MarshalToSizedBuffer added in v1.0.0

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

func (*ValidatorConsumerPubKey) ProtoMessage added in v1.0.0

func (*ValidatorConsumerPubKey) ProtoMessage()

func (*ValidatorConsumerPubKey) Reset added in v1.0.0

func (m *ValidatorConsumerPubKey) Reset()

func (*ValidatorConsumerPubKey) Size added in v1.0.0

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

func (*ValidatorConsumerPubKey) String added in v1.0.0

func (m *ValidatorConsumerPubKey) String() string

func (*ValidatorConsumerPubKey) Unmarshal added in v1.0.0

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

func (*ValidatorConsumerPubKey) XXX_DiscardUnknown added in v1.0.0

func (m *ValidatorConsumerPubKey) XXX_DiscardUnknown()

func (*ValidatorConsumerPubKey) XXX_Marshal added in v1.0.0

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

func (*ValidatorConsumerPubKey) XXX_Merge added in v1.0.0

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

func (*ValidatorConsumerPubKey) XXX_Size added in v1.0.0

func (m *ValidatorConsumerPubKey) XXX_Size() int

func (*ValidatorConsumerPubKey) XXX_Unmarshal added in v1.0.0

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

type ValsetUpdateIdToHeight added in v0.2.0

type ValsetUpdateIdToHeight struct {
	ValsetUpdateId uint64 `protobuf:"varint,1,opt,name=valset_update_id,json=valsetUpdateId,proto3" json:"valset_update_id,omitempty"`
	Height         uint64 `protobuf:"varint,2,opt,name=height,proto3" json:"height,omitempty"`
}

ValsetUpdateIdToHeight defines the genesis information for the mapping of each valset udpate id to a block height

func (*ValsetUpdateIdToHeight) Descriptor added in v0.2.0

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

func (*ValsetUpdateIdToHeight) GetHeight added in v0.2.0

func (m *ValsetUpdateIdToHeight) GetHeight() uint64

func (*ValsetUpdateIdToHeight) GetValsetUpdateId added in v0.2.0

func (m *ValsetUpdateIdToHeight) GetValsetUpdateId() uint64

func (*ValsetUpdateIdToHeight) Marshal added in v0.2.0

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

func (*ValsetUpdateIdToHeight) MarshalTo added in v0.2.0

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

func (*ValsetUpdateIdToHeight) MarshalToSizedBuffer added in v0.2.0

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

func (*ValsetUpdateIdToHeight) ProtoMessage added in v0.2.0

func (*ValsetUpdateIdToHeight) ProtoMessage()

func (*ValsetUpdateIdToHeight) Reset added in v0.2.0

func (m *ValsetUpdateIdToHeight) Reset()

func (*ValsetUpdateIdToHeight) Size added in v0.2.0

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

func (*ValsetUpdateIdToHeight) String added in v0.2.0

func (m *ValsetUpdateIdToHeight) String() string

func (*ValsetUpdateIdToHeight) Unmarshal added in v0.2.0

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

func (*ValsetUpdateIdToHeight) XXX_DiscardUnknown added in v0.2.0

func (m *ValsetUpdateIdToHeight) XXX_DiscardUnknown()

func (*ValsetUpdateIdToHeight) XXX_Marshal added in v0.2.0

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

func (*ValsetUpdateIdToHeight) XXX_Merge added in v0.2.0

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

func (*ValsetUpdateIdToHeight) XXX_Size added in v0.2.0

func (m *ValsetUpdateIdToHeight) XXX_Size() int

func (*ValsetUpdateIdToHeight) XXX_Unmarshal added in v0.2.0

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

type VscSendTimestamp added in v1.0.0

type VscSendTimestamp struct {
	VscId     uint64    `protobuf:"varint,1,opt,name=vsc_id,json=vscId,proto3" json:"vsc_id,omitempty"`
	Timestamp time.Time `protobuf:"bytes,2,opt,name=timestamp,proto3,stdtime" json:"timestamp"`
}

func (*VscSendTimestamp) Descriptor added in v1.0.0

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

func (*VscSendTimestamp) GetTimestamp added in v1.0.0

func (m *VscSendTimestamp) GetTimestamp() time.Time

func (*VscSendTimestamp) GetVscId added in v1.0.0

func (m *VscSendTimestamp) GetVscId() uint64

func (*VscSendTimestamp) Marshal added in v1.0.0

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

func (*VscSendTimestamp) MarshalTo added in v1.0.0

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

func (*VscSendTimestamp) MarshalToSizedBuffer added in v1.0.0

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

func (*VscSendTimestamp) ProtoMessage added in v1.0.0

func (*VscSendTimestamp) ProtoMessage()

func (*VscSendTimestamp) Reset added in v1.0.0

func (m *VscSendTimestamp) Reset()

func (*VscSendTimestamp) Size added in v1.0.0

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

func (*VscSendTimestamp) String added in v1.0.0

func (m *VscSendTimestamp) String() string

func (*VscSendTimestamp) Unmarshal added in v1.0.0

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

func (*VscSendTimestamp) XXX_DiscardUnknown added in v1.0.0

func (m *VscSendTimestamp) XXX_DiscardUnknown()

func (*VscSendTimestamp) XXX_Marshal added in v1.0.0

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

func (*VscSendTimestamp) XXX_Merge added in v1.0.0

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

func (*VscSendTimestamp) XXX_Size added in v1.0.0

func (m *VscSendTimestamp) XXX_Size() int

func (*VscSendTimestamp) XXX_Unmarshal added in v1.0.0

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

type VscUnbondingOps added in v1.0.0

type VscUnbondingOps struct {
	VscId          uint64   `protobuf:"varint,1,opt,name=vsc_id,json=vscId,proto3" json:"vsc_id,omitempty"`
	UnbondingOpIds []uint64 `protobuf:"varint,2,rep,packed,name=unbonding_op_ids,json=unbondingOpIds,proto3" json:"unbonding_op_ids,omitempty"`
}

VscUnbondingOps contains the IDs of unbonding operations that are waiting for at least one VSCMaturedPacket with vscID from a consumer chain

func (*VscUnbondingOps) Descriptor added in v1.0.0

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

func (*VscUnbondingOps) GetUnbondingOpIds added in v1.0.0

func (m *VscUnbondingOps) GetUnbondingOpIds() []uint64

func (*VscUnbondingOps) GetVscId added in v1.0.0

func (m *VscUnbondingOps) GetVscId() uint64

func (*VscUnbondingOps) Marshal added in v1.0.0

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

func (*VscUnbondingOps) MarshalTo added in v1.0.0

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

func (*VscUnbondingOps) MarshalToSizedBuffer added in v1.0.0

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

func (*VscUnbondingOps) ProtoMessage added in v1.0.0

func (*VscUnbondingOps) ProtoMessage()

func (*VscUnbondingOps) Reset added in v1.0.0

func (m *VscUnbondingOps) Reset()

func (*VscUnbondingOps) Size added in v1.0.0

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

func (*VscUnbondingOps) String added in v1.0.0

func (m *VscUnbondingOps) String() string

func (*VscUnbondingOps) Unmarshal added in v1.0.0

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

func (*VscUnbondingOps) XXX_DiscardUnknown added in v1.0.0

func (m *VscUnbondingOps) XXX_DiscardUnknown()

func (*VscUnbondingOps) XXX_Marshal added in v1.0.0

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

func (*VscUnbondingOps) XXX_Merge added in v1.0.0

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

func (*VscUnbondingOps) XXX_Size added in v1.0.0

func (m *VscUnbondingOps) XXX_Size() int

func (*VscUnbondingOps) XXX_Unmarshal added in v1.0.0

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

Jump to

Keyboard shortcuts

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