tendermint

package
v0.1.4 Latest Latest
Warning

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

Go to latest
Published: Apr 10, 2023 License: MIT Imports: 36 Imported by: 0

Documentation

Overview

Package tendermint implements a concrete ClientState, ConsensusState, Header, Misbehaviour and types for the Tendermint consensus light client. This implementation is based off the ICS 07 specification (https://github.com/cosmos/ibc/tree/main/spec/client/ics-007-tendermint-client)

Index

Constants

View Source
const KeyIterateConsensusStatePrefix = "iterateConsensusStates"
View Source
const (
	ModuleName = "07-tendermint"
)
View Source
const SentinelRoot = "sentinel_root"

SentinelRoot is used as a stand-in root value for the consensus state set at the upgrade height

Variables

View Source
var (
	ErrInvalidChainID          = errorsmod.Register(ModuleName, 2, "invalid chain-id")
	ErrInvalidTrustingPeriod   = errorsmod.Register(ModuleName, 3, "invalid trusting period")
	ErrInvalidUnbondingPeriod  = errorsmod.Register(ModuleName, 4, "invalid unbonding period")
	ErrInvalidHeaderHeight     = errorsmod.Register(ModuleName, 5, "invalid header height")
	ErrInvalidHeader           = errorsmod.Register(ModuleName, 6, "invalid header")
	ErrInvalidMaxClockDrift    = errorsmod.Register(ModuleName, 7, "invalid max clock drift")
	ErrProcessedTimeNotFound   = errorsmod.Register(ModuleName, 8, "processed time not found")
	ErrProcessedHeightNotFound = errorsmod.Register(ModuleName, 9, "processed height not found")
	ErrDelayPeriodNotPassed    = errorsmod.Register(ModuleName, 10, "packet-specified delay period has not been reached")
	ErrTrustingPeriodExpired   = errorsmod.Register(ModuleName, 11, "time since latest trusted state has passed the trusting period")
	ErrUnbondingPeriodExpired  = errorsmod.Register(ModuleName, 12, "time since latest trusted state has passed the unbonding period")
	ErrInvalidProofSpecs       = errorsmod.Register(ModuleName, 13, "invalid proof specs")
	ErrInvalidValidatorSet     = errorsmod.Register(ModuleName, 14, "invalid validator set")
)

IBC tendermint client sentinel errors

View Source
var (
	// KeyProcessedTime is appended to consensus state key to store the processed time
	KeyProcessedTime = []byte("/processedTime")
	// KeyProcessedHeight is appended to consensus state key to store the processed height
	KeyProcessedHeight = []byte("/processedHeight")
	// KeyIteration stores the key mapping to consensus state key for efficient iteration
	KeyIteration = []byte("/iterationKey")
)
View Source
var (
	ErrInvalidLengthTendermint        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowTendermint          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupTendermint = fmt.Errorf("proto: unexpected end of group")
)

DefaultTrustLevel is the tendermint light client default trust level

View Source
var FrozenHeight = clienttypes.NewHeight(0, 1)

FrozenHeight is same for all misbehaviour

Functions

func GetHeightFromIterationKey added in v0.1.4

func GetHeightFromIterationKey(iterKey []byte) exported.Height

GetHeightFromIterationKey takes an iteration key and returns the height that it references

func GetIterationKey added in v0.1.4

func GetIterationKey(clientStore sdk.KVStore, height exported.Height) []byte

GetIterationKey returns the consensus state key stored under the efficient iteration key. NOTE: This function is currently only used for testing purposes

func GetProcessedHeight added in v0.1.4

func GetProcessedHeight(clientStore sdk.KVStore, height exported.Height) (exported.Height, bool)

GetProcessedHeight gets the height at which this chain received and processed a tendermint header. This is used to validate that a received packet has passed the block delay period.

func GetProcessedTime added in v0.1.4

func GetProcessedTime(clientStore sdk.KVStore, height exported.Height) (uint64, bool)

GetProcessedTime gets the time (in nanoseconds) at which this chain received and processed a tendermint header. This is used to validate that a received packet has passed the time delay period.

func IsMatchingClientState added in v0.1.4

func IsMatchingClientState(subject, substitute ClientState) bool

IsMatchingClientState returns true if all the client state parameters match except for frozen height, latest height, trusting period, chain-id.

func IterateConsensusMetadata added in v0.1.4

func IterateConsensusMetadata(store sdk.KVStore, cb func(key, val []byte) bool)

IterateConsensusMetadata iterates through the prefix store and applies the callback. If the cb returns true, then iterator will close and stop.

func IterateConsensusStateAscending added in v0.1.4

func IterateConsensusStateAscending(clientStore sdk.KVStore, cb func(height exported.Height) (stop bool))

IterateConsensusStateAscending iterates through the consensus states in ascending order. It calls the provided callback on each height, until stop=true is returned.

func IterationKey added in v0.1.4

func IterationKey(height exported.Height) []byte

IterationKey returns the key under which the consensus state key will be stored. The iteration key is a BigEndian representation of the consensus state key to support efficient iteration.

func ProcessedHeightKey added in v0.1.4

func ProcessedHeightKey(height exported.Height) []byte

ProcessedHeightKey returns the key under which the processed height will be stored in the client store.

func ProcessedTimeKey added in v0.1.4

func ProcessedTimeKey(height exported.Height) []byte

ProcessedTimeKey returns the key under which the processed time will be stored in the client store.

func PruneAllExpiredConsensusStates added in v0.1.4

func PruneAllExpiredConsensusStates(
	ctx sdk.Context, clientStore sdk.KVStore,
	cdc codec.BinaryCodec, clientState *ClientState,
) int

PruneAllExpiredConsensusStates iterates over all consensus states for a given client store. If a consensus state is expired, it is deleted and its metadata is deleted. The number of consensus states pruned is returned.

func RegisterInterfaces added in v0.1.4

func RegisterInterfaces(registry codectypes.InterfaceRegistry)

RegisterInterfaces registers the tendermint concrete client-related implementations and interfaces.

func SetIterationKey added in v0.1.4

func SetIterationKey(clientStore sdk.KVStore, height exported.Height)

SetIterationKey stores the consensus state key under a key that is more efficient for ordered iteration

func SetProcessedHeight added in v0.1.4

func SetProcessedHeight(clientStore sdk.KVStore, consHeight, processedHeight exported.Height)

SetProcessedHeight stores the height at which a header was processed and the corresponding consensus state was created. This is useful when validating whether a packet has reached the specified block delay period in the tendermint client's verification functions

func SetProcessedTime added in v0.1.4

func SetProcessedTime(clientStore sdk.KVStore, height exported.Height, timeNs uint64)

SetProcessedTime stores the time at which a header was processed and the corresponding consensus state was created. This is useful when validating whether a packet has reached the time specified delay period in the tendermint client's verification functions

Types

type AppModuleBasic added in v0.1.4

type AppModuleBasic struct{}

AppModuleBasic defines the basic application module used by the tendermint light client. Only the RegisterInterfaces function needs to be implemented. All other function perform a no-op.

func (AppModuleBasic) DefaultGenesis added in v0.1.4

func (AppModuleBasic) DefaultGenesis(cdc codec.JSONCodec) json.RawMessage

DefaultGenesis performs a no-op. Genesis is not supported for the tendermint light client.

func (AppModuleBasic) GetQueryCmd added in v0.1.4

func (AppModuleBasic) GetQueryCmd() *cobra.Command

GetQueryCmd performs a no-op. Please see the 02-client cli commands.

func (AppModuleBasic) GetTxCmd added in v0.1.4

func (AppModuleBasic) GetTxCmd() *cobra.Command

GetTxCmd performs a no-op. Please see the 02-client cli commands.

func (AppModuleBasic) Name added in v0.1.4

func (AppModuleBasic) Name() string

Name returns the tendermint module name.

func (AppModuleBasic) RegisterGRPCGatewayRoutes added in v0.1.4

func (AppModuleBasic) RegisterGRPCGatewayRoutes(clientCtx client.Context, mux *runtime.ServeMux)

RegisterGRPCGatewayRoutes performs a no-op.

func (AppModuleBasic) RegisterInterfaces added in v0.1.4

func (AppModuleBasic) RegisterInterfaces(registry codectypes.InterfaceRegistry)

RegisterInterfaces registers module concrete types into protobuf Any. This allows core IBC to unmarshal tendermint light client types.

func (AppModuleBasic) RegisterLegacyAminoCodec added in v0.1.4

func (AppModuleBasic) RegisterLegacyAminoCodec(*codec.LegacyAmino)

RegisterLegacyAminoCodec performs a no-op. The Tendermint client does not support amino.

func (AppModuleBasic) ValidateGenesis added in v0.1.4

func (AppModuleBasic) ValidateGenesis(cdc codec.JSONCodec, config client.TxEncodingConfig, bz json.RawMessage) error

ValidateGenesis performs a no-op. Genesis is not supported for the tendermint light cilent.

type ClientState added in v0.1.4

type ClientState struct {
	ChainId    string   `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"`
	TrustLevel Fraction `protobuf:"bytes,2,opt,name=trust_level,json=trustLevel,proto3" json:"trust_level"`
	// duration of the period since the LastestTimestamp during which the
	// submitted headers are valid for upgrade
	TrustingPeriod time.Duration `protobuf:"bytes,3,opt,name=trusting_period,json=trustingPeriod,proto3,stdduration" json:"trusting_period"`
	// duration of the staking unbonding period
	UnbondingPeriod time.Duration `protobuf:"bytes,4,opt,name=unbonding_period,json=unbondingPeriod,proto3,stdduration" json:"unbonding_period"`
	// defines how much new (untrusted) header's Time can drift into the future.
	MaxClockDrift time.Duration `protobuf:"bytes,5,opt,name=max_clock_drift,json=maxClockDrift,proto3,stdduration" json:"max_clock_drift"`
	// Block height when the client was frozen due to a misbehaviour
	FrozenHeight types.Height `protobuf:"bytes,6,opt,name=frozen_height,json=frozenHeight,proto3" json:"frozen_height"`
	// Latest height the client was updated to
	LatestHeight types.Height `protobuf:"bytes,7,opt,name=latest_height,json=latestHeight,proto3" json:"latest_height"`
	// Proof specifications used in verifying counterparty state
	ProofSpecs []*_go.ProofSpec `protobuf:"bytes,8,rep,name=proof_specs,json=proofSpecs,proto3" json:"proof_specs,omitempty"`
	// Path at which next upgraded client will be committed.
	// Each element corresponds to the key for a single CommitmentProof in the
	// chained proof. NOTE: ClientState must stored under
	// `{upgradePath}/{upgradeHeight}/clientState` ConsensusState must be stored
	// under `{upgradepath}/{upgradeHeight}/consensusState` For SDK chains using
	// the default upgrade module, upgrade_path should be []string{"upgrade",
	// "upgradedIBCState"}`
	UpgradePath []string `protobuf:"bytes,9,rep,name=upgrade_path,json=upgradePath,proto3" json:"upgrade_path,omitempty"`
	// allow_update_after_expiry is deprecated
	AllowUpdateAfterExpiry bool `` // Deprecated: Do not use.
	/* 133-byte string literal not displayed */
	// allow_update_after_misbehaviour is deprecated
	AllowUpdateAfterMisbehaviour bool `` // Deprecated: Do not use.
	/* 151-byte string literal not displayed */
}

ClientState from Tendermint tracks the current validator set, latest height, and a possible frozen height.

func NewClientState added in v0.1.4

func NewClientState(
	chainID string, trustLevel Fraction,
	trustingPeriod, ubdPeriod, maxClockDrift time.Duration,
	latestHeight clienttypes.Height, specs []*ics23.ProofSpec,
	upgradePath []string,
) *ClientState

NewClientState creates a new ClientState instance

func (ClientState) CheckForMisbehaviour added in v0.1.4

func (cs ClientState) CheckForMisbehaviour(ctx sdk.Context, cdc codec.BinaryCodec, clientStore sdk.KVStore, msg exported.ClientMessage) bool

CheckForMisbehaviour detects duplicate height misbehaviour and BFT time violation misbehaviour in a submitted Header message and verifies the correctness of a submitted Misbehaviour ClientMessage

func (ClientState) CheckSubstituteAndUpdateState added in v0.1.4

func (cs ClientState) CheckSubstituteAndUpdateState(
	ctx sdk.Context, cdc codec.BinaryCodec, subjectClientStore,
	substituteClientStore sdk.KVStore, substituteClient exported.ClientState,
) error

CheckSubstituteAndUpdateState will try to update the client with the state of the substitute.

AllowUpdateAfterMisbehaviour and AllowUpdateAfterExpiry have been deprecated. Please see ADR 026 for more information.

The following must always be true:

  • The substitute client is the same type as the subject client
  • The subject and substitute client states match in all parameters (expect frozen height, latest height, and chain-id)

In case 1) before updating the client, the client will be unfrozen by resetting the FrozenHeight to the zero Height.

