Documentation ¶
Index ¶
- Constants
- Variables
- func CanonicalTime(t time.Time) string
- func CanonicalizeBlockID(bid tmproto.BlockID) *tmproto.CanonicalBlockID
- func CanonicalizePartSetHeader(psh tmproto.PartSetHeader) tmproto.CanonicalPartSetHeader
- func CanonicalizeProposal(chainID string, proposal *tmproto.Proposal) tmproto.CanonicalProposal
- func CanonicalizeVote(chainID string, vote *tmproto.Vote) tmproto.CanonicalVote
- func ComputeProtoSizeForTxs(txs []Tx) int64
- func EventQueryTxFor(tx Tx) tmpubsub.Query
- func EvidenceToProto(evidence Evidence) (*tmproto.Evidence, error)
- func IsErrNotEnoughVotingPowerSigned(err error) bool
- func IsPreCheckError(err error) bool
- func IsVoteTypeValid(t tmproto.SignedMsgType) bool
- func MaxCommitBytes(valCount int) int64
- func MaxDataBytes(maxBytes, evidenceBytes int64, valsCount int) int64
- func MaxDataBytesNoEvidence(maxBytes int64, valsCount int) int64
- func MaxNodeInfoSize() int
- func ProposalSignBytes(chainID string, p *tmproto.Proposal) []byte
- func QueryForEvent(eventValue string) tmpubsub.Query
- 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 VerifyCommitLightTrusting(chainID string, vals *ValidatorSet, commit *Commit, trustLevel tmmath.Fraction) error
- func VoteSignBytes(chainID string, vote *tmproto.Vote) []byte
- type ABCIResults
- type Address
- type Block
- func (b *Block) Hash() tmbytes.HexBytes
- func (b *Block) HashesTo(hash []byte) bool
- func (b *Block) MakePartSet(partSize uint32) *PartSet
- 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() (*tmproto.Block, error)
- func (b *Block) ValidateBasic() error
- type BlockEventPublisher
- type BlockID
- type BlockIDFlag
- type BlockMeta
- type BlockParams
- type Commit
- func (commit *Commit) BitArray() *bits.BitArray
- func (commit *Commit) GetByIndex(valIdx int32) *Vote
- func (commit *Commit) GetHeight() int64
- func (commit *Commit) GetRound() int32
- func (commit *Commit) GetVote(valIdx int32) *Vote
- func (commit *Commit) Hash() tmbytes.HexBytes
- func (commit *Commit) IsCommit() bool
- func (commit *Commit) Size() int
- func (commit *Commit) StringIndented(indent string) string
- func (commit *Commit) ToProto() *tmproto.Commit
- func (commit *Commit) Type() byte
- func (commit *Commit) ValidateBasic() error
- func (commit *Commit) VoteSignBytes(chainID string, valIdx int32) []byte
- type CommitSig
- func (cs CommitSig) Absent() bool
- func (cs CommitSig) BlockID(commitBlockID BlockID) BlockID
- func (cs CommitSig) ForBlock() bool
- func (cs *CommitSig) FromProto(csp tmproto.CommitSig) error
- func (cs CommitSig) String() string
- func (cs *CommitSig) ToProto() *tmproto.CommitSig
- func (cs CommitSig) ValidateBasic() error
- type ConsensusParams
- func (params *ConsensusParams) Equals(params2 *ConsensusParams) bool
- func (params ConsensusParams) HashConsensusParams() []byte
- func (params *ConsensusParams) ToProto() tmproto.ConsensusParams
- func (params ConsensusParams) UpdateConsensusParams(params2 *tmproto.ConsensusParams) ConsensusParams
- func (params ConsensusParams) ValidateConsensusParams() error
- type Data
- type DuplicateVoteEvidence
- func DuplicateVoteEvidenceFromProto(pb *tmproto.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
- func NewMockDuplicateVoteEvidenceWithValidator(height int64, time time.Time, pv PrivValidator, chainID string) *DuplicateVoteEvidence
- func (dve *DuplicateVoteEvidence) ABCI() []abci.Evidence
- func (dve *DuplicateVoteEvidence) Bytes() []byte
- func (dve *DuplicateVoteEvidence) GenerateABCI(val *Validator, valSet *ValidatorSet, evidenceTime time.Time)
- 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() *tmproto.DuplicateVoteEvidence
- func (dve *DuplicateVoteEvidence) ValidateABCI(val *Validator, valSet *ValidatorSet, evidenceTime time.Time) error
- func (dve *DuplicateVoteEvidence) ValidateBasic() error
- type ErrEvidenceOverflow
- type ErrInvalidCommitHeight
- type ErrInvalidCommitSignatures
- type ErrInvalidEvidence
- type ErrMempoolIsFull
- type ErrNetAddressInvalid
- type ErrNetAddressLookup
- type ErrNetAddressNoID
- type ErrNotEnoughVotingPowerSigned
- type ErrPreCheck
- type ErrTxTooLarge
- type ErrVoteConflictingVotes
- type ErroringMockPV
- type 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(eventValue string, eventData TMEventData) error
- func (b *EventBus) PublishEventBlockSyncStatus(data EventDataBlockSyncStatus) 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) 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) PublishEventStateSyncStatus(data EventDataStateSyncStatus) 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) PublishEventUnlock(data EventDataRoundState) 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 tmpubsub.Query, ...) (Subscription, error)
- func (b *EventBus) SubscribeUnbuffered(ctx context.Context, subscriber string, query tmpubsub.Query) (Subscription, error)
- func (b *EventBus) Unsubscribe(ctx context.Context, args tmpubsub.UnsubscribeArgs) error
- func (b *EventBus) UnsubscribeAll(ctx context.Context, subscriber string) error
- type EventBusSubscriber
- type EventDataBlockSyncStatus
- type EventDataCompleteProposal
- type EventDataNewBlock
- type EventDataNewBlockHeader
- type EventDataNewEvidence
- type EventDataNewRound
- type EventDataRoundState
- type EventDataStateSyncStatus
- type EventDataString
- type EventDataTx
- type EventDataValidatorSetUpdates
- type EventDataVote
- type Evidence
- type EvidenceData
- type EvidenceList
- type EvidenceParams
- type GenesisDoc
- type GenesisValidator
- type HashedParams
- type Header
- type LightBlock
- type LightClientAttackEvidence
- func (l *LightClientAttackEvidence) ABCI() []abci.Evidence
- func (l *LightClientAttackEvidence) Bytes() []byte
- func (l *LightClientAttackEvidence) ConflictingHeaderIsInvalid(trustedHeader *Header) bool
- func (l *LightClientAttackEvidence) GenerateABCI(commonVals *ValidatorSet, trustedHeader *SignedHeader, evidenceTime time.Time)
- 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() (*tmproto.LightClientAttackEvidence, error)
- func (l *LightClientAttackEvidence) ValidateABCI(commonVals *ValidatorSet, trustedHeader *SignedHeader, evidenceTime time.Time) error
- func (l *LightClientAttackEvidence) ValidateBasic() error
- type MockPV
- func (pv MockPV) DisableChecks()
- func (pv MockPV) ExtractIntoValidator(votingPower int64) *Validator
- func (pv MockPV) GetPubKey(ctx context.Context) (crypto.PubKey, error)
- func (pv MockPV) SignProposal(ctx context.Context, chainID string, proposal *tmproto.Proposal) error
- func (pv MockPV) SignVote(ctx context.Context, chainID string, vote *tmproto.Vote) error
- func (pv MockPV) String() string
- type NetAddress
- func (na *NetAddress) Dial() (net.Conn, error)
- func (na *NetAddress) DialString() string
- func (na *NetAddress) DialTimeout(timeout time.Duration) (net.Conn, error)
- func (na *NetAddress) Equals(other interface{}) bool
- func (na *NetAddress) Local() bool
- func (na *NetAddress) OnionCatTor() bool
- func (na *NetAddress) RFC1918() bool
- func (na *NetAddress) RFC3849() bool
- func (na *NetAddress) RFC3927() bool
- func (na *NetAddress) RFC3964() bool
- func (na *NetAddress) RFC4193() bool
- func (na *NetAddress) RFC4380() bool
- func (na *NetAddress) RFC4843() bool
- func (na *NetAddress) RFC4862() bool
- func (na *NetAddress) RFC6052() bool
- func (na *NetAddress) RFC6145() bool
- func (na *NetAddress) ReachabilityTo(o *NetAddress) int
- func (na *NetAddress) Routable() bool
- func (na *NetAddress) Same(other interface{}) bool
- func (na *NetAddress) String() string
- func (na *NetAddress) Valid() error
- type NodeID
- type NodeInfo
- func (info *NodeInfo) AddChannel(channel uint16)
- func (info NodeInfo) CompatibleWith(other NodeInfo) error
- func (info NodeInfo) Copy() NodeInfo
- func (info NodeInfo) ID() NodeID
- func (info NodeInfo) NetAddress() (*NetAddress, error)
- func (info NodeInfo) ToProto() *tmp2p.NodeInfo
- func (info NodeInfo) Validate() error
- type NodeInfoOther
- type NodeKey
- type NopEventBus
- func (NopEventBus) PublishEventBlockSyncStatus(data EventDataBlockSyncStatus) error
- func (NopEventBus) PublishEventCompleteProposal(data EventDataRoundState) error
- func (NopEventBus) PublishEventLock(data EventDataRoundState) error
- func (NopEventBus) PublishEventNewBlock(data EventDataNewBlock) error
- func (NopEventBus) PublishEventNewBlockHeader(data EventDataNewBlockHeader) error
- func (NopEventBus) PublishEventNewEvidence(evidence EventDataNewEvidence) error
- func (NopEventBus) PublishEventNewRound(data EventDataRoundState) error
- func (NopEventBus) PublishEventNewRoundStep(data EventDataRoundState) error
- func (NopEventBus) PublishEventPolka(data EventDataRoundState) error
- func (NopEventBus) PublishEventRelock(data EventDataRoundState) error
- func (NopEventBus) PublishEventStateSyncStatus(data EventDataStateSyncStatus) error
- func (NopEventBus) PublishEventTimeoutPropose(data EventDataRoundState) error
- func (NopEventBus) PublishEventTimeoutWait(data EventDataRoundState) error
- func (NopEventBus) PublishEventTx(data EventDataTx) error
- func (NopEventBus) PublishEventUnlock(data EventDataRoundState) error
- func (NopEventBus) PublishEventValidatorSetUpdates(data EventDataValidatorSetUpdates) error
- func (NopEventBus) PublishEventVote(data EventDataVote) error
- func (NopEventBus) Subscribe(ctx context.Context, subscriber string, query tmpubsub.Query, ...) error
- func (NopEventBus) Unsubscribe(ctx context.Context, args tmpubsub.UnsubscribeArgs) error
- func (NopEventBus) UnsubscribeAll(ctx context.Context, subscriber string) error
- type P2PID
- type Part
- type 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
- type PartSetReader
- type PrivValidator
- type PrivValidatorType
- type PrivValidatorsByAddress
- type Proposal
- type ProtocolVersion
- type Signable
- type SignedHeader
- type Subscription
- type TMEventData
- type Tx
- type TxEventPublisher
- type TxProof
- type Txs
- type Validator
- type ValidatorInfo
- type ValidatorParams
- type ValidatorSet
- 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() (*tmproto.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) VerifyCommitLightTrusting(chainID string, commit *Commit, trustLevel tmmath.Fraction) error
- type ValidatorsByAddress
- type ValidatorsByVotingPower
- type VersionParams
- type Vote
- type 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) LogString() string
- func (voteSet *VoteSet) MakeCommit() *Commit
- 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
- type VoteSetReader
Constants ¶
const ( // MaxHeaderBytes is a maximum header size. // NOTE: Because app hash can be of arbitrary size, the header is therefore not // capped in size and thus this number should be seen as a soft max MaxHeaderBytes int64 = 626 // MaxOverheadForBlock - maximum overhead to encode a block (up to // MaxBlockSizeBytes in size) not including it's parts except Data. // This means it also excludes the overhead for individual transactions. // // Uvarint length of MaxBlockSizeBytes: 4 bytes // 2 fields (2 embedded): 2 bytes // Uvarint length of Data.Txs: 4 bytes // Data.Txs field: 1 byte MaxOverheadForBlock int64 = 11 )
const ( // Max size of commit without any commitSigs -> 82 for BlockID, 8 for Height, 4 for Round. MaxCommitOverheadBytes int64 = 94 // Commit sig size is made up of 64 bytes for the signature, 20 bytes for the address, // 1 byte for the flag and 14 bytes for the timestamp MaxCommitSigBytes int64 = 109 )
const ( // Block level events for mass consumption by users. // These events are triggered from the state package, // after a block has been committed. // These are also used by the tx indexer for async indexing. // All of this data can be fetched through the rpc. EventNewBlockValue = "NewBlock" EventNewBlockHeaderValue = "NewBlockHeader" EventNewEvidenceValue = "NewEvidence" EventTxValue = "Tx" EventValidatorSetUpdatesValue = "ValidatorSetUpdates" // Internal consensus events. // These are used for testing the consensus state machine. // They can also be used to build real-time consensus visualizers. EventCompleteProposalValue = "CompleteProposal" // The BlockSyncStatus event will be emitted when the node switching // state sync mechanism between the consensus reactor and the blocksync reactor. EventBlockSyncStatusValue = "BlockSyncStatus" EventLockValue = "Lock" EventNewRoundValue = "NewRound" EventNewRoundStepValue = "NewRoundStep" EventPolkaValue = "Polka" EventRelockValue = "Relock" EventStateSyncStatusValue = "StateSyncStatus" EventTimeoutProposeValue = "TimeoutPropose" EventTimeoutWaitValue = "TimeoutWait" EventUnlockValue = "Unlock" EventValidBlockValue = "ValidBlock" EventVoteValue = "Vote" )
Reserved event types (alphabetically sorted).
const ( // EventTypeKey is a reserved composite key for event name. EventTypeKey = "tm.event" // TxHashKey is a reserved key, used to specify transaction's hash. // see EventBus#PublishEventTx TxHashKey = "tx.hash" // TxHeightKey is a reserved key, used to specify transaction block's height. // see EventBus#PublishEventTx TxHeightKey = "tx.height" // BlockHeightKey is a reserved key used for indexing BeginBlock and Endblock // events. BlockHeightKey = "block.height" EventTypeBeginBlock = "begin_block" EventTypeEndBlock = "end_block" )
const ( // MaxBlockSizeBytes is the maximum permitted size of the blocks. MaxBlockSizeBytes = 104857600 // 100MB // BlockPartSizeBytes is the size of one block part. BlockPartSizeBytes uint32 = 65536 // 64kB // MaxBlockPartsCount is the maximum number of block parts. MaxBlockPartsCount = (MaxBlockSizeBytes / BlockPartSizeBytes) + 1 ABCIPubKeyTypeEd25519 = ed25519.KeyType ABCIPubKeyTypeSecp256k1 = secp256k1.KeyType ABCIPubKeyTypeSr25519 = sr25519.KeyType )
const ( MockSignerClient = PrivValidatorType(0x00) // mock signer FileSignerClient = PrivValidatorType(0x01) // signer client via file RetrySignerClient = PrivValidatorType(0x02) // signer client with retry via socket SignerSocketClient = PrivValidatorType(0x03) // signer client via socket ErrorMockSignerClient = PrivValidatorType(0x04) // error mock signer SignerGRPCClient = PrivValidatorType(0x05) // signer client via gRPC )
const ( // MaxTotalVotingPower - the maximum allowed total voting power. // It needs to be sufficiently small to, in all cases: // 1. prevent clipping in incrementProposerPriority() // 2. let (diff+diffMax-1) not overflow in IncrementProposerPriority() // (Proof of 1 is tricky, left to the reader). // It could be higher, but this is sufficiently large for our purposes, // and leaves room for defensive purposes. MaxTotalVotingPower = int64(math.MaxInt64) / 8 // PriorityWindowSizeFactor - is a constant that when multiplied with the // total voting power gives the maximum allowed distance between validator // priorities. PriorityWindowSizeFactor = 2 )
const EmptyNetAddress = "<nil-NetAddress>"
EmptyNetAddress defines the string representation of an empty NetAddress
const (
// MaxChainIDLen is a maximum length of the chain ID.
MaxChainIDLen = 50
)
const ( // MaxVotesCount is the maximum number of votes in a set. Used in ValidateBasic funcs for // protection against DOS attacks. Note this implies a corresponding equal limit to // the number of validators. MaxVotesCount = 10000 )
const NodeIDByteLength = crypto.AddressSize
NodeIDByteLength is the length of a crypto.Address. Currently only 20. FIXME: support other length addresses?
const TimeFormat = time.RFC3339Nano
TimeFormat is used for generating the sigs
Variables ¶
var ( EventNewBlock = abci.Event{ Type: strings.Split(EventTypeKey, ".")[0], Attributes: []abci.EventAttribute{ { Key: strings.Split(EventTypeKey, ".")[1], Value: EventNewBlockValue, }, }, } EventNewBlockHeader = abci.Event{ Type: strings.Split(EventTypeKey, ".")[0], Attributes: []abci.EventAttribute{ { Key: strings.Split(EventTypeKey, ".")[1], Value: EventNewBlockHeaderValue, }, }, } EventNewEvidence = abci.Event{ Type: strings.Split(EventTypeKey, ".")[0], Attributes: []abci.EventAttribute{ { Key: strings.Split(EventTypeKey, ".")[1], Value: EventNewEvidenceValue, }, }, } EventTx = abci.Event{ Type: strings.Split(EventTypeKey, ".")[0], Attributes: []abci.EventAttribute{ { Key: strings.Split(EventTypeKey, ".")[1], Value: EventTxValue, }, }, } )
Pre-populated ABCI Tendermint-reserved events
var ( EventQueryCompleteProposal = QueryForEvent(EventCompleteProposalValue) EventQueryLock = QueryForEvent(EventLockValue) EventQueryNewBlock = QueryForEvent(EventNewBlockValue) EventQueryNewBlockHeader = QueryForEvent(EventNewBlockHeaderValue) EventQueryNewEvidence = QueryForEvent(EventNewEvidenceValue) EventQueryNewRound = QueryForEvent(EventNewRoundValue) EventQueryNewRoundStep = QueryForEvent(EventNewRoundStepValue) EventQueryPolka = QueryForEvent(EventPolkaValue) EventQueryRelock = QueryForEvent(EventRelockValue) EventQueryTimeoutPropose = QueryForEvent(EventTimeoutProposeValue) EventQueryTimeoutWait = QueryForEvent(EventTimeoutWaitValue) EventQueryTx = QueryForEvent(EventTxValue) EventQueryUnlock = QueryForEvent(EventUnlockValue) EventQueryValidatorSetUpdates = QueryForEvent(EventValidatorSetUpdatesValue) EventQueryValidBlock = QueryForEvent(EventValidBlockValue) EventQueryVote = QueryForEvent(EventVoteValue) EventQueryBlockSyncStatus = QueryForEvent(EventBlockSyncStatusValue) EventQueryStateSyncStatus = QueryForEvent(EventStateSyncStatusValue) )
var ( ErrPartSetUnexpectedIndex = errors.New("error part set unexpected index") ErrPartSetInvalidProof = errors.New("error part set invalid proof") )
var ( ErrInvalidBlockPartSignature = errors.New("error invalid block part signature") ErrInvalidBlockPartHash = errors.New("error invalid block part hash") )
var ( ErrVoteUnexpectedStep = errors.New("unexpected step") ErrVoteInvalidValidatorIndex = errors.New("invalid validator index") ErrVoteInvalidValidatorAddress = errors.New("invalid validator address") ErrVoteInvalidSignature = errors.New("invalid signature") ErrVoteInvalidBlockHash = errors.New("invalid block hash") ErrVoteNonDeterministicSignature = errors.New("non-deterministic signature") ErrVoteNil = errors.New("nil vote") )
var ABCIPubKeyTypesToNames = map[string]string{ ABCIPubKeyTypeEd25519: ed25519.PubKeyName, ABCIPubKeyTypeSecp256k1: secp256k1.PubKeyName, ABCIPubKeyTypeSr25519: sr25519.PubKeyName, }
var ErrTotalVotingPowerOverflow = fmt.Errorf("total voting power of resulting valset exceeds max %d", MaxTotalVotingPower)
ErrTotalVotingPowerOverflow is returned if the total voting power of the resulting validator set exceeds MaxTotalVotingPower.
var ( // ErrTxInCache is returned to the client if we saw tx earlier ErrTxInCache = errors.New("tx already exists in cache") )
var ErroringMockPVErr = errors.New("erroringMockPV always returns an error")
var ( // MaxSignatureSize is a maximum allowed signature size for the Proposal // and Vote. // XXX: secp256k1 does not have Size nor MaxSize defined. MaxSignatureSize = tmmath.MaxInt(ed25519.SignatureSize, 64) )
var PB2TM = pb2tm{}
PB2TM is used for converting protobuf ABCI to Tendermint ABCI. UNSTABLE
var (
PeerStateKey = "ConsensusReactor.peerState"
)
UNSTABLE
var TM2PB = tm2pb{}
TM2PB is used for converting Tendermint ABCI to protobuf ABCI. UNSTABLE
Functions ¶
func CanonicalTime ¶
CanonicalTime can be used to stringify time in a canonical way.
func CanonicalizeBlockID ¶
func CanonicalizeBlockID(bid tmproto.BlockID) *tmproto.CanonicalBlockID
func CanonicalizePartSetHeader ¶
func CanonicalizePartSetHeader(psh tmproto.PartSetHeader) tmproto.CanonicalPartSetHeader
CanonicalizeVote transforms the given PartSetHeader to a CanonicalPartSetHeader.
func CanonicalizeProposal ¶
func CanonicalizeProposal(chainID string, proposal *tmproto.Proposal) tmproto.CanonicalProposal
CanonicalizeVote transforms the given Proposal to a CanonicalProposal.
func CanonicalizeVote ¶
func CanonicalizeVote(chainID string, vote *tmproto.Vote) tmproto.CanonicalVote
CanonicalizeVote transforms the given Vote to a CanonicalVote, which does not contain ValidatorIndex and ValidatorAddress fields.
func ComputeProtoSizeForTxs ¶ added in v0.34.0
ComputeProtoSizeForTxs wraps the transactions in tmproto.Data{} and calculates the size. https://developers.google.com/protocol-buffers/docs/encoding
func EventQueryTxFor ¶
func EvidenceToProto ¶ added in v0.33.5
EvidenceToProto is a generalized function for encoding evidence that conforms to the evidence interface to protobuf
func IsErrNotEnoughVotingPowerSigned ¶ added in v0.33.0
IsErrNotEnoughVotingPowerSigned returns true if err is ErrNotEnoughVotingPowerSigned.
func IsPreCheckError ¶ added in v0.35.0
IsPreCheckError returns true if err is due to pre check failure.
func IsVoteTypeValid ¶
func IsVoteTypeValid(t tmproto.SignedMsgType) bool
IsVoteTypeValid returns true if t is a valid vote type.
func MaxCommitBytes ¶ added in v0.34.0
func MaxDataBytes ¶
MaxDataBytes returns the maximum size of block's data.
XXX: Panics on negative result.
func MaxDataBytesNoEvidence ¶ added in v0.34.0
MaxDataBytesNoEvidence returns the maximum size of block's data when evidence count is unknown. MaxEvidencePerBlock will be used for the size of evidence.
XXX: Panics on negative result.
func ProposalSignBytes ¶ added in v0.34.0
ProposalSignBytes returns the proto-encoding of the canonicalized Proposal, for signing. Panics if the marshaling fails.
The encoded Protobuf message is varint length-prefixed (using MarshalDelimited) for backwards-compatibility with the Amino encoding, due to e.g. hardware devices that rely on this encoding.
See CanonicalizeProposal
func QueryForEvent ¶
func ValidateHash ¶
ValidateHash returns an error if the hash is not empty, but its size != tmhash.Size.
func ValidatorListString ¶
ValidatorListString returns a prettified validator list for logging purposes.
func VerifyCommit ¶ added in v0.35.0
func VerifyCommit(chainID string, vals *ValidatorSet, blockID BlockID, height int64, commit *Commit) error
VerifyCommit verifies +2/3 of the set had signed the given commit.
It checks all the signatures! While it's safe to exit as soon as we have 2/3+ signatures, doing so would impact incentivization logic in the ABCI application that depends on the LastCommitInfo sent in BeginBlock, which includes which validators signed. For instance, Gaia incentivizes proposers with a bonus for including more than +2/3 of the signatures.
func VerifyCommitLight ¶ added in v0.35.0
func VerifyCommitLight(chainID string, vals *ValidatorSet, blockID BlockID, height int64, commit *Commit) error
VerifyCommitLight verifies +2/3 of the set had signed the given commit.
This method is primarily used by the light client and does not check all the signatures.
func VerifyCommitLightTrusting ¶ added in v0.35.0
func VerifyCommitLightTrusting(chainID string, vals *ValidatorSet, commit *Commit, trustLevel tmmath.Fraction) error
VerifyCommitLightTrusting verifies that trustLevel of the validator set signed this commit.
NOTE the given validators do not necessarily correspond to the validator set for this commit, but there may be some intersection.
This method is primarily used by the light client and does not check all the signatures.
func VoteSignBytes ¶ added in v0.34.0
VoteSignBytes returns the proto-encoding of the canonicalized Vote, for signing. Panics is the marshaling fails.
The encoded Protobuf message is varint length-prefixed (using MarshalDelimited) for backwards-compatibility with the Amino encoding, due to e.g. hardware devices that rely on this encoding.
See CanonicalizeVote
Types ¶
type ABCIResults ¶
type ABCIResults []*abci.ResponseDeliverTx
ABCIResults wraps the deliver tx results to return a proof.
func NewResults ¶
func NewResults(responses []*abci.ResponseDeliverTx) ABCIResults
NewResults strips non-deterministic fields from ResponseDeliverTx responses and returns ABCIResults.
func (ABCIResults) Hash ¶
func (a ABCIResults) Hash() []byte
Hash returns a merkle hash of all results.
func (ABCIResults) ProveResult ¶
func (a ABCIResults) ProveResult(i int) merkle.Proof
ProveResult returns a merkle proof of one result from the set
type Block ¶
type Block struct { Header `json:"header"` Data `json:"data"` Evidence EvidenceData `json:"evidence"` LastCommit *Commit `json:"last_commit"` // contains filtered or unexported fields }
Block defines the atomic unit of a Tendermint blockchain.
func BlockFromProto ¶ added in v0.34.0
FromProto sets a protobuf Block to the given pointer. It returns an error if the block is invalid.
func MakeBlock ¶
MakeBlock returns a new block with an empty header, except what can be computed from itself. It populates the same set of fields validated by ValidateBasic.
func (*Block) Hash ¶
Hash computes and returns the block hash. If the block is incomplete, block hash is nil for safety.
func (*Block) HashesTo ¶
HashesTo is a convenience function that checks if a block hashes to the given argument. Returns false if the block is nil or the hash is empty.
func (*Block) MakePartSet ¶
MakePartSet returns a PartSet containing parts of a serialized block. This is the form in which the block is gossipped to peers. CONTRACT: partSize is greater than zero.
func (*Block) StringIndented ¶
StringIndented returns an indented String.
Header Data Evidence LastCommit Hash
func (*Block) StringShort ¶
StringShort returns a shortened string representation of the block.
func (*Block) ValidateBasic ¶
ValidateBasic performs basic validation that doesn't involve state data. It checks the internal consistency of the block. Further validation is done using state#ValidateBlock.
type BlockEventPublisher ¶
type BlockEventPublisher interface { PublishEventNewBlock(block EventDataNewBlock) error PublishEventNewBlockHeader(header EventDataNewBlockHeader) error PublishEventNewEvidence(evidence EventDataNewEvidence) error PublishEventTx(EventDataTx) error PublishEventValidatorSetUpdates(EventDataValidatorSetUpdates) error }
BlockEventPublisher publishes all block related events
type BlockID ¶
type BlockID struct { Hash tmbytes.HexBytes `json:"hash"` PartSetHeader PartSetHeader `json:"parts"` }
BlockID
func BlockIDFromProto ¶ added in v0.33.5
FromProto sets a protobuf BlockID to the given pointer. It returns an error if the block id is invalid.
func (BlockID) IsComplete ¶
IsComplete returns true if this is a valid BlockID of a non-nil block.
func (BlockID) String ¶
String returns a human readable string representation of the BlockID.
1. hash 2. part set header
See PartSetHeader#String
func (BlockID) ValidateBasic ¶
ValidateBasic performs basic validation.
type BlockIDFlag ¶ added in v0.33.0
type BlockIDFlag byte
BlockIDFlag indicates which BlockID the signature is for.
const ( // BlockIDFlagAbsent - no vote was received from a validator. BlockIDFlagAbsent BlockIDFlag = iota + 1 // BlockIDFlagCommit - voted for the Commit.BlockID. BlockIDFlagCommit // BlockIDFlagNil - voted for nil. BlockIDFlagNil )
type BlockMeta ¶
type BlockMeta struct { BlockID BlockID `json:"block_id"` BlockSize int `json:"block_size"` Header Header `json:"header"` NumTxs int `json:"num_txs"` }
BlockMeta contains meta information.
func BlockMetaFromProto ¶ added in v0.34.0
func NewBlockMeta ¶
NewBlockMeta returns a new BlockMeta.
func (*BlockMeta) ValidateBasic ¶ added in v0.33.0
ValidateBasic performs basic validation.
type BlockParams ¶
BlockParams define limits on the block size and gas plus minimum time between blocks.
func DefaultBlockParams ¶
func DefaultBlockParams() BlockParams
DefaultBlockParams returns a default BlockParams.
type Commit ¶
type Commit struct { // NOTE: The signatures are in order of address to preserve the bonded // ValidatorSet order. // Any peer with a block can gossip signatures by index with a peer without // recalculating the active ValidatorSet. Height int64 `json:"height"` Round int32 `json:"round"` BlockID BlockID `json:"block_id"` Signatures []CommitSig `json:"signatures"` // contains filtered or unexported fields }
Commit contains the evidence that a block was committed by a set of validators. NOTE: Commit is empty for height 1, but never nil.
func CommitFromProto ¶ added in v0.33.5
FromProto sets a protobuf Commit to the given pointer. It returns an error if the commit is invalid.
func (*Commit) BitArray ¶
BitArray returns a BitArray of which validators voted for BlockID or nil in this commit. Implements VoteSetReader.
func (*Commit) GetByIndex ¶
GetByIndex returns the vote corresponding to a given validator index. Panics if `index >= commit.Size()`. Implements VoteSetReader.
func (*Commit) GetHeight ¶ added in v0.33.0
GetHeight returns height of the commit. Implements VoteSetReader.
func (*Commit) GetRound ¶ added in v0.33.0
GetRound returns height of the commit. Implements VoteSetReader.
func (*Commit) GetVote ¶ added in v0.31.6
GetVote converts the CommitSig for the given valIdx to a Vote. Returns nil if the precommit at valIdx is nil. Panics if valIdx >= commit.Size().
func (*Commit) IsCommit ¶
IsCommit returns true if there is at least one signature. Implements VoteSetReader.
func (*Commit) Size ¶
Size returns the number of signatures in the commit. Implements VoteSetReader.
func (*Commit) StringIndented ¶
StringIndented returns a string representation of the commit.
func (*Commit) Type ¶
Type returns the vote type of the commit, which is always VoteTypePrecommit Implements VoteSetReader.
func (*Commit) ValidateBasic ¶
ValidateBasic performs basic validation that doesn't involve state data. Does not actually check the cryptographic signatures.
func (*Commit) VoteSignBytes ¶
VoteSignBytes returns the bytes of the Vote corresponding to valIdx for signing.
The only unique part is the Timestamp - all other fields signed over are otherwise the same for all validators.
Panics if valIdx >= commit.Size().
See VoteSignBytes
type CommitSig ¶
type CommitSig struct { BlockIDFlag BlockIDFlag `json:"block_id_flag"` ValidatorAddress Address `json:"validator_address"` Timestamp time.Time `json:"timestamp"` Signature []byte `json:"signature"` }
CommitSig is a part of the Vote included in a Commit.
func NewCommitSigAbsent ¶ added in v0.33.0
func NewCommitSigAbsent() CommitSig
NewCommitSigAbsent returns new CommitSig with BlockIDFlagAbsent. Other fields are all empty.
func NewCommitSigForBlock ¶ added in v0.33.0
NewCommitSigForBlock returns new CommitSig with BlockIDFlagCommit.
func (CommitSig) BlockID ¶ added in v0.33.0
BlockID returns the Commit's BlockID if CommitSig indicates signing, otherwise - empty BlockID.
func (*CommitSig) FromProto ¶ added in v0.33.5
FromProto sets a protobuf CommitSig to the given pointer. It returns an error if the CommitSig is invalid.
func (CommitSig) String ¶
CommitSig returns a string representation of CommitSig.
1. first 6 bytes of signature 2. first 6 bytes of validator address 3. block ID flag 4. timestamp
func (CommitSig) ValidateBasic ¶ added in v0.33.0
ValidateBasic performs basic validation.
type ConsensusParams ¶
type ConsensusParams struct { Block BlockParams `json:"block"` Evidence EvidenceParams `json:"evidence"` Validator ValidatorParams `json:"validator"` Version VersionParams `json:"version"` }
ConsensusParams contains consensus critical parameters that determine the validity of blocks.
func ConsensusParamsFromProto ¶ added in v0.35.0
func ConsensusParamsFromProto(pbParams tmproto.ConsensusParams) ConsensusParams
func DefaultConsensusParams ¶
func DefaultConsensusParams() *ConsensusParams
DefaultConsensusParams returns a default ConsensusParams.
func (*ConsensusParams) Equals ¶
func (params *ConsensusParams) Equals(params2 *ConsensusParams) bool
func (ConsensusParams) HashConsensusParams ¶ added in v0.35.0
func (params ConsensusParams) HashConsensusParams() []byte
Hash returns a hash of a subset of the parameters to store in the block header. Only the Block.MaxBytes and Block.MaxGas are included in the hash. This allows the ConsensusParams to evolve more without breaking the block protocol. No need for a Merkle tree here, just a small struct to hash.
func (*ConsensusParams) ToProto ¶ added in v0.35.0
func (params *ConsensusParams) ToProto() tmproto.ConsensusParams
func (ConsensusParams) UpdateConsensusParams ¶ added in v0.35.0
func (params ConsensusParams) UpdateConsensusParams(params2 *tmproto.ConsensusParams) ConsensusParams
Update returns a copy of the params with updates from the non-zero fields of p2. NOTE: note: must not modify the original
func (ConsensusParams) ValidateConsensusParams ¶ added in v0.35.0
func (params ConsensusParams) ValidateConsensusParams() error
Validate validates the ConsensusParams to ensure all values are within their allowed limits, and returns an error if they are not.
type Data ¶
type Data struct { // Txs that will be applied by state @ block.Height+1. // NOTE: not all txs here are valid. We're just agreeing on the order first. // This means that block.AppHash does not include these txs. Txs Txs `json:"txs"` // contains filtered or unexported fields }
Data contains the set of transactions included in the block
func DataFromProto ¶ added in v0.34.0
DataFromProto takes a protobuf representation of Data & returns the native type.
func (*Data) StringIndented ¶
StringIndented returns an indented string representation of the transactions.
type DuplicateVoteEvidence ¶
type DuplicateVoteEvidence struct { VoteA *Vote `json:"vote_a"` VoteB *Vote `json:"vote_b"` // abci specific information TotalVotingPower int64 ValidatorPower int64 Timestamp time.Time }
DuplicateVoteEvidence contains evidence of a single validator signing two conflicting votes.
func DuplicateVoteEvidenceFromProto ¶ added in v0.34.0
func DuplicateVoteEvidenceFromProto(pb *tmproto.DuplicateVoteEvidence) (*DuplicateVoteEvidence, error)
DuplicateVoteEvidenceFromProto decodes protobuf into DuplicateVoteEvidence
func NewDuplicateVoteEvidence ¶ added in v0.33.0
func NewDuplicateVoteEvidence(vote1, vote2 *Vote, blockTime time.Time, valSet *ValidatorSet, ) (*DuplicateVoteEvidence, error)
NewDuplicateVoteEvidence creates DuplicateVoteEvidence with right ordering given two conflicting votes. If either of the votes is nil, the val set is nil or the voter is not in the val set, an error is returned
func NewMockDuplicateVoteEvidence ¶ added in v0.34.0
func NewMockDuplicateVoteEvidence(height int64, time time.Time, chainID string) *DuplicateVoteEvidence
assumes the round to be 0 and the validator index to be 0
func NewMockDuplicateVoteEvidenceWithValidator ¶ added in v0.34.0
func NewMockDuplicateVoteEvidenceWithValidator(height int64, time time.Time, pv PrivValidator, chainID string) *DuplicateVoteEvidence
assumes voting power to be 10 and validator to be the only one in the set
func (*DuplicateVoteEvidence) ABCI ¶ added in v0.34.0
func (dve *DuplicateVoteEvidence) ABCI() []abci.Evidence
ABCI returns the application relevant representation of the evidence
func (*DuplicateVoteEvidence) Bytes ¶
func (dve *DuplicateVoteEvidence) Bytes() []byte
Bytes returns the proto-encoded evidence as a byte array.
func (*DuplicateVoteEvidence) GenerateABCI ¶ added in v0.35.0
func (dve *DuplicateVoteEvidence) GenerateABCI( val *Validator, valSet *ValidatorSet, evidenceTime time.Time, )
GenerateABCI populates the ABCI component of the evidence. This includes the validator power, timestamp and total voting power.
func (*DuplicateVoteEvidence) Hash ¶
func (dve *DuplicateVoteEvidence) Hash() []byte
Hash returns the hash of the evidence.
func (*DuplicateVoteEvidence) Height ¶
func (dve *DuplicateVoteEvidence) Height() int64
Height returns the height of the infraction
func (*DuplicateVoteEvidence) String ¶
func (dve *DuplicateVoteEvidence) String() string
String returns a string representation of the evidence.
func (*DuplicateVoteEvidence) Time ¶ added in v0.33.0
func (dve *DuplicateVoteEvidence) Time() time.Time
Time returns the time of the infraction
func (*DuplicateVoteEvidence) ToProto ¶ added in v0.34.0
func (dve *DuplicateVoteEvidence) ToProto() *tmproto.DuplicateVoteEvidence
ToProto encodes DuplicateVoteEvidence to protobuf
func (*DuplicateVoteEvidence) ValidateABCI ¶ added in v0.35.0
func (dve *DuplicateVoteEvidence) ValidateABCI( val *Validator, valSet *ValidatorSet, evidenceTime time.Time, ) error
ValidateABCI validates the ABCI component of the evidence by checking the timestamp, validator power and total voting power.
func (*DuplicateVoteEvidence) ValidateBasic ¶
func (dve *DuplicateVoteEvidence) ValidateBasic() error
ValidateBasic performs basic validation.
type ErrEvidenceOverflow ¶
ErrEvidenceOverflow is for when there the amount of evidence exceeds the max bytes.
func NewErrEvidenceOverflow ¶
func NewErrEvidenceOverflow(max, got int64) *ErrEvidenceOverflow
NewErrEvidenceOverflow returns a new ErrEvidenceOverflow where got > max.
func (*ErrEvidenceOverflow) Error ¶
func (err *ErrEvidenceOverflow) Error() string
Error returns a string representation of the error.
type ErrInvalidCommitHeight ¶ added in v0.32.0
ErrInvalidCommitHeight is returned when we encounter a commit with an unexpected height.
func NewErrInvalidCommitHeight ¶ added in v0.32.0
func NewErrInvalidCommitHeight(expected, actual int64) ErrInvalidCommitHeight
func (ErrInvalidCommitHeight) Error ¶ added in v0.32.0
func (e ErrInvalidCommitHeight) Error() string
type ErrInvalidCommitSignatures ¶ added in v0.33.0
ErrInvalidCommitSignatures is returned when we encounter a commit where the number of signatures doesn't match the number of validators.
func NewErrInvalidCommitSignatures ¶ added in v0.33.0
func NewErrInvalidCommitSignatures(expected, actual int) ErrInvalidCommitSignatures
func (ErrInvalidCommitSignatures) Error ¶ added in v0.33.0
func (e ErrInvalidCommitSignatures) Error() string
type ErrInvalidEvidence ¶ added in v0.34.0
ErrInvalidEvidence wraps a piece of evidence and the error denoting how or why it is invalid.
func NewErrInvalidEvidence ¶ added in v0.34.0
func NewErrInvalidEvidence(ev Evidence, err error) *ErrInvalidEvidence
NewErrInvalidEvidence returns a new EvidenceInvalid with the given err.
func (*ErrInvalidEvidence) Error ¶ added in v0.34.0
func (err *ErrInvalidEvidence) Error() string
Error returns a string representation of the error.
type ErrMempoolIsFull ¶ added in v0.35.0
ErrMempoolIsFull defines an error where Tendermint and the application cannot handle that much load.
func (ErrMempoolIsFull) Error ¶ added in v0.35.0
func (e ErrMempoolIsFull) Error() string
type ErrNetAddressInvalid ¶ added in v0.35.0
func (ErrNetAddressInvalid) Error ¶ added in v0.35.0
func (e ErrNetAddressInvalid) Error() string
type ErrNetAddressLookup ¶ added in v0.35.0
func (ErrNetAddressLookup) Error ¶ added in v0.35.0
func (e ErrNetAddressLookup) Error() string
type ErrNetAddressNoID ¶ added in v0.35.0
type ErrNetAddressNoID struct {
Addr string
}
func (ErrNetAddressNoID) Error ¶ added in v0.35.0
func (e ErrNetAddressNoID) Error() string
type ErrNotEnoughVotingPowerSigned ¶ added in v0.33.0
ErrNotEnoughVotingPowerSigned is returned when not enough validators signed a commit.
func (ErrNotEnoughVotingPowerSigned) Error ¶ added in v0.33.0
func (e ErrNotEnoughVotingPowerSigned) Error() string
type ErrPreCheck ¶ added in v0.35.0
type ErrPreCheck struct {
Reason error
}
ErrPreCheck defines an error where a transaction fails a pre-check.
func (ErrPreCheck) Error ¶ added in v0.35.0
func (e ErrPreCheck) Error() string
type ErrTxTooLarge ¶ added in v0.35.0
ErrTxTooLarge defines an error when a transaction is too big to be sent in a message to other peers.
func (ErrTxTooLarge) Error ¶ added in v0.35.0
func (e ErrTxTooLarge) Error() string
type ErrVoteConflictingVotes ¶
func NewConflictingVoteError ¶
func NewConflictingVoteError(vote1, vote2 *Vote) *ErrVoteConflictingVotes
func (*ErrVoteConflictingVotes) Error ¶
func (err *ErrVoteConflictingVotes) Error() string
type ErroringMockPV ¶ added in v0.33.2
type ErroringMockPV struct {
MockPV
}
func NewErroringMockPV ¶
func NewErroringMockPV() *ErroringMockPV
func (*ErroringMockPV) SignProposal ¶ added in v0.33.2
func (pv *ErroringMockPV) SignProposal(ctx context.Context, chainID string, proposal *tmproto.Proposal) error
Implements PrivValidator.
type EventBus ¶
type EventBus struct { service.BaseService // contains filtered or unexported fields }
EventBus is a common bus for all events going through the system. All calls are proxied to underlying pubsub server. All events must be published using EventBus to ensure correct data types.
func NewEventBusWithBufferCapacity ¶
NewEventBusWithBufferCapacity returns a new event bus with the given buffer capacity.
func (*EventBus) NumClientSubscriptions ¶
func (*EventBus) NumClients ¶
func (*EventBus) Publish ¶
func (b *EventBus) Publish(eventValue string, eventData TMEventData) error
func (*EventBus) PublishEventBlockSyncStatus ¶ added in v0.35.0
func (b *EventBus) PublishEventBlockSyncStatus(data EventDataBlockSyncStatus) error
func (*EventBus) PublishEventCompleteProposal ¶
func (b *EventBus) PublishEventCompleteProposal(data EventDataCompleteProposal) error
func (*EventBus) PublishEventLock ¶
func (b *EventBus) PublishEventLock(data EventDataRoundState) error
func (*EventBus) PublishEventNewBlock ¶
func (b *EventBus) PublishEventNewBlock(data EventDataNewBlock) error
func (*EventBus) PublishEventNewBlockHeader ¶
func (b *EventBus) PublishEventNewBlockHeader(data EventDataNewBlockHeader) error
func (*EventBus) PublishEventNewEvidence ¶ added in v0.34.0
func (b *EventBus) PublishEventNewEvidence(evidence EventDataNewEvidence) error
func (*EventBus) PublishEventNewRound ¶
func (b *EventBus) PublishEventNewRound(data EventDataNewRound) error
func (*EventBus) PublishEventNewRoundStep ¶
func (b *EventBus) PublishEventNewRoundStep(data EventDataRoundState) error
func (*EventBus) PublishEventPolka ¶
func (b *EventBus) PublishEventPolka(data EventDataRoundState) error
func (*EventBus) PublishEventRelock ¶
func (b *EventBus) PublishEventRelock(data EventDataRoundState) error
func (*EventBus) PublishEventStateSyncStatus ¶ added in v0.35.0
func (b *EventBus) PublishEventStateSyncStatus(data EventDataStateSyncStatus) error
func (*EventBus) PublishEventTimeoutPropose ¶
func (b *EventBus) PublishEventTimeoutPropose(data EventDataRoundState) error
func (*EventBus) PublishEventTimeoutWait ¶
func (b *EventBus) PublishEventTimeoutWait(data EventDataRoundState) error
func (*EventBus) PublishEventTx ¶
func (b *EventBus) PublishEventTx(data EventDataTx) error
PublishEventTx publishes tx event with events from Result. Note it will add predefined keys (EventTypeKey, TxHashKey). Existing events with the same keys will be overwritten.
func (*EventBus) PublishEventUnlock ¶
func (b *EventBus) PublishEventUnlock(data EventDataRoundState) error
func (*EventBus) PublishEventValidBlock ¶
func (b *EventBus) PublishEventValidBlock(data EventDataRoundState) error
func (*EventBus) PublishEventValidatorSetUpdates ¶
func (b *EventBus) PublishEventValidatorSetUpdates(data EventDataValidatorSetUpdates) error
func (*EventBus) PublishEventVote ¶
func (b *EventBus) PublishEventVote(data EventDataVote) error
func (*EventBus) SubscribeUnbuffered ¶
func (b *EventBus) SubscribeUnbuffered( ctx context.Context, subscriber string, query tmpubsub.Query, ) (Subscription, error)
This method can be used for a local consensus explorer and synchronous testing. Do not use for for public facing / untrusted subscriptions!
func (*EventBus) Unsubscribe ¶
type EventBusSubscriber ¶
type EventBusSubscriber interface { Subscribe(ctx context.Context, subscriber string, query tmpubsub.Query, outCapacity ...int) (Subscription, error) Unsubscribe(ctx context.Context, args tmpubsub.UnsubscribeArgs) error UnsubscribeAll(ctx context.Context, subscriber string) error NumClients() int NumClientSubscriptions(clientID string) int }
type EventDataBlockSyncStatus ¶ added in v0.35.0
type EventDataBlockSyncStatus struct { Complete bool `json:"complete"` Height int64 `json:"height"` }
EventDataBlockSyncStatus shows the fastsync status and the height when the node state sync mechanism changes.
type EventDataNewBlock ¶
type EventDataNewBlock struct { Block *Block `json:"block"` BlockID BlockID `json:"block_id"` ResultBeginBlock abci.ResponseBeginBlock `json:"result_begin_block"` ResultEndBlock abci.ResponseEndBlock `json:"result_end_block"` }
type EventDataNewBlockHeader ¶
type EventDataNewBlockHeader struct { Header Header `json:"header"` NumTxs int64 `json:"num_txs"` // Number of txs in a block ResultBeginBlock abci.ResponseBeginBlock `json:"result_begin_block"` ResultEndBlock abci.ResponseEndBlock `json:"result_end_block"` }
type EventDataNewEvidence ¶ added in v0.34.0
type EventDataNewRound ¶
type EventDataNewRound struct { Height int64 `json:"height"` Round int32 `json:"round"` Step string `json:"step"` Proposer ValidatorInfo `json:"proposer"` }
type EventDataRoundState ¶
type EventDataRoundState struct { Height int64 `json:"height"` Round int32 `json:"round"` Step string `json:"step"` }
NOTE: This goes into the replay WAL
type EventDataStateSyncStatus ¶ added in v0.35.0
type EventDataStateSyncStatus struct { Complete bool `json:"complete"` Height int64 `json:"height"` }
EventDataStateSyncStatus shows the statesync status and the height when the node state sync mechanism changes.
type EventDataString ¶
type EventDataString string
type EventDataValidatorSetUpdates ¶
type EventDataValidatorSetUpdates struct {
ValidatorUpdates []*Validator `json:"validator_updates"`
}
type EventDataVote ¶
type EventDataVote struct {
Vote *Vote
}
type Evidence ¶
type Evidence interface { ABCI() []abci.Evidence // forms individual evidence to be sent to the application Bytes() []byte // bytes which comprise the evidence Hash() []byte // hash of the evidence Height() int64 // height of the infraction String() string // string format of the evidence Time() time.Time // time of the infraction ValidateBasic() error // basic consistency check }
Evidence represents any provable malicious activity by a validator. Verification logic for each evidence is part of the evidence module.
type EvidenceData ¶
type EvidenceData struct { Evidence EvidenceList `json:"evidence"` // contains filtered or unexported fields }
EvidenceData contains any evidence of malicious wrong-doing by validators
func (*EvidenceData) ByteSize ¶ added in v0.34.0
func (data *EvidenceData) ByteSize() int64
ByteSize returns the total byte size of all the evidence
func (*EvidenceData) FromProto ¶ added in v0.34.0
func (data *EvidenceData) FromProto(eviData *tmproto.EvidenceList) error
FromProto sets a protobuf EvidenceData to the given pointer.
func (*EvidenceData) Hash ¶
func (data *EvidenceData) Hash() tmbytes.HexBytes
Hash returns the hash of the data.
func (*EvidenceData) StringIndented ¶
func (data *EvidenceData) StringIndented(indent string) string
StringIndented returns a string representation of the evidence.
func (*EvidenceData) ToProto ¶ added in v0.34.0
func (data *EvidenceData) ToProto() (*tmproto.EvidenceList, error)
ToProto converts EvidenceData to protobuf
type EvidenceList ¶
type EvidenceList []Evidence
EvidenceList is a list of Evidence. Evidences is not a word.
func (EvidenceList) Has ¶
func (evl EvidenceList) Has(evidence Evidence) bool
Has returns true if the evidence is in the EvidenceList.
func (EvidenceList) Hash ¶
func (evl EvidenceList) Hash() []byte
Hash returns the simple merkle root hash of the EvidenceList.
func (EvidenceList) String ¶
func (evl EvidenceList) String() string
type EvidenceParams ¶
type EvidenceParams struct { MaxAgeNumBlocks int64 `json:"max_age_num_blocks"` // only accept new evidence more recent than this MaxAgeDuration time.Duration `json:"max_age_duration"` MaxBytes int64 `json:"max_bytes"` }
EvidenceParams determine how we handle evidence of malfeasance.
func DefaultEvidenceParams ¶
func DefaultEvidenceParams() EvidenceParams
DefaultEvidenceParams returns a default EvidenceParams.
type GenesisDoc ¶
type GenesisDoc struct { GenesisTime time.Time `json:"genesis_time"` ChainID string `json:"chain_id"` InitialHeight int64 `json:"initial_height"` ConsensusParams *ConsensusParams `json:"consensus_params,omitempty"` Validators []GenesisValidator `json:"validators,omitempty"` AppHash tmbytes.HexBytes `json:"app_hash"` AppState json.RawMessage `json:"app_state,omitempty"` }
GenesisDoc defines the initial conditions for a tendermint blockchain, in particular its validator set.
func GenesisDocFromFile ¶
func GenesisDocFromFile(genDocFile string) (*GenesisDoc, error)
GenesisDocFromFile reads JSON data from a file and unmarshalls it into a GenesisDoc.
func GenesisDocFromJSON ¶
func GenesisDocFromJSON(jsonBlob []byte) (*GenesisDoc, error)
GenesisDocFromJSON unmarshalls JSON data into a GenesisDoc.
func (*GenesisDoc) SaveAs ¶
func (genDoc *GenesisDoc) SaveAs(file string) error
SaveAs is a utility method for saving GenensisDoc as a JSON file.
func (*GenesisDoc) ValidateAndComplete ¶
func (genDoc *GenesisDoc) ValidateAndComplete() error
ValidateAndComplete checks that all necessary fields are present and fills in defaults for optional fields left empty
func (*GenesisDoc) ValidatorHash ¶
func (genDoc *GenesisDoc) ValidatorHash() []byte
ValidatorHash returns the hash of the validator set contained in the GenesisDoc
type GenesisValidator ¶
type GenesisValidator struct { Address Address `json:"address"` PubKey crypto.PubKey `json:"pub_key"` Power int64 `json:"power"` Name string `json:"name"` }
GenesisValidator is an initial validator.
type HashedParams ¶
HashedParams is a subset of ConsensusParams. It is amino encoded and hashed into the Header.ConsensusHash.
type Header ¶
type Header struct { // basic block info Version version.Consensus `json:"version"` ChainID string `json:"chain_id"` Height int64 `json:"height"` Time time.Time `json:"time"` // prev block info LastBlockID BlockID `json:"last_block_id"` // hashes of block data LastCommitHash tmbytes.HexBytes `json:"last_commit_hash"` // commit from validators from the last block DataHash tmbytes.HexBytes `json:"data_hash"` // transactions // hashes from the app output from the prev block ValidatorsHash tmbytes.HexBytes `json:"validators_hash"` // validators for the current block NextValidatorsHash tmbytes.HexBytes `json:"next_validators_hash"` // validators for the next block ConsensusHash tmbytes.HexBytes `json:"consensus_hash"` // consensus params for current block AppHash tmbytes.HexBytes `json:"app_hash"` // state after txs from the previous block // root hash of all results from the txs from the previous block // see `deterministicResponseDeliverTx` to understand which parts of a tx is hashed into here LastResultsHash tmbytes.HexBytes `json:"last_results_hash"` // consensus info EvidenceHash tmbytes.HexBytes `json:"evidence_hash"` // evidence included in the block ProposerAddress Address `json:"proposer_address"` // original proposer of the block }
Header defines the structure of a Tendermint block header. NOTE: changes to the Header should be duplicated in: - header.Hash() - abci.Header - https://github.com/tendermint/spec/blob/master/spec/blockchain/blockchain.md
func HeaderFromProto ¶ added in v0.33.5
FromProto sets a protobuf Header to the given pointer. It returns an error if the header is invalid.
func (*Header) Hash ¶
Hash returns the hash of the header. It computes a Merkle tree from the header fields ordered as they appear in the Header. Returns nil if ValidatorHash is missing, since a Header is not valid unless there is a ValidatorsHash (corresponding to the validator set).
func (*Header) Populate ¶
func (h *Header) Populate( version version.Consensus, chainID string, timestamp time.Time, lastBlockID BlockID, valHash, nextValHash []byte, consensusHash, appHash, lastResultsHash []byte, proposerAddress Address, )
Populate the Header with state-derived data. Call this after MakeBlock to complete the Header.
func (*Header) StringIndented ¶
StringIndented returns an indented string representation of the header.
func (Header) ValidateBasic ¶ added in v0.33.5
ValidateBasic performs stateless validation on a Header returning an error if any validation fails.
NOTE: Timestamp validation is subtle and handled elsewhere.
type LightBlock ¶ added in v0.34.0
type LightBlock struct { *SignedHeader `json:"signed_header"` ValidatorSet *ValidatorSet `json:"validator_set"` }
LightBlock is a SignedHeader and a ValidatorSet. It is the basis of the light client
func LightBlockFromProto ¶ added in v0.34.0
func LightBlockFromProto(pb *tmproto.LightBlock) (*LightBlock, error)
LightBlockFromProto converts from protobuf back into the Lightblock. An error is returned if either the validator set or signed header are invalid
func (LightBlock) String ¶ added in v0.34.0
func (lb LightBlock) String() string
String returns a string representation of the LightBlock
func (LightBlock) StringIndented ¶ added in v0.34.0
func (lb LightBlock) StringIndented(indent string) string
StringIndented returns an indented string representation of the LightBlock
SignedHeader ValidatorSet
func (*LightBlock) ToProto ¶ added in v0.34.0
func (lb *LightBlock) ToProto() (*tmproto.LightBlock, error)
ToProto converts the LightBlock to protobuf
func (LightBlock) ValidateBasic ¶ added in v0.34.0
func (lb LightBlock) ValidateBasic(chainID string) error
ValidateBasic checks that the data is correct and consistent
This does no verification of the signatures
type LightClientAttackEvidence ¶ added in v0.34.0
type LightClientAttackEvidence struct { ConflictingBlock *LightBlock CommonHeight int64 // abci specific information ByzantineValidators []*Validator // validators in the validator set that misbehaved in creating the conflicting block TotalVotingPower int64 // total voting power of the validator set at the common height Timestamp time.Time // timestamp of the block at the common height }
LightClientAttackEvidence is a generalized evidence that captures all forms of known attacks on a light client such that a full node can verify, propose and commit the evidence on-chain for punishment of the malicious validators. There are three forms of attacks: Lunatic, Equivocation and Amnesia. These attacks are exhaustive. You can find a more detailed overview of this at tendermint/docs/architecture/adr-047-handling-evidence-from-light-client.md
CommonHeight is used to indicate the type of attack. If the height is different to the conflicting block height, then nodes will treat this as of the Lunatic form, else it is of the Equivocation form.
func LightClientAttackEvidenceFromProto ¶ added in v0.34.0
func LightClientAttackEvidenceFromProto(lpb *tmproto.LightClientAttackEvidence) (*LightClientAttackEvidence, error)
LightClientAttackEvidenceFromProto decodes protobuf
func (*LightClientAttackEvidence) ABCI ¶ added in v0.34.0
func (l *LightClientAttackEvidence) ABCI() []abci.Evidence
ABCI forms an array of abci evidence for each byzantine validator
func (*LightClientAttackEvidence) Bytes ¶ added in v0.34.0
func (l *LightClientAttackEvidence) Bytes() []byte
Bytes returns the proto-encoded evidence as a byte array
func (*LightClientAttackEvidence) ConflictingHeaderIsInvalid ¶ added in v0.34.0
func (l *LightClientAttackEvidence) ConflictingHeaderIsInvalid(trustedHeader *Header) bool
ConflictingHeaderIsInvalid takes a trusted header and matches it againt a conflicting header to determine whether the conflicting header was the product of a valid state transition or not. If it is then all the deterministic fields of the header should be the same. If not, it is an invalid header and constitutes a lunatic attack.
func (*LightClientAttackEvidence) GenerateABCI ¶ added in v0.35.0
func (l *LightClientAttackEvidence) GenerateABCI( commonVals *ValidatorSet, trustedHeader *SignedHeader, evidenceTime time.Time, )
GenerateABCI populates the ABCI component of the evidence: the timestamp, total voting power and byantine validators
func (*LightClientAttackEvidence) GetByzantineValidators ¶ added in v0.34.0
func (l *LightClientAttackEvidence) GetByzantineValidators(commonVals *ValidatorSet, trusted *SignedHeader) []*Validator
GetByzantineValidators finds out what style of attack LightClientAttackEvidence was and then works out who the malicious validators were and returns them. This is used both for forming the ByzantineValidators field and for validating that it is correct. Validators are ordered based on validator power
func (*LightClientAttackEvidence) Hash ¶ added in v0.34.0
func (l *LightClientAttackEvidence) Hash() []byte
Hash returns the hash of the header and the commonHeight. This is designed to cause hash collisions with evidence that have the same conflicting header and common height but different permutations of validator commit signatures. The reason for this is that we don't want to allow several permutations of the same evidence to be committed on chain. Ideally we commit the header with the most commit signatures (captures the most byzantine validators) but anything greater than 1/3 is sufficient. TODO: We should change the hash to include the commit, header, total voting power, byzantine validators and timestamp
func (*LightClientAttackEvidence) Height ¶ added in v0.34.0
func (l *LightClientAttackEvidence) Height() int64
Height returns the last height at which the primary provider and witness provider had the same header. We use this as the height of the infraction rather than the actual conflicting header because we know that the malicious validators were bonded at this height which is important for evidence expiry
func (*LightClientAttackEvidence) String ¶ added in v0.34.0
func (l *LightClientAttackEvidence) String() string
String returns a string representation of LightClientAttackEvidence
func (*LightClientAttackEvidence) Time ¶ added in v0.34.0
func (l *LightClientAttackEvidence) Time() time.Time
Time returns the time of the common block where the infraction leveraged off.
func (*LightClientAttackEvidence) ToProto ¶ added in v0.34.0
func (l *LightClientAttackEvidence) ToProto() (*tmproto.LightClientAttackEvidence, error)
ToProto encodes LightClientAttackEvidence to protobuf
func (*LightClientAttackEvidence) ValidateABCI ¶ added in v0.35.0
func (l *LightClientAttackEvidence) ValidateABCI( commonVals *ValidatorSet, trustedHeader *SignedHeader, evidenceTime time.Time, ) error
ValidateABCI validates the ABCI component of the evidence by checking the timestamp, byzantine validators and total voting power all match. ABCI components are validated separately because they can be re generated if invalid.
func (*LightClientAttackEvidence) ValidateBasic ¶ added in v0.34.0
func (l *LightClientAttackEvidence) ValidateBasic() error
ValidateBasic performs basic validation such that the evidence is consistent and can now be used for verification.
type MockPV ¶
MockPV implements PrivValidator without any safety or persistence. Only use it for testing.
func NewMockPVWithParams ¶
func NewMockPVWithParams(privKey crypto.PrivKey, breakProposalSigning, breakVoteSigning bool) MockPV
NewMockPVWithParams allows one to create a MockPV instance, but with finer grained control over the operation of the mock validator. This is useful for mocking test failures.
func (MockPV) ExtractIntoValidator ¶ added in v0.34.0
func (MockPV) SignProposal ¶
func (pv MockPV) SignProposal(ctx context.Context, chainID string, proposal *tmproto.Proposal) error
Implements PrivValidator.
type NetAddress ¶ added in v0.35.0
NetAddress defines information about a peer on the network including its ID, IP address, and port.
func NewNetAddress ¶ added in v0.35.0
func NewNetAddress(id NodeID, addr net.Addr) *NetAddress
NewNetAddress returns a new NetAddress using the provided TCP address. When testing, other net.Addr (except TCP) will result in using 0.0.0.0:0. When normal run, other net.Addr (except TCP) will panic. Panics if ID is invalid. TODO: socks proxies?
func NewNetAddressIPPort ¶ added in v0.35.0
func NewNetAddressIPPort(ip net.IP, port uint16) *NetAddress
NewNetAddressIPPort returns a new NetAddress using the provided IP and port number.
func NewNetAddressString ¶ added in v0.35.0
func NewNetAddressString(addr string) (*NetAddress, error)
NewNetAddressString returns a new NetAddress using the provided address in the form of "ID@IP:Port". Also resolves the host if host is not an IP. Errors are of type ErrNetAddressXxx where Xxx is in (NoID, Invalid, Lookup)
func (*NetAddress) Dial ¶ added in v0.35.0
func (na *NetAddress) Dial() (net.Conn, error)
Dial calls net.Dial on the address.
func (*NetAddress) DialString ¶ added in v0.35.0
func (na *NetAddress) DialString() string
func (*NetAddress) DialTimeout ¶ added in v0.35.0
DialTimeout calls net.DialTimeout on the address.
func (*NetAddress) Equals ¶ added in v0.35.0
func (na *NetAddress) Equals(other interface{}) bool
Equals reports whether na and other are the same addresses, including their ID, IP, and Port.
func (*NetAddress) Local ¶ added in v0.35.0
func (na *NetAddress) Local() bool
Local returns true if it is a local address.
func (*NetAddress) OnionCatTor ¶ added in v0.35.0
func (na *NetAddress) OnionCatTor() bool
func (*NetAddress) RFC1918 ¶ added in v0.35.0
func (na *NetAddress) RFC1918() bool
func (*NetAddress) RFC3849 ¶ added in v0.35.0
func (na *NetAddress) RFC3849() bool
func (*NetAddress) RFC3927 ¶ added in v0.35.0
func (na *NetAddress) RFC3927() bool
func (*NetAddress) RFC3964 ¶ added in v0.35.0
func (na *NetAddress) RFC3964() bool
func (*NetAddress) RFC4193 ¶ added in v0.35.0
func (na *NetAddress) RFC4193() bool
func (*NetAddress) RFC4380 ¶ added in v0.35.0
func (na *NetAddress) RFC4380() bool
func (*NetAddress) RFC4843 ¶ added in v0.35.0
func (na *NetAddress) RFC4843() bool
func (*NetAddress) RFC4862 ¶ added in v0.35.0
func (na *NetAddress) RFC4862() bool
func (*NetAddress) RFC6052 ¶ added in v0.35.0
func (na *NetAddress) RFC6052() bool
func (*NetAddress) RFC6145 ¶ added in v0.35.0
func (na *NetAddress) RFC6145() bool
func (*NetAddress) ReachabilityTo ¶ added in v0.35.0
func (na *NetAddress) ReachabilityTo(o *NetAddress) int
ReachabilityTo checks whenever o can be reached from na.
func (*NetAddress) Routable ¶ added in v0.35.0
func (na *NetAddress) Routable() bool
Routable returns true if the address is routable.
func (*NetAddress) Same ¶ added in v0.35.0
func (na *NetAddress) Same(other interface{}) bool
Same returns true is na has the same non-empty ID or DialString as other.
func (*NetAddress) String ¶ added in v0.35.0
func (na *NetAddress) String() string
String representation: <ID>@<IP>:<PORT>
func (*NetAddress) Valid ¶ added in v0.35.0
func (na *NetAddress) Valid() error
For IPv4 these are either a 0 or all bits set address. For IPv6 a zero address or one that matches the RFC3849 documentation address format.
type NodeID ¶ added in v0.35.0
type NodeID string
NodeID is a hex-encoded crypto.Address. It must be lowercased (for uniqueness) and of length 2*NodeIDByteLength.
func NewNodeID ¶ added in v0.35.0
NewNodeID returns a lowercased (normalized) NodeID, or errors if the node ID is invalid.
func NodeIDFromPubKey ¶ added in v0.35.0
NodeIDFromPubKey creates a node ID from a given PubKey address.
func (NodeID) AddressString ¶ added in v0.35.0
IDAddressString returns id@hostPort. It strips the leading protocol from protocolHostPort if it exists.
type NodeInfo ¶ added in v0.35.0
type NodeInfo struct { ProtocolVersion ProtocolVersion `json:"protocol_version"` // Authenticate NodeID NodeID `json:"id"` // authenticated identifier ListenAddr string `json:"listen_addr"` // accepting incoming // Check compatibility. // Channels are HexBytes so easier to read as JSON Network string `json:"network"` // network/chain ID Version string `json:"version"` // major.minor.revision // FIXME: This should be changed to uint16 to be consistent with the updated channel type Channels bytes.HexBytes `json:"channels"` // channels this node knows about // ASCIIText fields Moniker string `json:"moniker"` // arbitrary moniker Other NodeInfoOther `json:"other"` // other application specific data }
NodeInfo is the basic node information exchanged between two peers during the Tendermint P2P handshake.
func NodeInfoFromProto ¶ added in v0.35.0
func (*NodeInfo) AddChannel ¶ added in v0.35.0
AddChannel is used by the router when a channel is opened to add it to the node info
func (NodeInfo) CompatibleWith ¶ added in v0.35.0
CompatibleWith checks if two NodeInfo are compatible with each other. CONTRACT: two nodes are compatible if the Block version and network match and they have at least one channel in common.
func (NodeInfo) NetAddress ¶ added in v0.35.0
func (info NodeInfo) NetAddress() (*NetAddress, error)
NetAddress returns a NetAddress derived from the NodeInfo - it includes the authenticated peer ID and the self-reported ListenAddr. Note that the ListenAddr is not authenticated and may not match that address actually dialed if its an outbound peer.
func (NodeInfo) Validate ¶ added in v0.35.0
Validate checks the self-reported NodeInfo is safe. It returns an error if there are too many Channels, if there are any duplicate Channels, if the ListenAddr is malformed, or if the ListenAddr is a host name that can not be resolved to some IP. TODO: constraints for Moniker/Other? Or is that for the UI ? JAE: It needs to be done on the client, but to prevent ambiguous unicode characters, maybe it's worth sanitizing it here. In the future we might want to validate these, once we have a name-resolution system up. International clients could then use punycode (or we could use url-encoding), and we just need to be careful with how we handle that in our clients. (e.g. off by default).
type NodeInfoOther ¶ added in v0.35.0
type NodeInfoOther struct { TxIndex string `json:"tx_index"` RPCAddress string `json:"rpc_address"` }
NodeInfoOther is the misc. applcation specific data
type NodeKey ¶ added in v0.35.0
type NodeKey struct { // Canonical ID - hex-encoded pubkey's address (IDByteLength bytes) ID NodeID `json:"id"` // Private key PrivKey crypto.PrivKey `json:"priv_key"` }
NodeKey is the persistent peer key. It contains the nodes private key for authentication.
func LoadNodeKey ¶ added in v0.35.0
LoadNodeKey loads NodeKey located in filePath.
func LoadOrGenNodeKey ¶ added in v0.35.0
LoadOrGenNodeKey attempts to load the NodeKey from the given filePath. If the file does not exist, it generates and saves a new NodeKey.
type NopEventBus ¶
type NopEventBus struct{}
-----------------------------------------------------------------------------
func (NopEventBus) PublishEventBlockSyncStatus ¶ added in v0.35.0
func (NopEventBus) PublishEventBlockSyncStatus(data EventDataBlockSyncStatus) error
func (NopEventBus) PublishEventCompleteProposal ¶
func (NopEventBus) PublishEventCompleteProposal(data EventDataRoundState) error
func (NopEventBus) PublishEventLock ¶
func (NopEventBus) PublishEventLock(data EventDataRoundState) error
func (NopEventBus) PublishEventNewBlock ¶
func (NopEventBus) PublishEventNewBlock(data EventDataNewBlock) error
func (NopEventBus) PublishEventNewBlockHeader ¶
func (NopEventBus) PublishEventNewBlockHeader(data EventDataNewBlockHeader) error
func (NopEventBus) PublishEventNewEvidence ¶ added in v0.34.0
func (NopEventBus) PublishEventNewEvidence(evidence EventDataNewEvidence) error
func (NopEventBus) PublishEventNewRound ¶
func (NopEventBus) PublishEventNewRound(data EventDataRoundState) error
func (NopEventBus) PublishEventNewRoundStep ¶
func (NopEventBus) PublishEventNewRoundStep(data EventDataRoundState) error
func (NopEventBus) PublishEventPolka ¶
func (NopEventBus) PublishEventPolka(data EventDataRoundState) error
func (NopEventBus) PublishEventRelock ¶
func (NopEventBus) PublishEventRelock(data EventDataRoundState) error
func (NopEventBus) PublishEventStateSyncStatus ¶ added in v0.35.0
func (NopEventBus) PublishEventStateSyncStatus(data EventDataStateSyncStatus) error
func (NopEventBus) PublishEventTimeoutPropose ¶
func (NopEventBus) PublishEventTimeoutPropose(data EventDataRoundState) error
func (NopEventBus) PublishEventTimeoutWait ¶
func (NopEventBus) PublishEventTimeoutWait(data EventDataRoundState) error
func (NopEventBus) PublishEventTx ¶
func (NopEventBus) PublishEventTx(data EventDataTx) error
func (NopEventBus) PublishEventUnlock ¶
func (NopEventBus) PublishEventUnlock(data EventDataRoundState) error
func (NopEventBus) PublishEventValidatorSetUpdates ¶
func (NopEventBus) PublishEventValidatorSetUpdates(data EventDataValidatorSetUpdates) error
func (NopEventBus) PublishEventVote ¶
func (NopEventBus) PublishEventVote(data EventDataVote) error
func (NopEventBus) Unsubscribe ¶
func (NopEventBus) Unsubscribe(ctx context.Context, args tmpubsub.UnsubscribeArgs) error
func (NopEventBus) UnsubscribeAll ¶
func (NopEventBus) UnsubscribeAll(ctx context.Context, subscriber string) error
type P2PID ¶
type P2PID string
UNSTABLE XXX: duplicate of p2p.ID to avoid dependence between packages. Perhaps we can have a minimal types package containing this (and other things?) that both `types` and `p2p` import ?
type Part ¶
type Part struct { Index uint32 `json:"index"` Bytes tmbytes.HexBytes `json:"bytes"` Proof merkle.Proof `json:"proof"` }
func (*Part) StringIndented ¶
StringIndented returns an indented Part.
See merkle.Proof#StringIndented
func (*Part) ValidateBasic ¶
ValidateBasic performs basic validation.
type PartSet ¶
type PartSet struct {
// contains filtered or unexported fields
}
func NewPartSetFromData ¶
Returns an immutable, full PartSet from the data bytes. The data bytes are split into "partSize" chunks, and merkle tree computed. CONTRACT: partSize is greater than zero.
func NewPartSetFromHeader ¶
func NewPartSetFromHeader(header PartSetHeader) *PartSet
Returns an empty PartSet ready to be populated.
func (*PartSet) HasHeader ¶
func (ps *PartSet) HasHeader(header PartSetHeader) bool
func (*PartSet) Header ¶
func (ps *PartSet) Header() PartSetHeader
func (*PartSet) IsComplete ¶
func (*PartSet) MarshalJSON ¶
type PartSetHeader ¶
func PartSetHeaderFromProto ¶ added in v0.33.5
func PartSetHeaderFromProto(ppsh *tmproto.PartSetHeader) (*PartSetHeader, error)
FromProto sets a protobuf PartSetHeader to the given pointer
func (PartSetHeader) Equals ¶
func (psh PartSetHeader) Equals(other PartSetHeader) bool
func (PartSetHeader) IsZero ¶
func (psh PartSetHeader) IsZero() bool
func (PartSetHeader) String ¶
func (psh PartSetHeader) String() string
String returns a string representation of PartSetHeader.
1. total number of parts 2. first 6 bytes of the hash
func (*PartSetHeader) ToProto ¶ added in v0.33.5
func (psh *PartSetHeader) ToProto() tmproto.PartSetHeader
ToProto converts PartSetHeader to protobuf
func (PartSetHeader) ValidateBasic ¶
func (psh PartSetHeader) ValidateBasic() error
ValidateBasic performs basic validation.
type PartSetReader ¶
type PartSetReader struct {
// contains filtered or unexported fields
}
func NewPartSetReader ¶
func NewPartSetReader(parts []*Part) *PartSetReader
type PrivValidator ¶
type PrivValidator interface { GetPubKey(context.Context) (crypto.PubKey, error) SignVote(ctx context.Context, chainID string, vote *tmproto.Vote) error SignProposal(ctx context.Context, chainID string, proposal *tmproto.Proposal) error }
PrivValidator defines the functionality of a local Tendermint validator that signs votes and proposals, and never double signs.
type PrivValidatorType ¶ added in v0.35.0
type PrivValidatorType uint8
PrivValidatorType defines the implemtation types.
type PrivValidatorsByAddress ¶
type PrivValidatorsByAddress []PrivValidator
func (PrivValidatorsByAddress) Len ¶
func (pvs PrivValidatorsByAddress) Len() int
func (PrivValidatorsByAddress) Less ¶
func (pvs PrivValidatorsByAddress) Less(i, j int) bool
func (PrivValidatorsByAddress) Swap ¶
func (pvs PrivValidatorsByAddress) Swap(i, j int)
type Proposal ¶
type Proposal struct { Type tmproto.SignedMsgType Height int64 `json:"height"` Round int32 `json:"round"` // there can not be greater than 2_147_483_647 rounds POLRound int32 `json:"pol_round"` // -1 if null. BlockID BlockID `json:"block_id"` Timestamp time.Time `json:"timestamp"` Signature []byte `json:"signature"` }
Proposal defines a block proposal for the consensus. It refers to the block by BlockID field. It must be signed by the correct proposer for the given Height/Round to be considered valid. It may depend on votes from a previous round, a so-called Proof-of-Lock (POL) round, as noted in the POLRound. If POLRound >= 0, then BlockID corresponds to the block that is locked in POLRound.
func NewProposal ¶
NewProposal returns a new Proposal. If there is no POLRound, polRound should be -1.
func ProposalFromProto ¶ added in v0.33.5
FromProto sets a protobuf Proposal to the given pointer. It returns an error if the proposal is invalid.
func (*Proposal) String ¶
String returns a string representation of the Proposal.
1. height 2. round 3. block ID 4. POL round 5. first 6 bytes of signature 6. timestamp
See BlockID#String.
func (*Proposal) ValidateBasic ¶
ValidateBasic performs basic validation.
type ProtocolVersion ¶ added in v0.35.0
type ProtocolVersion struct { P2P uint64 `json:"p2p"` Block uint64 `json:"block"` App uint64 `json:"app"` }
ProtocolVersion contains the protocol versions for the software.
type Signable ¶
Signable is an interface for all signable things. It typically removes signatures before serializing. SignBytes returns the bytes to be signed NOTE: chainIDs are part of the SignBytes but not necessarily the object themselves. NOTE: Expected to panic if there is an error marshaling.
type SignedHeader ¶
SignedHeader is a header along with the commits that prove it.
func SignedHeaderFromProto ¶ added in v0.33.5
func SignedHeaderFromProto(shp *tmproto.SignedHeader) (*SignedHeader, error)
FromProto sets a protobuf SignedHeader to the given pointer. It returns an error if the header or the commit is invalid.
func (SignedHeader) String ¶
func (sh SignedHeader) String() string
String returns a string representation of SignedHeader.
func (SignedHeader) StringIndented ¶
func (sh SignedHeader) StringIndented(indent string) string
StringIndented returns an indented string representation of SignedHeader.
Header Commit
func (*SignedHeader) ToProto ¶ added in v0.33.5
func (sh *SignedHeader) ToProto() *tmproto.SignedHeader
ToProto converts SignedHeader to protobuf
func (SignedHeader) ValidateBasic ¶
func (sh SignedHeader) ValidateBasic(chainID string) error
ValidateBasic does basic consistency checks and makes sure the header and commit are consistent.
NOTE: This does not actually check the cryptographic signatures. Make sure to use a Verifier to validate the signatures actually provide a significantly strong proof for this header's validity.
type Subscription ¶
type Tx ¶
type Tx []byte
Tx is an arbitrary byte array. NOTE: Tx has no types at this level, so when wire encoded it's just length-prefixed. Might we want types here ?
type TxEventPublisher ¶
type TxEventPublisher interface {
PublishEventTx(EventDataTx) error
}
type TxProof ¶
type TxProof struct { RootHash tmbytes.HexBytes `json:"root_hash"` Data Tx `json:"data"` Proof merkle.Proof `json:"proof"` }
TxProof represents a Merkle proof of the presence of a transaction in the Merkle tree.
type Txs ¶
type Txs []Tx
Txs is a slice of Tx.
func (Txs) Hash ¶
Hash returns the Merkle root hash of the transaction hashes. i.e. the leaves of the tree are the hashes of the txs.
func (Txs) IndexByHash ¶
IndexByHash returns the index of this transaction hash in the list, or -1 if not found
type Validator ¶
type Validator struct { Address Address `json:"address"` PubKey crypto.PubKey `json:"pub_key"` VotingPower int64 `json:"voting_power"` ProposerPriority int64 `json:"proposer_priority"` }
Volatile state for each Validator NOTE: The ProposerPriority is not included in Validator.Hash(); make sure to update that method if changes are made here
func NewValidator ¶
NewValidator returns a new validator with the given pubkey and voting power.
func ValidatorFromProto ¶ added in v0.33.5
FromProto sets a protobuf Validator to the given pointer. It returns an error if the public key is invalid.
func (*Validator) Bytes ¶
Bytes computes the unique encoding of a validator with a given voting power. These are the bytes that gets hashed in consensus. It excludes address as its redundant with the pubkey. This also excludes ProposerPriority which changes every round.
func (*Validator) CompareProposerPriority ¶
Returns the one with higher ProposerPriority.
func (*Validator) Copy ¶
Creates a new copy of the validator so we can mutate ProposerPriority. Panics if the validator is nil.
func (*Validator) String ¶
String returns a string representation of String.
1. address 2. public key 3. voting power 4. proposer priority
func (*Validator) ValidateBasic ¶ added in v0.34.0
ValidateBasic performs basic validation.
type ValidatorInfo ¶
type ValidatorParams ¶
type ValidatorParams struct {
PubKeyTypes []string `json:"pub_key_types"`
}
ValidatorParams restrict the public key types validators can use. NOTE: uses ABCI pubkey naming, not Amino names.
func DefaultValidatorParams ¶
func DefaultValidatorParams() ValidatorParams
DefaultValidatorParams returns a default ValidatorParams, which allows only ed25519 pubkeys.
func (*ValidatorParams) IsValidPubkeyType ¶
func (val *ValidatorParams) IsValidPubkeyType(pubkeyType string) bool
type ValidatorSet ¶
type ValidatorSet struct { // NOTE: persisted via reflect, must be exported. Validators []*Validator `json:"validators"` Proposer *Validator `json:"proposer"` // contains filtered or unexported fields }
ValidatorSet represent a set of *Validator at a given height.
The validators can be fetched by address or index. The index is in order of .VotingPower, so the indices are fixed for all rounds of a given blockchain height - ie. the validators are sorted by their voting power (descending). Secondary index - .Address (ascending).
On the other hand, the .ProposerPriority of each validator and the designated .GetProposer() of a set changes every round, upon calling .IncrementProposerPriority().
NOTE: Not goroutine-safe. NOTE: All get/set to validators should copy the value for safety.
func NewValidatorSet ¶
func NewValidatorSet(valz []*Validator) *ValidatorSet
NewValidatorSet initializes a ValidatorSet by copying over the values from `valz`, a list of Validators. If valz is nil or empty, the new ValidatorSet will have an empty list of Validators.
The addresses of validators in `valz` must be unique otherwise the function panics.
Note the validator set size has an implied limit equal to that of the MaxVotesCount - commits by a validator set larger than this will fail validation.
func ValidatorSetFromExistingValidators ¶ added in v0.34.0
func ValidatorSetFromExistingValidators(valz []*Validator) (*ValidatorSet, error)
ValidatorSetFromExistingValidators takes an existing array of validators and rebuilds the exact same validator set that corresponds to it without changing the proposer priority or power if any of the validators fail validate basic then an empty set is returned.
func ValidatorSetFromProto ¶ added in v0.33.5
func ValidatorSetFromProto(vp *tmproto.ValidatorSet) (*ValidatorSet, error)
ValidatorSetFromProto sets a protobuf ValidatorSet to the given pointer. It returns an error if any of the validators from the set or the proposer is invalid
func (*ValidatorSet) Copy ¶
func (vals *ValidatorSet) Copy() *ValidatorSet
Copy each validator into a new ValidatorSet.
func (*ValidatorSet) CopyIncrementProposerPriority ¶
func (vals *ValidatorSet) CopyIncrementProposerPriority(times int32) *ValidatorSet
CopyIncrementProposerPriority increments ProposerPriority and updates the proposer on a copy, and returns it.
func (*ValidatorSet) GetByAddress ¶
func (vals *ValidatorSet) GetByAddress(address []byte) (index int32, val *Validator)
GetByAddress returns an index of the validator with address and validator itself (copy) if found. Otherwise, -1 and nil are returned.
func (*ValidatorSet) GetByIndex ¶
func (vals *ValidatorSet) GetByIndex(index int32) (address []byte, val *Validator)
GetByIndex returns the validator's address and validator itself (copy) by index. It returns nil values if index is less than 0 or greater or equal to len(ValidatorSet.Validators).
func (*ValidatorSet) GetProposer ¶
func (vals *ValidatorSet) GetProposer() (proposer *Validator)
GetProposer returns the current proposer. If the validator set is empty, nil is returned.
func (*ValidatorSet) HasAddress ¶
func (vals *ValidatorSet) HasAddress(address []byte) bool
HasAddress returns true if address given is in the validator set, false - otherwise.
func (*ValidatorSet) Hash ¶
func (vals *ValidatorSet) Hash() []byte
Hash returns the Merkle root hash build using validators (as leaves) in the set.
func (*ValidatorSet) IncrementProposerPriority ¶
func (vals *ValidatorSet) IncrementProposerPriority(times int32)
IncrementProposerPriority increments ProposerPriority of each validator and updates the proposer. Panics if validator set is empty. `times` must be positive.
func (*ValidatorSet) IsNilOrEmpty ¶
func (vals *ValidatorSet) IsNilOrEmpty() bool
IsNilOrEmpty returns true if validator set is nil or empty.
func (*ValidatorSet) Iterate ¶
func (vals *ValidatorSet) Iterate(fn func(index int, val *Validator) bool)
Iterate will run the given function over the set.
func (*ValidatorSet) RescalePriorities ¶
func (vals *ValidatorSet) RescalePriorities(diffMax int64)
RescalePriorities rescales the priorities such that the distance between the maximum and minimum is smaller than `diffMax`. Panics if validator set is empty.
func (*ValidatorSet) Size ¶
func (vals *ValidatorSet) Size() int
Size returns the length of the validator set.
func (*ValidatorSet) String ¶
func (vals *ValidatorSet) String() string
String returns a string representation of ValidatorSet.
See StringIndented.
func (*ValidatorSet) StringIndented ¶
func (vals *ValidatorSet) StringIndented(indent string) string
StringIndented returns an intended String.
See Validator#String.
func (*ValidatorSet) ToProto ¶ added in v0.33.5
func (vals *ValidatorSet) ToProto() (*tmproto.ValidatorSet, error)
ToProto converts ValidatorSet to protobuf
func (*ValidatorSet) TotalVotingPower ¶
func (vals *ValidatorSet) TotalVotingPower() int64
TotalVotingPower returns the sum of the voting powers of all validators. It recomputes the total voting power if required.
func (*ValidatorSet) UpdateWithChangeSet ¶
func (vals *ValidatorSet) UpdateWithChangeSet(changes []*Validator) error
UpdateWithChangeSet attempts to update the validator set with 'changes'. It performs the following steps:
- validates the changes making sure there are no duplicates and splits them in updates and deletes
- verifies that applying the changes will not result in errors
- computes the total voting power BEFORE removals to ensure that in the next steps the priorities across old and newly added validators are fair
- computes the priorities of new validators against the final set
- applies the updates against the validator set
- applies the removals against the validator set
- performs scaling and centering of priority values
If an error is detected during verification steps, it is returned and the validator set is not changed.
func (*ValidatorSet) ValidateBasic ¶ added in v0.34.0
func (vals *ValidatorSet) ValidateBasic() error
func (*ValidatorSet) VerifyCommit ¶
func (vals *ValidatorSet) VerifyCommit(chainID string, blockID BlockID, height int64, commit *Commit) error
VerifyCommit verifies +2/3 of the set had signed the given commit and all other signatures are valid
func (*ValidatorSet) VerifyCommitLight ¶ added in v0.33.6
func (vals *ValidatorSet) VerifyCommitLight(chainID string, blockID BlockID, height int64, commit *Commit) error
VerifyCommitLight verifies +2/3 of the set had signed the given commit.
func (*ValidatorSet) VerifyCommitLightTrusting ¶ added in v0.33.6
func (vals *ValidatorSet) VerifyCommitLightTrusting(chainID string, commit *Commit, trustLevel tmmath.Fraction) error
VerifyCommitLightTrusting verifies that trustLevel of the validator set signed this commit.
type ValidatorsByAddress ¶
type ValidatorsByAddress []*Validator
ValidatorsByAddress implements sort.Interface for []*Validator based on the Address field.
func (ValidatorsByAddress) Len ¶
func (valz ValidatorsByAddress) Len() int
func (ValidatorsByAddress) Less ¶
func (valz ValidatorsByAddress) Less(i, j int) bool
func (ValidatorsByAddress) Swap ¶
func (valz ValidatorsByAddress) Swap(i, j int)
type ValidatorsByVotingPower ¶ added in v0.34.0
type ValidatorsByVotingPower []*Validator
ValidatorsByVotingPower implements sort.Interface for []*Validator based on the VotingPower and Address fields.
func (ValidatorsByVotingPower) Len ¶ added in v0.34.0
func (valz ValidatorsByVotingPower) Len() int
func (ValidatorsByVotingPower) Less ¶ added in v0.34.0
func (valz ValidatorsByVotingPower) Less(i, j int) bool
func (ValidatorsByVotingPower) Swap ¶ added in v0.34.0
func (valz ValidatorsByVotingPower) Swap(i, j int)
type VersionParams ¶ added in v0.35.0
type VersionParams struct {
AppVersion uint64 `json:"app_version"`
}
func DefaultVersionParams ¶ added in v0.34.0
func DefaultVersionParams() VersionParams
type Vote ¶
type Vote struct { Type tmproto.SignedMsgType `json:"type"` Height int64 `json:"height"` Round int32 `json:"round"` // assume there will not be greater than 2_147_483_647 rounds BlockID BlockID `json:"block_id"` // zero if vote is nil. Timestamp time.Time `json:"timestamp"` ValidatorAddress Address `json:"validator_address"` ValidatorIndex int32 `json:"validator_index"` Signature []byte `json:"signature"` }
Vote represents a prevote, precommit, or commit vote from validators for consensus.
func VoteFromProto ¶ added in v0.33.5
FromProto converts a proto generetad type to a handwritten type return type, nil if everything converts safely, otherwise nil, error
func (*Vote) String ¶
String returns a string representation of Vote.
1. validator index 2. first 6 bytes of validator address 3. height 4. round, 5. type byte 6. type string 7. first 6 bytes of block hash 8. first 6 bytes of signature 9. timestamp
func (*Vote) ToProto ¶ added in v0.33.5
ToProto converts the handwritten type to proto generated type return type, nil if everything converts safely, otherwise nil, error
func (*Vote) ValidateBasic ¶
ValidateBasic performs basic validation.
type VoteSet ¶
type VoteSet struct {
// contains filtered or unexported fields
}
VoteSet helps collect signatures from validators at each height+round for a predefined vote type.
We need VoteSet to be able to keep track of conflicting votes when validators double-sign. Yet, we can't keep track of *all* the votes seen, as that could be a DoS attack vector.
There are two storage areas for votes. 1. voteSet.votes 2. voteSet.votesByBlock
`.votes` is the "canonical" list of votes. It always has at least one vote, if a vote from a validator had been seen at all. Usually it keeps track of the first vote seen, but when a 2/3 majority is found, votes for that get priority and are copied over from `.votesByBlock`.
`.votesByBlock` keeps track of a list of votes for a particular block. There are two ways a &blockVotes{} gets created in `.votesByBlock`. 1. the first vote seen by a validator was for the particular block. 2. a peer claims to have seen 2/3 majority for the particular block.
Since the first vote from a validator will always get added in `.votesByBlock` , all votes in `.votes` will have a corresponding entry in `.votesByBlock`.
When a &blockVotes{} in `.votesByBlock` reaches a 2/3 majority quorum, its votes are copied into `.votes`.
All this is memory bounded because conflicting votes only get added if a peer told us to track that block, each peer only gets to tell us 1 such block, and, there's only a limited number of peers.
NOTE: Assumes that the sum total of voting power does not exceed MaxUInt64.
func CommitToVoteSet ¶ added in v0.31.6
func CommitToVoteSet(chainID string, commit *Commit, vals *ValidatorSet) *VoteSet
CommitToVoteSet constructs a VoteSet from the Commit and validator set. Panics if signatures from the commit can't be added to the voteset. Inverse of VoteSet.MakeCommit().
func NewVoteSet ¶
func NewVoteSet(chainID string, height int64, round int32, signedMsgType tmproto.SignedMsgType, valSet *ValidatorSet) *VoteSet
Constructs a new VoteSet struct used to accumulate votes for given height/round.
func (*VoteSet) AddVote ¶
Returns added=true if vote is valid and new. Otherwise returns err=ErrVote[
UnexpectedStep | InvalidIndex | InvalidAddress | InvalidSignature | InvalidBlockHash | ConflictingVotes ]
Duplicate votes return added=false, err=nil. Conflicting votes return added=*, err=ErrVoteConflictingVotes. NOTE: vote should not be mutated after adding. NOTE: VoteSet must not be nil NOTE: Vote must not be nil
func (*VoteSet) BitArrayByBlockID ¶
func (*VoteSet) BitArrayString ¶
Return the bit-array of votes including the fraction of power that has voted like: "BA{29:xx__x__x_x___x__x_______xxx__} 856/1304 = 0.66"
func (*VoteSet) GetByAddress ¶
func (*VoteSet) GetByIndex ¶
NOTE: if validator has conflicting votes, returns "canonical" vote Implements VoteSetReader.
func (*VoteSet) HasTwoThirdsAny ¶
func (*VoteSet) HasTwoThirdsMajority ¶
func (*VoteSet) LogString ¶ added in v0.34.9
LogString produces a logging suitable string representation of the vote set.
func (*VoteSet) MakeCommit ¶
MakeCommit constructs a Commit from the VoteSet. It only includes precommits for the block, which has 2/3+ majority, and nil.
Panics if the vote type is not PrecommitType or if there's no +2/3 votes for a single block.
func (*VoteSet) MarshalJSON ¶
Marshal the VoteSet to JSON. Same as String(), just in JSON, and without the height/round/signedMsgType (since its already included in the votes).
func (*VoteSet) SetPeerMaj23 ¶
If a peer claims that it has 2/3 majority for given blockKey, call this. NOTE: if there are too many peers, or too much peer churn, this can cause memory issues. TODO: implement ability to remove peers too NOTE: VoteSet must not be nil
func (*VoteSet) StringIndented ¶
StringIndented returns an indented String.
Height Round Type Votes Votes bit array 2/3+ majority
See Vote#String.
func (*VoteSet) StringShort ¶
StringShort returns a short representation of VoteSet.
1. height 2. round 3. signed msg type 4. first 2/3+ majority 5. fraction of voted power 6. votes bit array 7. 2/3+ majority for each peer
func (*VoteSet) TwoThirdsMajority ¶
If there was a +2/3 majority for blockID, return blockID and true. Else, return the empty BlockID{} and false.
func (*VoteSet) VoteStrings ¶
Returns a list of votes compressed to more readable strings.
type VoteSetJSON ¶
type VoteSetJSON struct { Votes []string `json:"votes"` VotesBitArray string `json:"votes_bit_array"` PeerMaj23s map[P2PID]BlockID `json:"peer_maj_23s"` }
More human readable JSON of the vote set NOTE: insufficient for unmarshaling from (compressed votes) TODO: make the peerMaj23s nicer to read (eg just the block hash)
Source Files ¶
- block.go
- block_meta.go
- canonical.go
- encoding_helper.go
- errors.go
- errors_p2p.go
- event_bus.go
- events.go
- evidence.go
- genesis.go
- keys.go
- light.go
- mempool.go
- netaddress.go
- node_id.go
- node_info.go
- node_key.go
- params.go
- part_set.go
- priv_validator.go
- proposal.go
- protobuf.go
- results.go
- signable.go
- signed_msg_type.go
- test_util.go
- tx.go
- utils.go
- validation.go
- validator.go
- validator_set.go
- vote.go
- vote_set.go