Versions in this module Expand all Collapse all v100 v100.2.4 Sep 4, 2024 v100.2.3 Sep 4, 2024 v100.2.2 Sep 4, 2024 v100.2.1 Sep 4, 2024 v100.2.0 Sep 4, 2024 v100.1.0 Sep 3, 2024 v100.0.4 Sep 3, 2024 v100.0.3 Sep 3, 2024 v100.0.2 Sep 3, 2024 v100.0.1 Sep 3, 2024 v100.0.0 Sep 3, 2024 Changes in this version + const ABCIPubKeyTypeBls12381 + const ABCIPubKeyTypeEd25519 + const ABCIPubKeyTypeSecp256k1 + const BlockHeightKey + const BlockPartSizeBytes + const EventCompleteProposal + const EventLock + const EventNewBlock + const EventNewBlockEvents + const EventNewBlockHeader + const EventNewEvidence + const EventNewRound + const EventNewRoundStep + const EventPolka + const EventProposalBlockPart + const EventRelock + const EventTimeoutPropose + const EventTimeoutWait + const EventTx + const EventTypeKey + const EventValidBlock + const EventValidatorSetUpdates + const EventVote + const MaxBlockPartsCount + const MaxBlockSizeBytes + const MaxChainIDLen + const MaxCommitOverheadBytes + const MaxCommitSigBytes + const MaxHeaderBytes + const MaxOverheadForBlock + const MaxTotalVotingPower + const MaxVoteExtensionSize + const MaxVotesCount + const PriorityWindowSizeFactor + const TimeFormat + const TxHashKey + const TxHeightKey + const TxKeySize + var ABCIPubKeyTypesToNames = map[string]string + var ErrInvalidBlockPartHash = errors.New("error invalid block part hash") + var ErrInvalidBlockPartSignature = errors.New("error invalid block part signature") + var ErrInvalidVoteExtension = errors.New("invalid vote extension") + var ErrPartInvalidSize = errors.New("error inner part with invalid size") + var ErrPartSetInvalidProof = errors.New("error part set invalid proof") + var ErrPartSetUnexpectedIndex = errors.New("error part set unexpected index") + var ErrPartTooBig = errors.New("error part size too big") + var ErrTotalVotingPowerOverflow = fmt.Errorf("total voting power of resulting valset exceeds max %d", MaxTotalVotingPower) + var ErrVoteExtensionAbsent = errors.New("vote extension absent") + var ErrVoteInvalidBlockHash = errors.New("invalid block hash") + var ErrVoteInvalidSignature = errors.New("invalid signature") + var ErrVoteInvalidValidatorAddress = errors.New("invalid validator address") + var ErrVoteInvalidValidatorIndex = errors.New("invalid validator index") + var ErrVoteNil = errors.New("nil vote") + var ErrVoteNoSignature = errors.New("no signature") + var ErrVoteNonDeterministicSignature = errors.New("non-deterministic signature") + var ErrVoteUnexpectedStep = errors.New("unexpected step") + var ErroringMockPVErr = errors.New("erroringMockPV always returns an error") + var EventQueryCompleteProposal = QueryForEvent(EventCompleteProposal) + var EventQueryLock = QueryForEvent(EventLock) + var EventQueryNewBlock = QueryForEvent(EventNewBlock) + var EventQueryNewBlockEvents = QueryForEvent(EventNewBlockEvents) + var EventQueryNewBlockHeader = QueryForEvent(EventNewBlockHeader) + var EventQueryNewEvidence = QueryForEvent(EventNewEvidence) + var EventQueryNewRound = QueryForEvent(EventNewRound) + var EventQueryNewRoundStep = QueryForEvent(EventNewRoundStep) + var EventQueryPolka = QueryForEvent(EventPolka) + var EventQueryRelock = QueryForEvent(EventRelock) + var EventQueryTimeoutPropose = QueryForEvent(EventTimeoutPropose) + var EventQueryTimeoutWait = QueryForEvent(EventTimeoutWait) + var EventQueryTx = QueryForEvent(EventTx) + var EventQueryValidBlock = QueryForEvent(EventValidBlock) + var EventQueryValidatorSetUpdates = QueryForEvent(EventValidatorSetUpdates) + var EventQueryVote = QueryForEvent(EventVote) + var MaxSignatureSize = cmtmath.MaxInt(ed25519.SignatureSize, cmtmath.MaxInt(bls12381.SignatureLength, 64)) + var PB2TM = pb2tm + var PeerStateKey = "ConsensusReactor.peerState" + var TM2PB = tm2pb + func CanonicalTime(t time.Time) string + func CanonicalizeBlockID(bid cmtproto.BlockID) *cmtproto.CanonicalBlockID + func CanonicalizePartSetHeader(psh cmtproto.PartSetHeader) cmtproto.CanonicalPartSetHeader + func CanonicalizeProposal(chainID string, proposal *cmtproto.Proposal) cmtproto.CanonicalProposal + func CanonicalizeVote(chainID string, vote *cmtproto.Vote) cmtproto.CanonicalVote + func CanonicalizeVoteExtension(chainID string, vote *cmtproto.Vote) cmtproto.CanonicalVoteExtension + func ComputeProtoSizeForTxs(txs []Tx) int64 + func EventQueryTxFor(tx Tx) cmtpubsub.Query + func EvidenceToProto(evidence Evidence) (*cmtproto.Evidence, error) + func IsErrNotEnoughVotingPowerSigned(err error) bool + func IsValidPubkeyType(params ValidatorParams, pubkeyType string) bool + func IsVoteTypeValid(t SignedMsgType) bool + func MaxCommitBytes(valCount int) int64 + func MaxDataBytes(maxBytes, evidenceBytes int64, valsCount int) int64 + func MaxDataBytesNoEvidence(maxBytes int64, valsCount int) int64 + func ProposalSignBytes(chainID string, p *cmtproto.Proposal) []byte + func ProtoBlockIDIsNil(bID *cmtproto.BlockID) bool + func ProtoPartSetHeaderIsZero(ppsh *cmtproto.PartSetHeader) bool + func QueryForEvent(eventType string) cmtpubsub.Query + func RandValidator(randPower bool, minPower int64) (*Validator, PrivValidator) + func RandValidatorSet(numValidators int, votingPower int64) (*ValidatorSet, []PrivValidator) + func SignAndCheckVote(vote *Vote, privVal PrivValidator, chainID string, extensionsEnabled bool) (bool, error) + func SignedMsgTypeToShortString(t SignedMsgType) string + func ValidateHash(h []byte) error + func ValidatorListString(vals []*Validator) string + func VerifyCommit(chainID string, vals *ValidatorSet, blockID BlockID, height int64, ...) error + func VerifyCommitLight(chainID string, vals *ValidatorSet, blockID BlockID, height int64, ...) error + func VerifyCommitLightAllSignatures(chainID string, vals *ValidatorSet, blockID BlockID, height int64, ...) error + func VerifyCommitLightTrusting(chainID string, vals *ValidatorSet, commit *Commit, ...) error + func VerifyCommitLightTrustingAllSignatures(chainID string, vals *ValidatorSet, commit *Commit, ...) error + func VoteExtensionSignBytes(chainID string, vote *cmtproto.Vote) []byte + func VoteSignBytes(chainID string, vote *cmtproto.Vote) []byte + func VotesToProto(votes []*Vote) []*cmtproto.Vote + type ABCIResults []*abci.ExecTxResult + func NewResults(responses []*abci.ExecTxResult) ABCIResults + func (a ABCIResults) Hash() []byte + func (a ABCIResults) ProveResult(i int) merkle.Proof + type Address = crypto.Address + type Block struct + Evidence EvidenceData + LastCommit *Commit + func BlockFromProto(bp *cmtproto.Block) (*Block, error) + func MakeBlock(height int64, txs []Tx, lastCommit *Commit, evidence []Evidence) *Block + func (b *Block) Hash() cmtbytes.HexBytes + func (b *Block) HashesTo(hash []byte) bool + func (b *Block) MakePartSet(partSize uint32) (*PartSet, error) + func (b *Block) Size() int + func (b *Block) String() string + func (b *Block) StringIndented(indent string) string + func (b *Block) StringShort() string + func (b *Block) ToProto() (*cmtproto.Block, error) + func (b *Block) ValidateBasic() error + type BlockEventPublisher interface + PublishEventNewBlock func(block EventDataNewBlock) error + PublishEventNewBlockEvents func(events EventDataNewBlockEvents) error + PublishEventNewBlockHeader func(header EventDataNewBlockHeader) error + PublishEventNewEvidence func(evidence EventDataNewEvidence) error + PublishEventTx func(tx EventDataTx) error + PublishEventValidatorSetUpdates func(updates EventDataValidatorSetUpdates) error + type BlockID struct + Hash cmtbytes.HexBytes + PartSetHeader PartSetHeader + func BlockIDFromProto(bID *cmtproto.BlockID) (*BlockID, error) + func (blockID *BlockID) ToProto() cmtproto.BlockID + func (blockID BlockID) Equals(other BlockID) bool + func (blockID BlockID) IsComplete() bool + func (blockID BlockID) IsNil() bool + func (blockID BlockID) Key() string + func (blockID BlockID) String() string + func (blockID BlockID) ValidateBasic() error + type BlockIDFlag byte + const BlockIDFlagAbsent + const BlockIDFlagCommit + const BlockIDFlagNil + type BlockMeta struct + BlockID BlockID + BlockSize int + Header Header + NumTxs int + func BlockMetaFromTrustedProto(pb *cmtproto.BlockMeta) (*BlockMeta, error) + func NewBlockMeta(block *Block, blockParts *PartSet) *BlockMeta + func (bm *BlockMeta) ToProto() *cmtproto.BlockMeta + func (bm *BlockMeta) ValidateBasic() error + type BlockParams struct + MaxBytes int64 + MaxGas int64 + func DefaultBlockParams() BlockParams + type Commit struct + BlockID BlockID + Height int64 + Round int32 + Signatures []CommitSig + func CommitFromProto(cp *cmtproto.Commit) (*Commit, error) + func (commit *Commit) Clone() *Commit + func (commit *Commit) GetVote(valIdx int32) *Vote + func (commit *Commit) Hash() cmtbytes.HexBytes + func (commit *Commit) MedianTime(validators *ValidatorSet) time.Time + func (commit *Commit) Size() int + func (commit *Commit) StringIndented(indent string) string + func (commit *Commit) ToProto() *cmtproto.Commit + func (commit *Commit) ToVoteSet(chainID string, vals *ValidatorSet) *VoteSet + func (commit *Commit) ValidateBasic() error + func (commit *Commit) VoteSignBytes(chainID string, valIdx int32) []byte + func (commit *Commit) WrappedExtendedCommit() *ExtendedCommit + type CommitSig struct + BlockIDFlag BlockIDFlag + Signature []byte + Timestamp time.Time + ValidatorAddress Address + func NewCommitSigAbsent() CommitSig + func (cs *CommitSig) FromProto(csp cmtproto.CommitSig) error + func (cs *CommitSig) ToProto() *cmtproto.CommitSig + func (cs CommitSig) BlockID(commitBlockID BlockID) BlockID + func (cs CommitSig) String() string + func (cs CommitSig) ValidateBasic() error + type ConsensusParams struct + Block BlockParams + Evidence EvidenceParams + Feature FeatureParams + Synchrony SynchronyParams + Validator ValidatorParams + Version VersionParams + func ConsensusParamsFromProto(pbParams cmtproto.ConsensusParams) ConsensusParams + func DefaultConsensusParams() *ConsensusParams + func (params *ConsensusParams) ToProto() cmtproto.ConsensusParams + func (params ConsensusParams) Hash() []byte + func (params ConsensusParams) Update(params2 *cmtproto.ConsensusParams) ConsensusParams + func (params ConsensusParams) ValidateBasic() error + func (params ConsensusParams) ValidateUpdate(updated *cmtproto.ConsensusParams, h int64) error + type Data struct + Txs Txs + func DataFromProto(dp *cmtproto.Data) (Data, error) + func (data *Data) Hash() cmtbytes.HexBytes + func (data *Data) StringIndented(indent string) string + func (data *Data) ToProto() cmtproto.Data + type DuplicateVoteEvidence struct + Timestamp time.Time + TotalVotingPower int64 + ValidatorPower int64 + VoteA *Vote + VoteB *Vote + func DuplicateVoteEvidenceFromProto(pb *cmtproto.DuplicateVoteEvidence) (*DuplicateVoteEvidence, error) + func NewDuplicateVoteEvidence(vote1, vote2 *Vote, blockTime time.Time, valSet *ValidatorSet) (*DuplicateVoteEvidence, error) + func NewMockDuplicateVoteEvidence(height int64, time time.Time, chainID string) (*DuplicateVoteEvidence, error) + func NewMockDuplicateVoteEvidenceWithValidator(height int64, time time.Time, pv PrivValidator, chainID string) (*DuplicateVoteEvidence, error) + func (dve *DuplicateVoteEvidence) ABCI() []abci.Misbehavior + func (dve *DuplicateVoteEvidence) Bytes() []byte + func (dve *DuplicateVoteEvidence) Hash() []byte + func (dve *DuplicateVoteEvidence) Height() int64 + func (dve *DuplicateVoteEvidence) String() string + func (dve *DuplicateVoteEvidence) Time() time.Time + func (dve *DuplicateVoteEvidence) ToProto() *cmtproto.DuplicateVoteEvidence + func (dve *DuplicateVoteEvidence) ValidateBasic() error + type ErrEvidenceOverflow struct + Got int64 + Max int64 + func NewErrEvidenceOverflow(max, got int64) *ErrEvidenceOverflow + func (err *ErrEvidenceOverflow) Error() string + type ErrInvalidEvidence struct + Evidence Evidence + Reason error + func NewErrInvalidEvidence(ev Evidence, err error) *ErrInvalidEvidence + func (err *ErrInvalidEvidence) Error() string + type ErrNotEnoughVotingPowerSigned struct + Got int64 + Needed int64 + func (e ErrNotEnoughVotingPowerSigned) Error() string + type ErrVoteConflictingVotes struct + VoteA *Vote + VoteB *Vote + func NewConflictingVoteError(vote1, vote2 *Vote) *ErrVoteConflictingVotes + func (err *ErrVoteConflictingVotes) Error() string + type ErrVoteExtensionInvalid struct + ExtSignature []byte + func (err *ErrVoteExtensionInvalid) Error() string + type ErroringMockPV struct + func NewErroringMockPV() *ErroringMockPV + func (*ErroringMockPV) SignProposal(string, *cmtproto.Proposal) error + func (*ErroringMockPV) SignVote(string, *cmtproto.Vote, bool) error + type EventBus struct + func NewEventBus() *EventBus + func NewEventBusWithBufferCapacity(cap int) *EventBus + func (b *EventBus) NumClientSubscriptions(clientID string) int + func (b *EventBus) NumClients() int + func (b *EventBus) OnStart() error + func (b *EventBus) OnStop() + func (b *EventBus) Publish(eventType string, eventData TMEventData) error + func (b *EventBus) PublishEventCompleteProposal(data EventDataCompleteProposal) error + func (b *EventBus) PublishEventLock(data EventDataRoundState) error + func (b *EventBus) PublishEventNewBlock(data EventDataNewBlock) error + func (b *EventBus) PublishEventNewBlockEvents(data EventDataNewBlockEvents) error + func (b *EventBus) PublishEventNewBlockHeader(data EventDataNewBlockHeader) error + func (b *EventBus) PublishEventNewEvidence(evidence EventDataNewEvidence) error + func (b *EventBus) PublishEventNewRound(data EventDataNewRound) error + func (b *EventBus) PublishEventNewRoundStep(data EventDataRoundState) error + func (b *EventBus) PublishEventPolka(data EventDataRoundState) error + func (b *EventBus) PublishEventRelock(data EventDataRoundState) error + func (b *EventBus) PublishEventTimeoutPropose(data EventDataRoundState) error + func (b *EventBus) PublishEventTimeoutWait(data EventDataRoundState) error + func (b *EventBus) PublishEventTx(data EventDataTx) error + func (b *EventBus) PublishEventValidBlock(data EventDataRoundState) error + func (b *EventBus) PublishEventValidatorSetUpdates(data EventDataValidatorSetUpdates) error + func (b *EventBus) PublishEventVote(data EventDataVote) error + func (b *EventBus) SetLogger(l log.Logger) + func (b *EventBus) Subscribe(ctx context.Context, subscriber string, query cmtpubsub.Query, ...) (Subscription, error) + func (b *EventBus) SubscribeUnbuffered(ctx context.Context, subscriber string, query cmtpubsub.Query) (Subscription, error) + func (b *EventBus) Unsubscribe(ctx context.Context, subscriber string, query cmtpubsub.Query) error + func (b *EventBus) UnsubscribeAll(ctx context.Context, subscriber string) error + type EventBusSubscriber interface + NumClientSubscriptions func(clientID string) int + NumClients func() int + Subscribe func(ctx context.Context, subscriber string, query cmtpubsub.Query, ...) (Subscription, error) + Unsubscribe func(ctx context.Context, subscriber string, query cmtpubsub.Query) error + UnsubscribeAll func(ctx context.Context, subscriber string) error + type EventDataCompleteProposal struct + BlockID BlockID + Height int64 + Round int32 + Step string + type EventDataNewBlock struct + Block *Block + BlockID BlockID + ResultFinalizeBlock abci.FinalizeBlockResponse + type EventDataNewBlockEvents struct + Events []abci.Event + Height int64 + NumTxs int64 + type EventDataNewBlockHeader struct + Header Header + type EventDataNewEvidence struct + Evidence Evidence + Height int64 + type EventDataNewRound struct + Height int64 + Proposer ValidatorInfo + Round int32 + Step string + type EventDataRoundState struct + Height int64 + Round int32 + Step string + type EventDataString string + type EventDataTx struct + type EventDataValidatorSetUpdates struct + ValidatorUpdates []*Validator + type EventDataVote struct + Vote *Vote + type Evidence interface + ABCI func() []abci.Misbehavior + Bytes func() []byte + Hash func() []byte + Height func() int64 + String func() string + Time func() time.Time + ValidateBasic func() error + func EvidenceFromProto(evidence *cmtproto.Evidence) (Evidence, error) + type EvidenceData struct + Evidence EvidenceList + func (data *EvidenceData) ByteSize() int64 + func (data *EvidenceData) FromProto(eviData *cmtproto.EvidenceList) error + func (data *EvidenceData) Hash() cmtbytes.HexBytes + func (data *EvidenceData) StringIndented(indent string) string + func (data *EvidenceData) ToProto() (*cmtproto.EvidenceList, error) + type EvidenceList []Evidence + func (evl EvidenceList) Has(evidence Evidence) bool + func (evl EvidenceList) Hash() []byte + func (evl EvidenceList) String() string + func (evl EvidenceList) ToABCI() []abci.Misbehavior + type EvidenceParams struct + MaxAgeDuration time.Duration + MaxAgeNumBlocks int64 + MaxBytes int64 + func DefaultEvidenceParams() EvidenceParams + type ExtendedCommit struct + BlockID BlockID + ExtendedSignatures []ExtendedCommitSig + Height int64 + Round int32 + func ExtendedCommitFromProto(ecp *cmtproto.ExtendedCommit) (*ExtendedCommit, error) + func MakeExtCommit(blockID BlockID, height int64, round int32, voteSet *VoteSet, ...) (*ExtendedCommit, error) + func (*ExtendedCommit) Type() byte + func (ec *ExtendedCommit) BitArray() *bits.BitArray + func (ec *ExtendedCommit) Clone() *ExtendedCommit + func (ec *ExtendedCommit) EnsureExtensions(extEnabled bool) error + func (ec *ExtendedCommit) GetByIndex(valIdx int32) *Vote + func (ec *ExtendedCommit) GetExtendedVote(valIndex int32) *Vote + func (ec *ExtendedCommit) GetHeight() int64 + func (ec *ExtendedCommit) GetRound() int32 + func (ec *ExtendedCommit) IsCommit() bool + func (ec *ExtendedCommit) Size() int + func (ec *ExtendedCommit) ToCommit() *Commit + func (ec *ExtendedCommit) ToExtendedVoteSet(chainID string, vals *ValidatorSet) *VoteSet + func (ec *ExtendedCommit) ToProto() *cmtproto.ExtendedCommit + func (ec *ExtendedCommit) ValidateBasic() error + type ExtendedCommitSig struct + Extension []byte + ExtensionSignature []byte + func NewExtendedCommitSigAbsent() ExtendedCommitSig + func (ecs *ExtendedCommitSig) FromProto(ecsp cmtproto.ExtendedCommitSig) error + func (ecs *ExtendedCommitSig) ToProto() *cmtproto.ExtendedCommitSig + func (ecs ExtendedCommitSig) EnsureExtension(extEnabled bool) error + func (ecs ExtendedCommitSig) String() string + func (ecs ExtendedCommitSig) ValidateBasic() error + type FeatureParams struct + PbtsEnableHeight int64 + VoteExtensionsEnableHeight int64 + func DefaultFeatureParams() FeatureParams + func (p FeatureParams) PbtsEnabled(h int64) bool + func (p FeatureParams) VoteExtensionsEnabled(h int64) bool + type GenesisDoc struct + AppHash cmtbytes.HexBytes + AppState json.RawMessage + ChainID string + ConsensusParams *ConsensusParams + GenesisTime time.Time + InitialHeight int64 + Validators []GenesisValidator + func GenesisDocFromFile(genDocFile string) (*GenesisDoc, error) + func GenesisDocFromJSON(jsonBlob []byte) (*GenesisDoc, error) + func (genDoc *GenesisDoc) SaveAs(file string) error + func (genDoc *GenesisDoc) ValidateAndComplete() error + func (genDoc *GenesisDoc) ValidatorHash() []byte + type GenesisValidator struct + Address Address + Name string + Power int64 + PubKey crypto.PubKey + type Header struct + AppHash cmtbytes.HexBytes + ChainID string + ConsensusHash cmtbytes.HexBytes + DataHash cmtbytes.HexBytes + EvidenceHash cmtbytes.HexBytes + Height int64 + LastBlockID BlockID + LastCommitHash cmtbytes.HexBytes + LastResultsHash cmtbytes.HexBytes + NextValidatorsHash cmtbytes.HexBytes + ProposerAddress Address + Time time.Time + ValidatorsHash cmtbytes.HexBytes + Version cmtversion.Consensus + func HeaderFromProto(ph *cmtproto.Header) (Header, error) + func (h *Header) Hash() cmtbytes.HexBytes + func (h *Header) Populate(version cmtversion.Consensus, chainID string, timestamp time.Time, ...) + func (h *Header) StringIndented(indent string) string + func (h *Header) ToProto() *cmtproto.Header + func (h Header) ValidateBasic() error + type LightBlock struct + ValidatorSet *ValidatorSet + func LightBlockFromProto(pb *cmtproto.LightBlock) (*LightBlock, error) + func (lb *LightBlock) ToProto() (*cmtproto.LightBlock, error) + func (lb LightBlock) String() string + func (lb LightBlock) StringIndented(indent string) string + func (lb LightBlock) ValidateBasic(chainID string) error + type LightClientAttackEvidence struct + ByzantineValidators []*Validator + CommonHeight int64 + ConflictingBlock *LightBlock + Timestamp time.Time + TotalVotingPower int64 + func LightClientAttackEvidenceFromProto(lpb *cmtproto.LightClientAttackEvidence) (*LightClientAttackEvidence, error) + func (l *LightClientAttackEvidence) ABCI() []abci.Misbehavior + func (l *LightClientAttackEvidence) Bytes() []byte + func (l *LightClientAttackEvidence) ConflictingHeaderIsInvalid(trustedHeader *Header) bool + func (l *LightClientAttackEvidence) GetByzantineValidators(commonVals *ValidatorSet, trusted *SignedHeader) []*Validator + func (l *LightClientAttackEvidence) Hash() []byte + func (l *LightClientAttackEvidence) Height() int64 + func (l *LightClientAttackEvidence) String() string + func (l *LightClientAttackEvidence) Time() time.Time + func (l *LightClientAttackEvidence) ToProto() (*cmtproto.LightClientAttackEvidence, error) + func (l *LightClientAttackEvidence) ValidateBasic() error + type MockPV struct + PrivKey crypto.PrivKey + func NewMockPV() MockPV + func NewMockPVWithParams(privKey crypto.PrivKey, breakProposalSigning, breakVoteSigning bool) MockPV + func (MockPV) DisableChecks() + func (pv MockPV) ExtractIntoValidator(votingPower int64) *Validator + func (pv MockPV) GetPubKey() (crypto.PubKey, error) + func (pv MockPV) SignBytes(bytes []byte) ([]byte, error) + func (pv MockPV) SignProposal(chainID string, proposal *cmtproto.Proposal) error + func (pv MockPV) SignVote(chainID string, vote *cmtproto.Vote, signExtension bool) error + func (pv MockPV) String() string + type NopEventBus struct + func (NopEventBus) PublishEventCompleteProposal(EventDataRoundState) error + func (NopEventBus) PublishEventLock(EventDataRoundState) error + func (NopEventBus) PublishEventNewBlock(EventDataNewBlock) error + func (NopEventBus) PublishEventNewBlockEvents(EventDataNewBlockEvents) error + func (NopEventBus) PublishEventNewBlockHeader(EventDataNewBlockHeader) error + func (NopEventBus) PublishEventNewEvidence(EventDataNewEvidence) error + func (NopEventBus) PublishEventNewRound(EventDataRoundState) error + func (NopEventBus) PublishEventNewRoundStep(EventDataRoundState) error + func (NopEventBus) PublishEventPolka(EventDataRoundState) error + func (NopEventBus) PublishEventRelock(EventDataRoundState) error + func (NopEventBus) PublishEventTimeoutPropose(EventDataRoundState) error + func (NopEventBus) PublishEventTimeoutWait(EventDataRoundState) error + func (NopEventBus) PublishEventTx(EventDataTx) error + func (NopEventBus) PublishEventValidatorSetUpdates(EventDataValidatorSetUpdates) error + func (NopEventBus) PublishEventVote(EventDataVote) error + func (NopEventBus) Subscribe(context.Context, string, cmtpubsub.Query, chan<- any) error + func (NopEventBus) Unsubscribe(context.Context, string, cmtpubsub.Query) error + func (NopEventBus) UnsubscribeAll(context.Context, string) error + type P2PID string + type Part struct + Bytes cmtbytes.HexBytes + Index uint32 + Proof merkle.Proof + func PartFromProto(pb *cmtproto.Part) (*Part, error) + func (part *Part) String() string + func (part *Part) StringIndented(indent string) string + func (part *Part) ToProto() (*cmtproto.Part, error) + func (part *Part) ValidateBasic() error + type PartSet struct + func NewPartSetFromData(data []byte, partSize uint32) *PartSet + func NewPartSetFromHeader(header PartSetHeader) *PartSet + func (ps *PartSet) AddPart(part *Part) (bool, error) + func (ps *PartSet) BitArray() *bits.BitArray + func (ps *PartSet) ByteSize() int64 + func (ps *PartSet) Count() uint32 + func (ps *PartSet) GetPart(index int) *Part + func (ps *PartSet) GetReader() io.Reader + func (ps *PartSet) HasHeader(header PartSetHeader) bool + func (ps *PartSet) Hash() []byte + func (ps *PartSet) HashesTo(hash []byte) bool + func (ps *PartSet) Header() PartSetHeader + func (ps *PartSet) IsComplete() bool + func (ps *PartSet) MarshalJSON() ([]byte, error) + func (ps *PartSet) StringShort() string + func (ps *PartSet) Total() uint32 + type PartSetHeader struct + Hash cmtbytes.HexBytes + Total uint32 + func PartSetHeaderFromProto(ppsh *cmtproto.PartSetHeader) (*PartSetHeader, error) + func (psh *PartSetHeader) ToProto() cmtproto.PartSetHeader + func (psh PartSetHeader) Equals(other PartSetHeader) bool + func (psh PartSetHeader) IsZero() bool + func (psh PartSetHeader) String() string + func (psh PartSetHeader) ValidateBasic() error + type PartSetReader struct + func NewPartSetReader(parts []*Part) *PartSetReader + func (psr *PartSetReader) Read(p []byte) (n int, err error) + type PrivValidator interface + GetPubKey func() (crypto.PubKey, error) + SignBytes func(bytes []byte) ([]byte, error) + SignProposal func(chainID string, proposal *cmtproto.Proposal) error + SignVote func(chainID string, vote *cmtproto.Vote, signExtension bool) error + type PrivValidatorsByAddress []PrivValidator + func (pvs PrivValidatorsByAddress) Len() int + func (pvs PrivValidatorsByAddress) Less(i, j int) bool + func (pvs PrivValidatorsByAddress) Swap(i, j int) + type Proposal struct + BlockID BlockID + Height int64 + POLRound int32 + Round int32 + Signature []byte + Timestamp time.Time + Type SignedMsgType + func NewProposal(height int64, round int32, polRound int32, blockID BlockID, ts time.Time) *Proposal + func ProposalFromProto(pp *cmtproto.Proposal) (*Proposal, error) + func (p *Proposal) IsTimely(recvTime time.Time, sp SynchronyParams) bool + func (p *Proposal) String() string + func (p *Proposal) ToProto() *cmtproto.Proposal + func (p *Proposal) ValidateBasic() error + type Signable interface + SignBytes func(chainID string) []byte + type SignedHeader struct + Commit *Commit + func SignedHeaderFromProto(shp *cmtproto.SignedHeader) (*SignedHeader, error) + func (sh *SignedHeader) ToProto() *cmtproto.SignedHeader + func (sh SignedHeader) IsEmpty() bool + func (sh SignedHeader) String() string + func (sh SignedHeader) StringIndented(indent string) string + func (sh SignedHeader) ValidateBasic(chainID string) error + type SignedMsgType = cmtproto.SignedMsgType + const PrecommitType + const PrevoteType + const ProposalType + const UnknownType + type Subscription interface + Canceled func() <-chan struct{} + Err func() error + Out func() <-chan cmtpubsub.Message + type SynchronyParams struct + MessageDelay time.Duration + Precision time.Duration + func DefaultSynchronyParams() SynchronyParams + func (sp SynchronyParams) InRound(round int32) SynchronyParams + type TMEventData interface + type Tx []byte + func (tx Tx) Hash() []byte + func (tx Tx) Key() TxKey + func (tx Tx) String() string + type TxEventPublisher interface + PublishEventTx func(tx EventDataTx) error + type TxKey [TxKeySize]byte + type TxProof struct + Data Tx + Proof merkle.Proof + RootHash cmtbytes.HexBytes + func TxProofFromProto(pb cmtproto.TxProof) (TxProof, error) + func (tp TxProof) Leaf() []byte + func (tp TxProof) ToProto() cmtproto.TxProof + func (tp TxProof) Validate(dataHash []byte) error + type Txs []Tx + func ToTxs(txl [][]byte) Txs + func (txs Txs) Hash() []byte + func (txs Txs) Index(tx Tx) int + func (txs Txs) IndexByHash(hash []byte) int + func (txs Txs) Len() int + func (txs Txs) Less(i, j int) bool + func (txs Txs) Proof(i int) TxProof + func (txs Txs) Swap(i, j int) + func (txs Txs) ToSliceOfBytes() [][]byte + func (txs Txs) Validate(maxSizeBytes int64) error + type Unwrapper interface + Unwrap func() (proto.Message, error) + type Validator struct + Address Address + ProposerPriority int64 + PubKey crypto.PubKey + VotingPower int64 + func NewValidator(pubKey crypto.PubKey, votingPower int64) *Validator + func ValidatorFromProto(vp *cmtproto.Validator) (*Validator, error) + func (v *Validator) Bytes() []byte + func (v *Validator) CompareProposerPriority(other *Validator) *Validator + func (v *Validator) Copy() *Validator + func (v *Validator) String() string + func (v *Validator) ToProto() (*cmtproto.Validator, error) + func (v *Validator) ValidateBasic() error + type ValidatorInfo struct + Address Address + Index int32 + type ValidatorParams struct + PubKeyTypes []string + func DefaultValidatorParams() ValidatorParams + type ValidatorSet struct + Proposer *Validator + Validators []*Validator + func NewValidatorSet(valz []*Validator) *ValidatorSet + func ValidatorSetFromExistingValidators(valz []*Validator) (*ValidatorSet, error) + func ValidatorSetFromProto(vp *cmtproto.ValidatorSet) (*ValidatorSet, error) + func (vals *ValidatorSet) AllKeysHaveSameType() bool + func (vals *ValidatorSet) Copy() *ValidatorSet + func (vals *ValidatorSet) CopyIncrementProposerPriority(times int32) *ValidatorSet + func (vals *ValidatorSet) GetByAddress(address []byte) (index int32, val *Validator) + func (vals *ValidatorSet) GetByIndex(index int32) (address []byte, val *Validator) + func (vals *ValidatorSet) GetProposer() (proposer *Validator) + func (vals *ValidatorSet) HasAddress(address []byte) bool + func (vals *ValidatorSet) Hash() []byte + func (vals *ValidatorSet) IncrementProposerPriority(times int32) + func (vals *ValidatorSet) IsNilOrEmpty() bool + func (vals *ValidatorSet) Iterate(fn func(index int, val *Validator) bool) + func (vals *ValidatorSet) RescalePriorities(diffMax int64) + func (vals *ValidatorSet) Size() int + func (vals *ValidatorSet) String() string + func (vals *ValidatorSet) StringIndented(indent string) string + func (vals *ValidatorSet) ToProto() (*cmtproto.ValidatorSet, error) + func (vals *ValidatorSet) TotalVotingPower() int64 + func (vals *ValidatorSet) UpdateWithChangeSet(changes []*Validator) error + func (vals *ValidatorSet) ValidateBasic() error + func (vals *ValidatorSet) VerifyCommit(chainID string, blockID BlockID, height int64, commit *Commit) error + func (vals *ValidatorSet) VerifyCommitLight(chainID string, blockID BlockID, height int64, commit *Commit) error + func (vals *ValidatorSet) VerifyCommitLightAllSignatures(chainID string, blockID BlockID, height int64, commit *Commit) error + func (vals *ValidatorSet) VerifyCommitLightTrusting(chainID string, commit *Commit, trustLevel cmtmath.Fraction) error + func (vals *ValidatorSet) VerifyCommitLightTrustingAllSignatures(chainID string, commit *Commit, trustLevel cmtmath.Fraction) error + type ValidatorsByAddress []*Validator + func (valz ValidatorsByAddress) Len() int + func (valz ValidatorsByAddress) Less(i, j int) bool + func (valz ValidatorsByAddress) Swap(i, j int) + type ValidatorsByVotingPower []*Validator + func (valz ValidatorsByVotingPower) Len() int + func (valz ValidatorsByVotingPower) Less(i, j int) bool + func (valz ValidatorsByVotingPower) Swap(i, j int) + type VersionParams struct + App uint64 + func DefaultVersionParams() VersionParams + type Vote struct + BlockID BlockID + Extension []byte + ExtensionSignature []byte + Height int64 + Round int32 + Signature []byte + Timestamp time.Time + Type SignedMsgType + ValidatorAddress Address + ValidatorIndex int32 + func MakeVote(val PrivValidator, chainID string, valIndex int32, height int64, round int32, ...) (*Vote, error) + func MakeVoteNoError(t *testing.T, val PrivValidator, chainID string, valIndex int32, height int64, ...) *Vote + func VoteFromProto(pv *cmtproto.Vote) (*Vote, error) + func (vote *Vote) CommitSig() CommitSig + func (vote *Vote) Copy() *Vote + func (vote *Vote) EnsureExtension() error + func (vote *Vote) ExtendedCommitSig() ExtendedCommitSig + func (vote *Vote) String() string + func (vote *Vote) ToProto() *cmtproto.Vote + func (vote *Vote) ValidateBasic() error + func (vote *Vote) Verify(chainID string, pubKey crypto.PubKey) error + func (vote *Vote) VerifyExtension(chainID string, pubKey crypto.PubKey) error + func (vote *Vote) VerifyVoteAndExtension(chainID string, pubKey crypto.PubKey) error + type VoteSet struct + func NewExtendedVoteSet(chainID string, height int64, round int32, signedMsgType SignedMsgType, ...) *VoteSet + func NewVoteSet(chainID string, height int64, round int32, signedMsgType SignedMsgType, ...) *VoteSet + func (voteSet *VoteSet) AddVote(vote *Vote) (added bool, err error) + func (voteSet *VoteSet) BitArray() *bits.BitArray + func (voteSet *VoteSet) BitArrayByBlockID(blockID BlockID) *bits.BitArray + func (voteSet *VoteSet) BitArrayString() string + func (voteSet *VoteSet) ChainID() string + func (voteSet *VoteSet) GetByAddress(address []byte) *Vote + func (voteSet *VoteSet) GetByIndex(valIndex int32) *Vote + func (voteSet *VoteSet) GetHeight() int64 + func (voteSet *VoteSet) GetRound() int32 + func (voteSet *VoteSet) HasAll() bool + func (voteSet *VoteSet) HasTwoThirdsAny() bool + func (voteSet *VoteSet) HasTwoThirdsMajority() bool + func (voteSet *VoteSet) IsCommit() bool + func (voteSet *VoteSet) List() []Vote + func (voteSet *VoteSet) LogString() string + func (voteSet *VoteSet) MakeExtendedCommit(fp FeatureParams) *ExtendedCommit + func (voteSet *VoteSet) MarshalJSON() ([]byte, error) + func (voteSet *VoteSet) SetPeerMaj23(peerID P2PID, blockID BlockID) error + func (voteSet *VoteSet) Size() int + func (voteSet *VoteSet) String() string + func (voteSet *VoteSet) StringIndented(indent string) string + func (voteSet *VoteSet) StringShort() string + func (voteSet *VoteSet) TwoThirdsMajority() (blockID BlockID, ok bool) + func (voteSet *VoteSet) Type() byte + func (voteSet *VoteSet) VoteStrings() []string + type VoteSetJSON struct + PeerMaj23s map[P2PID]BlockID + Votes []string + VotesBitArray string + type VoteSetReader interface + BitArray func() *bits.BitArray + GetByIndex func(idx int32) *Vote + GetHeight func() int64 + GetRound func() int32 + IsCommit func() bool + Size func() int + Type func() byte + type Wrapper interface + Wrap func() proto.Message Other modules containing this package github.com/KYVENetwork/cometbft/v34 github.com/KYVENetwork/cometbft/v37 github.com/KYVENetwork/cometbft/v38