func (ClientState) ClientType added in v0.1.4

func (cs ClientState) ClientType() string

ClientType is tendermint.

func (*ClientState) Descriptor added in v0.1.4

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

func (ClientState) ExportMetadata added in v0.1.4

func (cs ClientState) ExportMetadata(store sdk.KVStore) []exported.GenesisMetadata

ExportMetadata exports all the consensus metadata in the client store so they can be included in clients genesis and imported by a ClientKeeper

func (ClientState) GetChainID added in v0.1.4

func (cs ClientState) GetChainID() string

GetChainID returns the chain-id

func (ClientState) GetLatestHeight added in v0.1.4

func (cs ClientState) GetLatestHeight() exported.Height

GetLatestHeight returns latest block height.

func (ClientState) GetProofSpecs added in v0.1.4

func (cs ClientState) GetProofSpecs() []*ics23.ProofSpec

GetProofSpecs returns the format the client expects for proof verification as a string array specifying the proof type for each position in chained proof

func (ClientState) GetTimestampAtHeight added in v0.1.4

func (cs ClientState) GetTimestampAtHeight(
	ctx sdk.Context,
	clientStore sdk.KVStore,
	cdc codec.BinaryCodec,
	height exported.Height,
) (uint64, error)

GetTimestampAtHeight returns the timestamp in nanoseconds of the consensus state at the given height.

func (ClientState) Initialize added in v0.1.4

func (cs ClientState) Initialize(ctx sdk.Context, cdc codec.BinaryCodec, clientStore sdk.KVStore, consState exported.ConsensusState) error

Initialize checks that the initial consensus state is an 07-tendermint consensus state and sets the client state, consensus state and associated metadata in the provided client store.

func (ClientState) IsExpired added in v0.1.4

func (cs ClientState) IsExpired(latestTimestamp, now time.Time) bool

IsExpired returns whether or not the client has passed the trusting period since the last update (in which case no headers are considered valid).

func (*ClientState) Marshal added in v0.1.4

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

func (*ClientState) MarshalTo added in v0.1.4

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

func (*ClientState) MarshalToSizedBuffer added in v0.1.4

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

func (*ClientState) ProtoMessage added in v0.1.4

func (*ClientState) ProtoMessage()

func (*ClientState) Reset added in v0.1.4

func (m *ClientState) Reset()

func (*ClientState) Size added in v0.1.4

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

func (ClientState) Status added in v0.1.4

func (cs ClientState) Status(
	ctx sdk.Context,
	clientStore sdk.KVStore,
	cdc codec.BinaryCodec,
) exported.Status

Status returns the status of the tendermint client. The client may be: - Active: FrozenHeight is zero and client is not expired - Frozen: Frozen Height is not zero - Expired: the latest consensus state timestamp + trusting period <= current time

A frozen client will become expired, so the Frozen status has higher precedence.

func (*ClientState) String added in v0.1.4

func (m *ClientState) String() string

func (*ClientState) Unmarshal added in v0.1.4

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

func (ClientState) UpdateState added in v0.1.4

func (cs ClientState) UpdateState(ctx sdk.Context, cdc codec.BinaryCodec, clientStore sdk.KVStore, clientMsg exported.ClientMessage) []exported.Height

UpdateState may be used to either create a consensus state for: - a future height greater than the latest client state height - a past height that was skipped during bisection If we are updating to a past height, a consensus state is created for that height to be persisted in client store If we are updating to a future height, the consensus state is created and the client state is updated to reflect the new latest height A list containing the updated consensus height is returned. UpdateState must only be used to update within a single revision, thus header revision number and trusted height's revision number must be the same. To update to a new revision, use a separate upgrade path UpdateState will prune the oldest consensus state if it is expired.

func (ClientState) UpdateStateOnMisbehaviour added in v0.1.4

func (cs ClientState) UpdateStateOnMisbehaviour(ctx sdk.Context, cdc codec.BinaryCodec, clientStore sdk.KVStore, _ exported.ClientMessage)

UpdateStateOnMisbehaviour updates state upon misbehaviour, freezing the ClientState. This method should only be called when misbehaviour is detected as it does not perform any misbehaviour checks.

func (ClientState) Validate added in v0.1.4

func (cs ClientState) Validate() error

Validate performs a basic validation of the client state fields.

func (*ClientState) VerifyClientMessage added in v0.1.4

func (cs *ClientState) VerifyClientMessage(
	ctx sdk.Context, cdc codec.BinaryCodec, clientStore sdk.KVStore,
	clientMsg exported.ClientMessage,
) error

VerifyClientMessage checks if the clientMessage is of type Header or Misbehaviour and verifies the message

func (ClientState) VerifyMembership added in v0.1.4

func (cs ClientState) VerifyMembership(
	ctx sdk.Context,
	clientStore sdk.KVStore,
	cdc codec.BinaryCodec,
	height exported.Height,
	delayTimePeriod uint64,
	delayBlockPeriod uint64,
	proof []byte,
	path exported.Path,
	value []byte,
) error

VerifyMembership is a generic proof verification method which verifies a proof of the existence of a value at a given CommitmentPath at the specified height. The caller is expected to construct the full CommitmentPath from a CommitmentPrefix and a standardized path (as defined in ICS 24). If a zero proof height is passed in, it will fail to retrieve the associated consensus state.

func (ClientState) VerifyNonMembership added in v0.1.4

func (cs ClientState) VerifyNonMembership(
	ctx sdk.Context,
	clientStore sdk.KVStore,
	cdc codec.BinaryCodec,
	height exported.Height,
	delayTimePeriod uint64,
	delayBlockPeriod uint64,
	proof []byte,
	path exported.Path,
) error

VerifyNonMembership is a generic proof verification method which verifies the absence of a given CommitmentPath at a specified height. The caller is expected to construct the full CommitmentPath from a CommitmentPrefix and a standardized path (as defined in ICS 24). If a zero proof height is passed in, it will fail to retrieve the associated consensus state.

func (ClientState) VerifyUpgradeAndUpdateState added in v0.1.4

func (cs ClientState) VerifyUpgradeAndUpdateState(
	ctx sdk.Context, cdc codec.BinaryCodec, clientStore sdk.KVStore,
	upgradedClient exported.ClientState, upgradedConsState exported.ConsensusState,
	proofUpgradeClient, proofUpgradeConsState []byte,
) error

VerifyUpgradeAndUpdateState checks if the upgraded client has been committed by the current client It will zero out all client-specific fields (e.g. TrustingPeriod) and verify all data in client state that must be the same across all valid Tendermint clients for the new chain. VerifyUpgrade will return an error if: - the upgradedClient is not a Tendermint ClientState - the latest height of the client state does not have the same revision number or has a greater height than the committed client.

  • the height of upgraded client is not greater than that of current client
  • the latest height of the new client does not match or is greater than the height in committed client
  • any Tendermint chain specified parameter in upgraded client such as ChainID, UnbondingPeriod, and ProofSpecs do not match parameters set by committed client

func (*ClientState) XXX_DiscardUnknown added in v0.1.4

func (m *ClientState) XXX_DiscardUnknown()

func (*ClientState) XXX_Marshal added in v0.1.4

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

func (*ClientState) XXX_Merge added in v0.1.4

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

func (*ClientState) XXX_Size added in v0.1.4

func (m *ClientState) XXX_Size() int

func (*ClientState) XXX_Unmarshal added in v0.1.4

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

func (ClientState) ZeroCustomFields added in v0.1.4

func (cs ClientState) ZeroCustomFields() exported.ClientState

ZeroCustomFields returns a ClientState that is a copy of the current ClientState with all client customizable fields zeroed out

type ConsensusState added in v0.1.4

type ConsensusState struct {
	// timestamp that corresponds to the block height in which the ConsensusState
	// was stored.
	Timestamp time.Time `protobuf:"bytes,1,opt,name=timestamp,proto3,stdtime" json:"timestamp"`
	// commitment root (i.e app hash)
	Root               types1.MerkleRoot                                `protobuf:"bytes,2,opt,name=root,proto3" json:"root"`
	NextValidatorsHash github_com_cometbft_cometbft_libs_bytes.HexBytes `` /* 175-byte string literal not displayed */
}

ConsensusState defines the consensus state from Tendermint.

func GetConsensusState added in v0.1.4

func GetConsensusState(store sdk.KVStore, cdc codec.BinaryCodec, height exported.Height) (*ConsensusState, bool)

GetConsensusState retrieves the consensus state from the client prefixed store. If the ConsensusState does not exist in state for the provided height a nil value and false boolean flag is returned

func GetNextConsensusState added in v0.1.4

func GetNextConsensusState(clientStore sdk.KVStore, cdc codec.BinaryCodec, height exported.Height) (*ConsensusState, bool)

GetNextConsensusState returns the lowest consensus state that is larger than the given height. The Iterator returns a storetypes.Iterator which iterates from start (inclusive) to end (exclusive). If the starting height exists in store, we need to call iterator.Next() to get the next consenus state. Otherwise, the iterator is already at the next consensus state so we can call iterator.Value() immediately.

func GetPreviousConsensusState added in v0.1.4

func GetPreviousConsensusState(clientStore sdk.KVStore, cdc codec.BinaryCodec, height exported.Height) (*ConsensusState, bool)

GetPreviousConsensusState returns the highest consensus state that is lower than the given height. The Iterator returns a storetypes.Iterator which iterates from the end (exclusive) to start (inclusive). Thus to get previous consensus state we call iterator.Value() immediately.

func NewConsensusState added in v0.1.4

func NewConsensusState(
	timestamp time.Time, root commitmenttypes.MerkleRoot, nextValsHash tmbytes.HexBytes,
) *ConsensusState

NewConsensusState creates a new ConsensusState instance.

func (ConsensusState) ClientType added in v0.1.4

func (ConsensusState) ClientType() string

ClientType returns Tendermint

func (*ConsensusState) Descriptor added in v0.1.4

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

func (ConsensusState) GetRoot added in v0.1.4

func (cs ConsensusState) GetRoot() exported.Root

GetRoot returns the commitment Root for the specific

func (ConsensusState) GetTimestamp added in v0.1.4

func (cs ConsensusState) GetTimestamp() uint64

GetTimestamp returns block time in nanoseconds of the header that created consensus state

func (*ConsensusState) Marshal added in v0.1.4

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

func (*ConsensusState) MarshalTo added in v0.1.4

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

func (*ConsensusState) MarshalToSizedBuffer added in v0.1.4

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

func (*ConsensusState) ProtoMessage added in v0.1.4

func (*ConsensusState) ProtoMessage()

func (*ConsensusState) Reset added in v0.1.4

func (m *ConsensusState) Reset()

func (*ConsensusState) Size added in v0.1.4

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

func (*ConsensusState) String added in v0.1.4

func (m *ConsensusState) String() string

func (*ConsensusState) Unmarshal added in v0.1.4

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

func (ConsensusState) ValidateBasic added in v0.1.4

func (cs ConsensusState) ValidateBasic() error

ValidateBasic defines a basic validation for the tendermint consensus state. NOTE: ProcessedTimestamp may be zero if this is an initial consensus state passed in by relayer as opposed to a consensus state constructed by the chain.

func (*ConsensusState) XXX_DiscardUnknown added in v0.1.4

func (m *ConsensusState) XXX_DiscardUnknown()

func (*ConsensusState) XXX_Marshal added in v0.1.4

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

func (*ConsensusState) XXX_Merge added in v0.1.4

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

func (*ConsensusState) XXX_Size added in v0.1.4

func (m *ConsensusState) XXX_Size() int

func (*ConsensusState) XXX_Unmarshal added in v0.1.4

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

type Fraction added in v0.1.4

type Fraction struct {
	Numerator   uint64 `protobuf:"varint,1,opt,name=numerator,proto3" json:"numerator,omitempty"`
	Denominator uint64 `protobuf:"varint,2,opt,name=denominator,proto3" json:"denominator,omitempty"`
}

Fraction defines the protobuf message type for tmmath.Fraction that only supports positive values.

func NewFractionFromTm added in v0.1.4

func NewFractionFromTm(f tmmath.Fraction) Fraction

NewFractionFromTm returns a new Fraction instance from a tmmath.Fraction

func (*Fraction) Descriptor added in v0.1.4

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

func (*Fraction) GetDenominator added in v0.1.4

func (m *Fraction) GetDenominator() uint64

func (*Fraction) GetNumerator added in v0.1.4

func (m *Fraction) GetNumerator() uint64

func (*Fraction) Marshal added in v0.1.4

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

func (*Fraction) MarshalTo added in v0.1.4

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

func (*Fraction) MarshalToSizedBuffer added in v0.1.4

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

func (*Fraction) ProtoMessage added in v0.1.4

func (*Fraction) ProtoMessage()

func (*Fraction) Reset added in v0.1.4

func (m *Fraction) Reset()

func (*Fraction) Size added in v0.1.4

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

func (*Fraction) String added in v0.1.4

func (m *Fraction) String() string

func (Fraction) ToTendermint added in v0.1.4

func (f Fraction) ToTendermint() tmmath.Fraction

ToTendermint converts Fraction to tmmath.Fraction

func (*Fraction) Unmarshal added in v0.1.4

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

func (*Fraction) XXX_DiscardUnknown added in v0.1.4

func (m *Fraction) XXX_DiscardUnknown()

func (*Fraction) XXX_Marshal added in v0.1.4

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

func (*Fraction) XXX_Merge added in v0.1.4

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

func (*Fraction) XXX_Size added in v0.1.4

func (m *Fraction) XXX_Size() int

func (*Fraction) XXX_Unmarshal added in v0.1.4

func (m *Fraction) XXX_Unmarshal(b []byte) error
type Header struct {
	*types2.SignedHeader `protobuf:"bytes,1,opt,name=signed_header,json=signedHeader,proto3,embedded=signed_header" json:"signed_header,omitempty"`
	ValidatorSet         *types2.ValidatorSet `protobuf:"bytes,2,opt,name=validator_set,json=validatorSet,proto3" json:"validator_set,omitempty"`
	TrustedHeight        types.Height         `protobuf:"bytes,3,opt,name=trusted_height,json=trustedHeight,proto3" json:"trusted_height"`
	TrustedValidators    *types2.ValidatorSet `protobuf:"bytes,4,opt,name=trusted_validators,json=trustedValidators,proto3" json:"trusted_validators,omitempty"`
}

Header defines the Tendermint client consensus Header. It encapsulates all the information necessary to update from a trusted Tendermint ConsensusState. The inclusion of TrustedHeight and TrustedValidators allows this update to process correctly, so long as the ConsensusState for the TrustedHeight exists, this removes race conditions among relayers The SignedHeader and ValidatorSet are the new untrusted update fields for the client. The TrustedHeight is the height of a stored ConsensusState on the client that will be used to verify the new untrusted header. The Trusted ConsensusState must be within the unbonding period of current time in order to correctly verify, and the TrustedValidators must hash to TrustedConsensusState.NextValidatorsHash since that is the last trusted validator set at the TrustedHeight.

func (Header) ClientType added in v0.1.4

func (h Header) ClientType() string

ClientType defines that the Header is a Tendermint consensus algorithm

func (Header) ConsensusState added in v0.1.4

func (h Header) ConsensusState() *ConsensusState

ConsensusState returns the updated consensus state associated with the header

func (*Header) Descriptor added in v0.1.4

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

func (Header) GetHeight added in v0.1.4

func (h Header) GetHeight() exported.Height

GetHeight returns the current height. It returns 0 if the tendermint header is nil. NOTE: the header.Header is checked to be non nil in ValidateBasic.

func (Header) GetTime added in v0.1.4

func (h Header) GetTime() time.Time

GetTime returns the current block timestamp. It returns a zero time if the tendermint header is nil. NOTE: the header.Header is checked to be non nil in ValidateBasic.

func (*Header) GetTrustedHeight added in v0.1.4

func (m *Header) GetTrustedHeight() types.Height

func (*Header) GetTrustedValidators added in v0.1.4

func (m *Header) GetTrustedValidators() *types2.ValidatorSet

func (*Header) GetValidatorSet added in v0.1.4

func (m *Header) GetValidatorSet() *types2.ValidatorSet

func (*Header) Marshal added in v0.1.4

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

func (*Header) MarshalTo added in v0.1.4

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

func (*Header) MarshalToSizedBuffer added in v0.1.4

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

func (*Header) ProtoMessage added in v0.1.4

func (*Header) ProtoMessage()

func (*Header) Reset added in v0.1.4

func (m *Header) Reset()

func (*Header) Size added in v0.1.4

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

func (*Header) String added in v0.1.4

func (m *Header) String() string

func (*Header) Unmarshal added in v0.1.4

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

func (Header) ValidateBasic added in v0.1.4

func (h Header) ValidateBasic() error

ValidateBasic calls the SignedHeader ValidateBasic function and checks that validatorsets are not nil. NOTE: TrustedHeight and TrustedValidators may be empty when creating client with MsgCreateClient

func (*Header) XXX_DiscardUnknown added in v0.1.4

func (m *Header) XXX_DiscardUnknown()

func (*Header) XXX_Marshal added in v0.1.4

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

func (*Header) XXX_Merge added in v0.1.4

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

func (*Header) XXX_Size added in v0.1.4

func (m *Header) XXX_Size() int

func (*Header) XXX_Unmarshal added in v0.1.4

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

type Misbehaviour added in v0.1.4

type Misbehaviour struct {
	// ClientID is deprecated
	ClientId string  `protobuf:"bytes,1,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"` // Deprecated: Do not use.
	Header1  *Header `protobuf:"bytes,2,opt,name=header_1,json=header1,proto3" json:"header_1,omitempty"`
	Header2  *Header `protobuf:"bytes,3,opt,name=header_2,json=header2,proto3" json:"header_2,omitempty"`
}

Misbehaviour is a wrapper over two conflicting Headers that implements Misbehaviour interface expected by ICS-02

func NewMisbehaviour added in v0.1.4

func NewMisbehaviour(clientID string, header1, header2 *Header) *Misbehaviour

NewMisbehaviour creates a new Misbehaviour instance.

func (Misbehaviour) ClientType added in v0.1.4

func (misbehaviour Misbehaviour) ClientType() string

ClientType is Tendermint light client

func (*Misbehaviour) Descriptor added in v0.1.4

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

func (Misbehaviour) GetTime added in v0.1.4

func (misbehaviour Misbehaviour) GetTime() time.Time

GetTime returns the timestamp at which misbehaviour occurred. It uses the maximum value from both headers to prevent producing an invalid header outside of the misbehaviour age range.

func (*Misbehaviour) Marshal added in v0.1.4

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

func (*Misbehaviour) MarshalTo added in v0.1.4

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

func (*Misbehaviour) MarshalToSizedBuffer added in v0.1.4

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

func (*Misbehaviour) ProtoMessage added in v0.1.4

func (*Misbehaviour) ProtoMessage()

func (*Misbehaviour) Reset added in v0.1.4

func (m *Misbehaviour) Reset()

func (*Misbehaviour) Size added in v0.1.4

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

func (*Misbehaviour) String added in v0.1.4

func (m *Misbehaviour) String() string

func (*Misbehaviour) Unmarshal added in v0.1.4

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

func (Misbehaviour) ValidateBasic added in v0.1.4

func (misbehaviour Misbehaviour) ValidateBasic() error

ValidateBasic implements Misbehaviour interface

func (*Misbehaviour) XXX_DiscardUnknown added in v0.1.4

func (m *Misbehaviour) XXX_DiscardUnknown()

func (*Misbehaviour) XXX_Marshal added in v0.1.4

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

func (*Misbehaviour) XXX_Merge added in v0.1.4

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

func (*Misbehaviour) XXX_Size added in v0.1.4

func (m *Misbehaviour) XXX_Size() int

func (*Misbehaviour) XXX_Unmarshal added in v0.1.4

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

Directories

Path Synopsis

Jump to

Keyboard shortcuts

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