Documentation ¶
Index ¶
- Constants
- Variables
- func CanonicalTime(t time.Time) string
- func EventQueryTxFor(tx Tx) tmpubsub.Query
- func IsVoteTypeValid(type_ byte) bool
- func QueryForEvent(eventType string) tmpubsub.Query
- func RandValidator(randPower bool, minPower int64) (*Validator, PrivValidator)
- func RandValidatorSet(numValidators int, votingPower int64) (*ValidatorSet, []PrivValidator)
- func RegisterEventDatas(cdc *amino.Codec)
- func RegisterEvidences(cdc *amino.Codec)
- type ABCIResult
- type ABCIResults
- type Address
- type Block
- func (b *Block) AddEvidence(evidence []Evidence)
- func (b *Block) Hash() cmn.HexBytes
- func (b *Block) HashesTo(hash []byte) bool
- func (b *Block) MakePartSet(partSize int) *PartSet
- func (b *Block) String() string
- func (b *Block) StringIndented(indent string) string
- func (b *Block) StringShort() string
- func (b *Block) ValidateBasic() error
- type BlockEventPublisher
- type BlockGossip
- type BlockID
- type BlockMeta
- type BlockSize
- type BlockStore
- type BlockStoreRPC
- type CanonicalJSONBlockID
- type CanonicalJSONHeartbeat
- type CanonicalJSONPartSetHeader
- type CanonicalJSONProposal
- type CanonicalJSONVote
- type Commit
- func (commit *Commit) BitArray() *cmn.BitArray
- func (commit *Commit) FirstPrecommit() *Vote
- func (commit *Commit) GetByIndex(index int) *Vote
- func (commit *Commit) Hash() cmn.HexBytes
- func (commit *Commit) Height() int64
- func (commit *Commit) IsCommit() bool
- func (commit *Commit) Round() int
- func (commit *Commit) Size() int
- func (commit *Commit) StringIndented(indent string) string
- func (commit *Commit) Type() byte
- func (commit *Commit) ValidateBasic() error
- type ConsensusParams
- type Data
- type DuplicateVoteEvidence
- func (dve *DuplicateVoteEvidence) Address() []byte
- func (dve *DuplicateVoteEvidence) Equal(ev Evidence) bool
- func (dve *DuplicateVoteEvidence) Hash() []byte
- func (dve *DuplicateVoteEvidence) Height() int64
- func (dve *DuplicateVoteEvidence) Index() int
- func (dve *DuplicateVoteEvidence) String() string
- func (dve *DuplicateVoteEvidence) Verify(chainID string) error
- type ErrEvidenceInvalid
- type ErrVoteConflictingVotes
- type EventBus
- func (b *EventBus) OnStart() error
- func (b *EventBus) OnStop()
- func (b *EventBus) Publish(eventType string, eventData TMEventData) error
- func (b *EventBus) PublishEventCompleteProposal(event EventDataRoundState) error
- func (b *EventBus) PublishEventLock(event EventDataRoundState) error
- func (b *EventBus) PublishEventNewBlock(event EventDataNewBlock) error
- func (b *EventBus) PublishEventNewBlockHeader(event EventDataNewBlockHeader) error
- func (b *EventBus) PublishEventNewRound(event EventDataRoundState) error
- func (b *EventBus) PublishEventNewRoundStep(event EventDataRoundState) error
- func (b *EventBus) PublishEventPolka(event EventDataRoundState) error
- func (b *EventBus) PublishEventProposalHeartbeat(event EventDataProposalHeartbeat) error
- func (b *EventBus) PublishEventRelock(event EventDataRoundState) error
- func (b *EventBus) PublishEventTimeoutPropose(event EventDataRoundState) error
- func (b *EventBus) PublishEventTimeoutWait(event EventDataRoundState) error
- func (b *EventBus) PublishEventTx(event EventDataTx) error
- func (b *EventBus) PublishEventUnlock(event EventDataRoundState) error
- func (b *EventBus) PublishEventVote(event EventDataVote) error
- func (b *EventBus) SetLogger(l log.Logger)
- func (b *EventBus) Subscribe(ctx context.Context, subscriber string, query tmpubsub.Query, ...) error
- func (b *EventBus) Unsubscribe(ctx context.Context, subscriber string, query tmpubsub.Query) error
- func (b *EventBus) UnsubscribeAll(ctx context.Context, subscriber string) error
- type EventBusSubscriber
- type EventDataNewBlock
- type EventDataNewBlockHeader
- type EventDataProposalHeartbeat
- type EventDataRoundState
- type EventDataString
- type EventDataTx
- type EventDataVote
- type Evidence
- type EvidenceData
- type EvidenceList
- type EvidenceParams
- type EvidencePool
- type GenesisDoc
- type GenesisValidator
- type Header
- type Heartbeat
- type Mempool
- type MockBadEvidence
- type MockEvidencePool
- type MockGoodEvidence
- func (e MockGoodEvidence) Address() []byte
- func (e MockGoodEvidence) Equal(ev Evidence) bool
- func (e MockGoodEvidence) Hash() []byte
- func (e MockGoodEvidence) Height() int64
- func (e MockGoodEvidence) Index() int
- func (e MockGoodEvidence) String() string
- func (e MockGoodEvidence) Verify(chainID string) error
- type MockMempool
- func (m MockMempool) CheckTx(tx Tx, cb func(*abci.Response)) error
- func (m MockMempool) EnableTxsAvailable()
- func (m MockMempool) Flush()
- func (m MockMempool) FlushAppConn() error
- func (m MockMempool) Lock()
- func (m MockMempool) Reap(n int) Txs
- func (m MockMempool) Size() int
- func (m MockMempool) TxsAvailable() <-chan int64
- func (m MockMempool) Unlock()
- func (m MockMempool) Update(height int64, txs Txs) error
- type MockPV
- func (pv *MockPV) DisableChecks()
- func (pv *MockPV) GetAddress() Address
- func (pv *MockPV) GetPubKey() crypto.PubKey
- func (pv *MockPV) SignHeartbeat(chainID string, heartbeat *Heartbeat) error
- func (pv *MockPV) SignProposal(chainID string, proposal *Proposal) error
- func (pv *MockPV) SignVote(chainID string, vote *Vote) error
- func (pv *MockPV) String() string
- type NopEventBus
- func (NopEventBus) PublishEventCompleteProposal(rs EventDataRoundState) error
- func (NopEventBus) PublishEventLock(rs EventDataRoundState) error
- func (NopEventBus) PublishEventNewBlock(block EventDataNewBlock) error
- func (NopEventBus) PublishEventNewBlockHeader(header EventDataNewBlockHeader) error
- func (NopEventBus) PublishEventNewRound(rs EventDataRoundState) error
- func (NopEventBus) PublishEventNewRoundStep(rs EventDataRoundState) error
- func (NopEventBus) PublishEventPolka(rs EventDataRoundState) error
- func (NopEventBus) PublishEventRelock(rs EventDataRoundState) error
- func (NopEventBus) PublishEventTimeoutPropose(rs EventDataRoundState) error
- func (NopEventBus) PublishEventTimeoutWait(rs EventDataRoundState) error
- func (NopEventBus) PublishEventTx(tx EventDataTx) error
- func (NopEventBus) PublishEventUnlock(rs EventDataRoundState) error
- func (NopEventBus) PublishEventVote(vote EventDataVote) error
- func (NopEventBus) Subscribe(ctx context.Context, subscriber string, query tmpubsub.Query, ...) error
- func (NopEventBus) Unsubscribe(ctx context.Context, subscriber string, query tmpubsub.Query) 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() *cmn.BitArray
- func (ps *PartSet) Count() int
- 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() int
- type PartSetHeader
- type PartSetReader
- type PrivValidator
- type PrivValidatorsByAddress
- type Proposal
- type Signable
- type SignedHeader
- type TMEventData
- type Tx
- type TxEventBuffer
- type TxEventPublisher
- type TxProof
- type TxResult
- type TxSize
- type Txs
- type Validator
- type ValidatorSet
- func (valSet *ValidatorSet) Add(val *Validator) (added bool)
- func (valSet *ValidatorSet) Copy() *ValidatorSet
- func (valSet *ValidatorSet) GetByAddress(address []byte) (index int, val *Validator)
- func (valSet *ValidatorSet) GetByIndex(index int) (address []byte, val *Validator)
- func (valSet *ValidatorSet) GetProposer() (proposer *Validator)
- func (valSet *ValidatorSet) HasAddress(address []byte) bool
- func (valSet *ValidatorSet) Hash() []byte
- func (valSet *ValidatorSet) IncrementAccum(times int)
- func (valSet *ValidatorSet) Iterate(fn func(index int, val *Validator) bool)
- func (valSet *ValidatorSet) Remove(address []byte) (val *Validator, removed bool)
- func (valSet *ValidatorSet) Size() int
- func (valSet *ValidatorSet) String() string
- func (valSet *ValidatorSet) StringIndented(indent string) string
- func (valSet *ValidatorSet) TotalVotingPower() int64
- func (valSet *ValidatorSet) Update(val *Validator) (updated bool)
- func (valSet *ValidatorSet) VerifyCommit(chainID string, blockID BlockID, height int64, commit *Commit) error
- func (valSet *ValidatorSet) VerifyCommitAny(newSet *ValidatorSet, chainID string, blockID BlockID, height int64, ...) error
- type ValidatorsByAddress
- type Vote
- type VoteSet
- func (voteSet *VoteSet) AddVote(vote *Vote) (added bool, err error)
- func (voteSet *VoteSet) BitArray() *cmn.BitArray
- func (voteSet *VoteSet) BitArrayByBlockID(blockID BlockID) *cmn.BitArray
- func (voteSet *VoteSet) BitArrayString() string
- func (voteSet *VoteSet) ChainID() string
- func (voteSet *VoteSet) GetByAddress(address []byte) *Vote
- func (voteSet *VoteSet) GetByIndex(valIndex int) *Vote
- func (voteSet *VoteSet) HasAll() bool
- func (voteSet *VoteSet) HasTwoThirdsAny() bool
- func (voteSet *VoteSet) HasTwoThirdsMajority() bool
- func (voteSet *VoteSet) Height() int64
- func (voteSet *VoteSet) IsCommit() bool
- func (voteSet *VoteSet) MakeCommit() *Commit
- func (voteSet *VoteSet) MarshalJSON() ([]byte, error)
- func (voteSet *VoteSet) Round() int
- 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 ( EventBond = "Bond" EventCompleteProposal = "CompleteProposal" EventDupeout = "Dupeout" EventFork = "Fork" EventLock = "Lock" EventNewBlock = "NewBlock" EventNewBlockHeader = "NewBlockHeader" EventNewRound = "NewRound" EventNewRoundStep = "NewRoundStep" EventPolka = "Polka" EventRebond = "Rebond" EventRelock = "Relock" EventTimeoutPropose = "TimeoutPropose" EventTimeoutWait = "TimeoutWait" EventTx = "Tx" EventUnbond = "Unbond" EventUnlock = "Unlock" EventVote = "Vote" EventProposalHeartbeat = "ProposalHeartbeat" )
Reserved event types
const ( // EventTypeKey is a reserved key, used to specify event type in tags. 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" )
const ( VoteTypePrevote = byte(0x01) VoteTypePrecommit = byte(0x02) )
Types of votes TODO Make a new type "VoteType"
const (
// Evidence type for duplicate vote
DUPLICATE_VOTE = "DUPLICATE_VOTE"
)
const (
MaxBlockSizeBytes = 104857600 // 100MB
)
const TimeFormat = amino.RFC3339Millis
TimeFormat is used for generating the sigs
Variables ¶
var ( EventQueryBond = QueryForEvent(EventBond) EventQueryUnbond = QueryForEvent(EventUnbond) EventQueryRebond = QueryForEvent(EventRebond) EventQueryDupeout = QueryForEvent(EventDupeout) EventQueryFork = QueryForEvent(EventFork) EventQueryNewBlock = QueryForEvent(EventNewBlock) EventQueryNewBlockHeader = QueryForEvent(EventNewBlockHeader) EventQueryNewRound = QueryForEvent(EventNewRound) EventQueryNewRoundStep = QueryForEvent(EventNewRoundStep) EventQueryTimeoutPropose = QueryForEvent(EventTimeoutPropose) EventQueryCompleteProposal = QueryForEvent(EventCompleteProposal) EventQueryPolka = QueryForEvent(EventPolka) EventQueryUnlock = QueryForEvent(EventUnlock) EventQueryLock = QueryForEvent(EventLock) EventQueryRelock = QueryForEvent(EventRelock) EventQueryTimeoutWait = QueryForEvent(EventTimeoutWait) EventQueryVote = QueryForEvent(EventVote) EventQueryProposalHeartbeat = QueryForEvent(EventProposalHeartbeat) EventQueryTx = QueryForEvent(EventTx) )
var ( PeerStateKey = "ConsensusReactor.peerState" PeerMempoolChKey = "MempoolReactor.peerMempoolCh" )
UNSTABLE
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 TM2PB = tm2pb{}
TM2PB is used for converting Tendermint types to protobuf types. UNSTABLE
Functions ¶
func CanonicalTime ¶ added in v0.15.0
func EventQueryTxFor ¶ added in v0.13.0
func IsVoteTypeValid ¶ added in v0.8.0
func QueryForEvent ¶ added in v0.14.0
func RandValidator ¶
func RandValidator(randPower bool, minPower int64) (*Validator, PrivValidator)
RandValidator returns a randomized validator, useful for testing. UNSTABLE
func RandValidatorSet ¶
func RandValidatorSet(numValidators int, votingPower int64) (*ValidatorSet, []PrivValidator)
RandValidatorSet returns a randomized validator set, useful for testing. NOTE: PrivValidator are in order. UNSTABLE
func RegisterEventDatas ¶ added in v0.19.0
func RegisterEvidences ¶ added in v0.19.0
func RegisterEvidences(cdc *amino.Codec)
Types ¶
type ABCIResult ¶ added in v0.15.0
ABCIResult is the deterministic component of a ResponseDeliverTx. TODO: add Tags
func NewResultFromResponse ¶ added in v0.15.0
func NewResultFromResponse(response *abci.ResponseDeliverTx) ABCIResult
func (ABCIResult) Hash ¶ added in v0.15.0
func (a ABCIResult) Hash() []byte
Hash returns the canonical hash of the ABCIResult
type ABCIResults ¶ added in v0.15.0
type ABCIResults []ABCIResult
ABCIResults wraps the deliver tx results to return a proof
func NewResults ¶ added in v0.15.0
func NewResults(del []*abci.ResponseDeliverTx) ABCIResults
NewResults creates ABCIResults from ResponseDeliverTx
func (ABCIResults) Bytes ¶ added in v0.15.0
func (a ABCIResults) Bytes() []byte
Bytes serializes the ABCIResponse using wire
func (ABCIResults) Hash ¶ added in v0.15.0
func (a ABCIResults) Hash() []byte
Hash returns a merkle hash of all results
func (ABCIResults) ProveResult ¶ added in v0.15.0
func (a ABCIResults) ProveResult(i int) merkle.SimpleProof
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. TODO: add Version byte
func MakeBlock ¶ added in v0.8.0
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) AddEvidence ¶ added in v0.15.0
AddEvidence appends the given evidence to the block
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.
func (*Block) StringIndented ¶
StringIndented returns a string representation of the block
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.
type BlockEventPublisher ¶ added in v0.15.0
type BlockEventPublisher interface { PublishEventNewBlock(block EventDataNewBlock) error PublishEventNewBlockHeader(header EventDataNewBlockHeader) error PublishEventTx(EventDataTx) error }
BlockEventPublisher publishes all block related events
type BlockGossip ¶ added in v0.15.0
type BlockGossip struct {
BlockPartSizeBytes int `json:"block_part_size_bytes"` // NOTE: must not be 0
}
BlockGossip determine consensus critical elements of how blocks are gossiped
func DefaultBlockGossip ¶ added in v0.15.0
func DefaultBlockGossip() BlockGossip
DefaultBlockGossip returns a default BlockGossip.
type BlockID ¶ added in v0.8.0
type BlockID struct { Hash cmn.HexBytes `json:"hash"` PartsHeader PartSetHeader `json:"parts"` }
BlockID defines the unique ID of a block as its Hash and its PartSetHeader
func (BlockID) Equals ¶ added in v0.8.0
Equals returns true if the BlockID matches the given BlockID
type BlockMeta ¶
type BlockMeta struct { BlockID BlockID `json:"block_id"` // the block hash and partsethash Header *Header `json:"header"` // The block's Header }
BlockMeta contains meta information about a block - namely, it's ID and Header.
func NewBlockMeta ¶
NewBlockMeta returns a new BlockMeta from the block and its blockParts.
type BlockSize ¶ added in v0.15.0
type BlockSize struct { MaxBytes int `json:"max_bytes"` // NOTE: must not be 0 nor greater than 100MB MaxTxs int `json:"max_txs"` MaxGas int64 `json:"max_gas"` }
BlockSize contain limits on the block size.
func DefaultBlockSize ¶ added in v0.15.0
func DefaultBlockSize() BlockSize
DefaultBlockSize returns a default BlockSize.
type BlockStore ¶ added in v0.9.0
type BlockStore interface { BlockStoreRPC SaveBlock(block *Block, blockParts *PartSet, seenCommit *Commit) }
BlockStore defines the BlockStore interface used by the ConsensusState. UNSTABLE
type BlockStoreRPC ¶ added in v0.9.0
type BlockStoreRPC interface { Height() int64 LoadBlockMeta(height int64) *BlockMeta LoadBlock(height int64) *Block LoadBlockPart(height int64, index int) *Part LoadBlockCommit(height int64) *Commit LoadSeenCommit(height int64) *Commit }
BlockStoreRPC is the block store interface used by the RPC. UNSTABLE
type CanonicalJSONBlockID ¶ added in v0.8.0
type CanonicalJSONBlockID struct { Hash cmn.HexBytes `json:"hash,omitempty"` PartsHeader CanonicalJSONPartSetHeader `json:"parts,omitempty"` }
func CanonicalBlockID ¶ added in v0.8.0
func CanonicalBlockID(blockID BlockID) CanonicalJSONBlockID
type CanonicalJSONHeartbeat ¶ added in v0.10.3
type CanonicalJSONHeartbeat struct { ChainID string `json:"@chain_id"` Type string `json:"@type"` Height int64 `json:"height"` Round int `json:"round"` Sequence int `json:"sequence"` ValidatorAddress Address `json:"validator_address"` ValidatorIndex int `json:"validator_index"` }
func CanonicalHeartbeat ¶ added in v0.10.3
func CanonicalHeartbeat(chainID string, heartbeat *Heartbeat) CanonicalJSONHeartbeat
type CanonicalJSONPartSetHeader ¶ added in v0.8.0
type CanonicalJSONPartSetHeader struct { Hash cmn.HexBytes `json:"hash,omitempty"` Total int `json:"total,omitempty"` }
func CanonicalPartSetHeader ¶ added in v0.8.0
func CanonicalPartSetHeader(psh PartSetHeader) CanonicalJSONPartSetHeader
type CanonicalJSONProposal ¶ added in v0.8.0
type CanonicalJSONProposal struct { ChainID string `json:"@chain_id"` Type string `json:"@type"` BlockPartsHeader CanonicalJSONPartSetHeader `json:"block_parts_header"` Height int64 `json:"height"` POLBlockID CanonicalJSONBlockID `json:"pol_block_id"` POLRound int `json:"pol_round"` Round int `json:"round"` Timestamp string `json:"timestamp"` }
func CanonicalProposal ¶ added in v0.8.0
func CanonicalProposal(chainID string, proposal *Proposal) CanonicalJSONProposal
type CanonicalJSONVote ¶ added in v0.8.0
type CanonicalJSONVote struct { ChainID string `json:"@chain_id"` Type string `json:"@type"` BlockID CanonicalJSONBlockID `json:"block_id"` Height int64 `json:"height"` Round int `json:"round"` Timestamp string `json:"timestamp"` VoteType byte `json:"type"` }
func CanonicalVote ¶ added in v0.8.0
func CanonicalVote(chainID string, vote *Vote) CanonicalJSONVote
type Commit ¶
type Commit struct { // NOTE: The Precommits are in order of address to preserve the bonded ValidatorSet order. // Any peer with a block can gossip precommits by index with a peer without recalculating the // active ValidatorSet. BlockID BlockID `json:"block_id"` Precommits []*Vote `json:"precommits"` // 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 MakeCommit ¶ added in v0.15.0
func (*Commit) FirstPrecommit ¶
FirstPrecommit returns the first non-nil precommit in the commit. If all precommits are nil, it returns an empty precommit with height 0.
func (*Commit) GetByIndex ¶
GetByIndex returns the vote corresponding to a given validator index
func (*Commit) StringIndented ¶
StringIndented returns a string representation of the commit
func (*Commit) ValidateBasic ¶
ValidateBasic performs basic validation that doesn't involve state data.
type ConsensusParams ¶ added in v0.11.0
type ConsensusParams struct { BlockSize `json:"block_size_params"` TxSize `json:"tx_size_params"` BlockGossip `json:"block_gossip_params"` EvidenceParams `json:"evidence_params"` }
ConsensusParams contains consensus critical parameters that determine the validity of blocks.
func DefaultConsensusParams ¶ added in v0.11.0
func DefaultConsensusParams() *ConsensusParams
DefaultConsensusParams returns a default ConsensusParams.
func (*ConsensusParams) Hash ¶ added in v0.15.0
func (params *ConsensusParams) Hash() []byte
Hash returns a merkle hash of the parameters to store in the block header
func (ConsensusParams) Update ¶ added in v0.15.0
func (params ConsensusParams) Update(params2 *abci.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) Validate ¶ added in v0.11.0
func (params *ConsensusParams) Validate() 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 (*Data) StringIndented ¶
StringIndented returns a string representation of the transactions
type DuplicateVoteEvidence ¶ added in v0.15.0
DuplicateVoteEvidence contains evidence a validator signed two conflicting votes.
func (*DuplicateVoteEvidence) Address ¶ added in v0.15.0
func (dve *DuplicateVoteEvidence) Address() []byte
Address returns the address of the validator.
func (*DuplicateVoteEvidence) Equal ¶ added in v0.15.0
func (dve *DuplicateVoteEvidence) Equal(ev Evidence) bool
Equal checks if two pieces of evidence are equal.
func (*DuplicateVoteEvidence) Hash ¶ added in v0.15.0
func (dve *DuplicateVoteEvidence) Hash() []byte
Hash returns the hash of the evidence.
func (*DuplicateVoteEvidence) Height ¶ added in v0.15.0
func (dve *DuplicateVoteEvidence) Height() int64
Height returns the height this evidence refers to.
func (*DuplicateVoteEvidence) Index ¶ added in v0.15.0
func (dve *DuplicateVoteEvidence) Index() int
Index returns the index of the validator.
func (*DuplicateVoteEvidence) String ¶ added in v0.15.0
func (dve *DuplicateVoteEvidence) String() string
String returns a string representation of the evidence.
func (*DuplicateVoteEvidence) Verify ¶ added in v0.15.0
func (dve *DuplicateVoteEvidence) Verify(chainID string) error
Verify returns an error if the two votes aren't conflicting. To be conflicting, they must be from the same validator, for the same H/R/S, but for different blocks.
type ErrEvidenceInvalid ¶ added in v0.15.0
ErrEvidenceInvalid wraps a piece of evidence and the error denoting how or why it is invalid.
func NewEvidenceInvalidErr ¶ added in v0.15.0
func NewEvidenceInvalidErr(ev Evidence, err error) *ErrEvidenceInvalid
func (*ErrEvidenceInvalid) Error ¶ added in v0.15.0
func (err *ErrEvidenceInvalid) Error() string
Error returns a string representation of the error.
type ErrVoteConflictingVotes ¶ added in v0.8.0
type ErrVoteConflictingVotes struct {
*DuplicateVoteEvidence
}
func NewConflictingVoteError ¶ added in v0.15.0
func NewConflictingVoteError(val *Validator, voteA, voteB *Vote) *ErrVoteConflictingVotes
func (*ErrVoteConflictingVotes) Error ¶ added in v0.8.0
func (err *ErrVoteConflictingVotes) Error() string
type EventBus ¶ added in v0.13.0
type EventBus struct { cmn.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 NewEventBus ¶ added in v0.13.0
func NewEventBus() *EventBus
NewEventBus returns a new event bus.
func NewEventBusWithBufferCapacity ¶ added in v0.13.0
NewEventBusWithBufferCapacity returns a new event bus with the given buffer capacity.
func (*EventBus) Publish ¶ added in v0.13.0
func (b *EventBus) Publish(eventType string, eventData TMEventData) error
func (*EventBus) PublishEventCompleteProposal ¶ added in v0.13.0
func (b *EventBus) PublishEventCompleteProposal(event EventDataRoundState) error
func (*EventBus) PublishEventLock ¶ added in v0.13.0
func (b *EventBus) PublishEventLock(event EventDataRoundState) error
func (*EventBus) PublishEventNewBlock ¶ added in v0.13.0
func (b *EventBus) PublishEventNewBlock(event EventDataNewBlock) error
func (*EventBus) PublishEventNewBlockHeader ¶ added in v0.13.0
func (b *EventBus) PublishEventNewBlockHeader(event EventDataNewBlockHeader) error
func (*EventBus) PublishEventNewRound ¶ added in v0.13.0
func (b *EventBus) PublishEventNewRound(event EventDataRoundState) error
func (*EventBus) PublishEventNewRoundStep ¶ added in v0.13.0
func (b *EventBus) PublishEventNewRoundStep(event EventDataRoundState) error
func (*EventBus) PublishEventPolka ¶ added in v0.13.0
func (b *EventBus) PublishEventPolka(event EventDataRoundState) error
func (*EventBus) PublishEventProposalHeartbeat ¶ added in v0.13.0
func (b *EventBus) PublishEventProposalHeartbeat(event EventDataProposalHeartbeat) error
func (*EventBus) PublishEventRelock ¶ added in v0.13.0
func (b *EventBus) PublishEventRelock(event EventDataRoundState) error
func (*EventBus) PublishEventTimeoutPropose ¶ added in v0.13.0
func (b *EventBus) PublishEventTimeoutPropose(event EventDataRoundState) error
func (*EventBus) PublishEventTimeoutWait ¶ added in v0.13.0
func (b *EventBus) PublishEventTimeoutWait(event EventDataRoundState) error
func (*EventBus) PublishEventTx ¶ added in v0.13.0
func (b *EventBus) PublishEventTx(event EventDataTx) error
PublishEventTx publishes tx event with tags from Result. Note it will add predefined tags (EventTypeKey, TxHashKey). Existing tags with the same names will be overwritten.
func (*EventBus) PublishEventUnlock ¶ added in v0.13.0
func (b *EventBus) PublishEventUnlock(event EventDataRoundState) error
func (*EventBus) PublishEventVote ¶ added in v0.13.0
func (b *EventBus) PublishEventVote(event EventDataVote) error
func (*EventBus) Unsubscribe ¶ added in v0.13.0
type EventBusSubscriber ¶ added in v0.14.0
type EventDataNewBlock ¶
type EventDataNewBlock struct {
Block *Block `json:"block"`
}
func (EventDataNewBlock) AssertIsTMEventData ¶
func (_ EventDataNewBlock) AssertIsTMEventData()
type EventDataNewBlockHeader ¶
type EventDataNewBlockHeader struct {
Header *Header `json:"header"`
}
light weight event for benchmarking
func (EventDataNewBlockHeader) AssertIsTMEventData ¶
func (_ EventDataNewBlockHeader) AssertIsTMEventData()
type EventDataProposalHeartbeat ¶ added in v0.10.3
type EventDataProposalHeartbeat struct {
Heartbeat *Heartbeat
}
func (EventDataProposalHeartbeat) AssertIsTMEventData ¶ added in v0.10.3
func (_ EventDataProposalHeartbeat) AssertIsTMEventData()
type EventDataRoundState ¶
type EventDataRoundState struct { Height int64 `json:"height"` Round int `json:"round"` Step string `json:"step"` // private, not exposed to websockets RoundState interface{} `json:"-"` }
NOTE: This goes into the replay WAL
func (EventDataRoundState) AssertIsTMEventData ¶
func (_ EventDataRoundState) AssertIsTMEventData()
type EventDataString ¶ added in v0.19.0
type EventDataString string
func (EventDataString) AssertIsTMEventData ¶ added in v0.19.0
func (_ EventDataString) AssertIsTMEventData()
type EventDataTx ¶
type EventDataTx struct {
TxResult
}
All txs fire EventDataTx
func (EventDataTx) AssertIsTMEventData ¶
func (_ EventDataTx) AssertIsTMEventData()
type EventDataVote ¶
type EventDataVote struct {
Vote *Vote
}
func (EventDataVote) AssertIsTMEventData ¶
func (_ EventDataVote) AssertIsTMEventData()
type Evidence ¶ added in v0.15.0
type Evidence interface { Height() int64 // height of the equivocation Address() []byte // address of the equivocating validator Index() int // index of the validator in the validator set Hash() []byte // hash of the evidence Verify(chainID string) error // verify the evidence Equal(Evidence) bool // check equality of evidence String() string // used as type in abci.Evidence }
Evidence represents any provable malicious activity by a validator
type EvidenceData ¶ added in v0.15.0
type EvidenceData struct { Evidence EvidenceList `json:"evidence"` // contains filtered or unexported fields }
EvidenceData contains any evidence of malicious wrong-doing by validators
func (*EvidenceData) Hash ¶ added in v0.15.0
func (data *EvidenceData) Hash() cmn.HexBytes
Hash returns the hash of the data.
func (*EvidenceData) StringIndented ¶ added in v0.15.0
func (data *EvidenceData) StringIndented(indent string) string
StringIndented returns a string representation of the evidence.
type EvidenceList ¶ added in v0.15.0
type EvidenceList []Evidence
EvidenceList is a list of Evidence. Evidences is not a word.
func (EvidenceList) Has ¶ added in v0.15.0
func (evl EvidenceList) Has(evidence Evidence) bool
Has returns true if the evidence is in the EvidenceList.
func (EvidenceList) Hash ¶ added in v0.15.0
func (evl EvidenceList) Hash() []byte
Hash returns the simple merkle root hash of the EvidenceList.
func (EvidenceList) String ¶ added in v0.15.0
func (evl EvidenceList) String() string
type EvidenceParams ¶ added in v0.15.0
type EvidenceParams struct {
MaxAge int64 `json:"max_age"` // only accept new evidence more recent than this
}
EvidenceParams determine how we handle evidence of malfeasance
func DefaultEvidenceParams ¶ added in v0.15.0
func DefaultEvidenceParams() EvidenceParams
DefaultEvidence Params returns a default EvidenceParams.
type EvidencePool ¶ added in v0.15.0
type EvidencePool interface { PendingEvidence() []Evidence AddEvidence(Evidence) error Update(*Block) }
EvidencePool defines the EvidencePool interface used by the ConsensusState. UNSTABLE
type GenesisDoc ¶
type GenesisDoc struct { GenesisTime time.Time `json:"genesis_time"` ChainID string `json:"chain_id"` ConsensusParams *ConsensusParams `json:"consensus_params,omitempty"` Validators []GenesisValidator `json:"validators"` AppHash cmn.HexBytes `json:"app_hash"` AppStateJSON json.RawMessage `json:"app_state,omitempty"` AppOptions json.RawMessage `json:"app_options,omitempty"` // DEPRECATED }
GenesisDoc defines the initial conditions for a tendermint blockchain, in particular its validator set.
func GenesisDocFromFile ¶ added in v0.10.1
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) AppState ¶ added in v0.17.0
func (genDoc *GenesisDoc) AppState() json.RawMessage
AppState returns raw application state. TODO: replace with AppState field during next breaking release (0.18)
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 ¶ added in v0.11.0
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 ¶ added in v0.10.1
func (genDoc *GenesisDoc) ValidatorHash() []byte
ValidatorHash returns the hash of the validator set contained in the GenesisDoc
type GenesisValidator ¶
type GenesisValidator struct { PubKey crypto.PubKey `json:"pub_key"` Power int64 `json:"power"` Name string `json:"name"` }
GenesisValidator is an initial validator.
type Header ¶
type Header struct { // basic block info ChainID string `json:"chain_id"` Height int64 `json:"height"` Time time.Time `json:"time"` NumTxs int64 `json:"num_txs"` // prev block info LastBlockID BlockID `json:"last_block_id"` TotalTxs int64 `json:"total_txs"` // hashes of block data LastCommitHash cmn.HexBytes `json:"last_commit_hash"` // commit from validators from the last block DataHash cmn.HexBytes `json:"data_hash"` // transactions // hashes from the app output from the prev block ValidatorsHash cmn.HexBytes `json:"validators_hash"` // validators for the current block ConsensusHash cmn.HexBytes `json:"consensus_hash"` // consensus params for current block AppHash cmn.HexBytes `json:"app_hash"` // state after txs from the previous block LastResultsHash cmn.HexBytes `json:"last_results_hash"` // root hash of all results from the txs from the previous block // consensus info EvidenceHash cmn.HexBytes `json:"evidence_hash"` // evidence included in the block }
Header defines the structure of a Tendermint block header TODO: limit header size NOTE: changes to the Header should be duplicated in the abci Header
func (*Header) Hash ¶
Hash returns the hash of the header. Returns nil if ValidatorHash is missing, since a Header is not valid unless there is a ValidaotrsHash (corresponding to the validator set).
func (*Header) StringIndented ¶
StringIndented returns a string representation of the header
type Heartbeat ¶ added in v0.10.3
type Heartbeat struct { ValidatorAddress Address `json:"validator_address"` ValidatorIndex int `json:"validator_index"` Height int64 `json:"height"` Round int `json:"round"` Sequence int `json:"sequence"` Signature crypto.Signature `json:"signature"` }
Heartbeat is a simple vote-like structure so validators can alert others that they are alive and waiting for transactions. Note: We aren't adding ",omitempty" to Heartbeat's json field tags because we always want the JSON representation to be in its canonical form.
type Mempool ¶ added in v0.9.0
type Mempool interface { Lock() Unlock() Size() int CheckTx(Tx, func(*abci.Response)) error Reap(int) Txs Update(height int64, txs Txs) error Flush() FlushAppConn() error TxsAvailable() <-chan int64 EnableTxsAvailable() }
Mempool defines the mempool interface as used by the ConsensusState. Updates to the mempool need to be synchronized with committing a block so apps can reset their transient state on Commit UNSTABLE
type MockBadEvidence ¶ added in v0.15.0
type MockBadEvidence struct {
MockGoodEvidence
}
UNSTABLE
func (MockBadEvidence) Equal ¶ added in v0.15.0
func (e MockBadEvidence) Equal(ev Evidence) bool
func (MockBadEvidence) String ¶ added in v0.15.0
func (e MockBadEvidence) String() string
func (MockBadEvidence) Verify ¶ added in v0.15.0
func (e MockBadEvidence) Verify(chainID string) error
type MockEvidencePool ¶ added in v0.15.0
type MockEvidencePool struct { }
MockMempool is an empty implementation of a Mempool, useful for testing. UNSTABLE
func (MockEvidencePool) AddEvidence ¶ added in v0.15.0
func (m MockEvidencePool) AddEvidence(Evidence) error
func (MockEvidencePool) PendingEvidence ¶ added in v0.15.0
func (m MockEvidencePool) PendingEvidence() []Evidence
func (MockEvidencePool) Update ¶ added in v0.15.0
func (m MockEvidencePool) Update(*Block)
type MockGoodEvidence ¶ added in v0.15.0
UNSTABLE
func NewMockGoodEvidence ¶ added in v0.15.0
func NewMockGoodEvidence(height int64, index int, address []byte) MockGoodEvidence
UNSTABLE
func (MockGoodEvidence) Address ¶ added in v0.15.0
func (e MockGoodEvidence) Address() []byte
func (MockGoodEvidence) Equal ¶ added in v0.15.0
func (e MockGoodEvidence) Equal(ev Evidence) bool
func (MockGoodEvidence) Hash ¶ added in v0.15.0
func (e MockGoodEvidence) Hash() []byte
func (MockGoodEvidence) Height ¶ added in v0.15.0
func (e MockGoodEvidence) Height() int64
func (MockGoodEvidence) Index ¶ added in v0.15.0
func (e MockGoodEvidence) Index() int
func (MockGoodEvidence) String ¶ added in v0.15.0
func (e MockGoodEvidence) String() string
func (MockGoodEvidence) Verify ¶ added in v0.15.0
func (e MockGoodEvidence) Verify(chainID string) error
type MockMempool ¶ added in v0.9.0
type MockMempool struct { }
MockMempool is an empty implementation of a Mempool, useful for testing. UNSTABLE
func (MockMempool) CheckTx ¶ added in v0.9.0
func (m MockMempool) CheckTx(tx Tx, cb func(*abci.Response)) error
func (MockMempool) EnableTxsAvailable ¶ added in v0.10.3
func (m MockMempool) EnableTxsAvailable()
func (MockMempool) Flush ¶ added in v0.9.0
func (m MockMempool) Flush()
func (MockMempool) FlushAppConn ¶ added in v0.16.0
func (m MockMempool) FlushAppConn() error
func (MockMempool) Lock ¶ added in v0.9.0
func (m MockMempool) Lock()
func (MockMempool) Reap ¶ added in v0.9.0
func (m MockMempool) Reap(n int) Txs
func (MockMempool) Size ¶ added in v0.9.0
func (m MockMempool) Size() int
func (MockMempool) TxsAvailable ¶ added in v0.10.3
func (m MockMempool) TxsAvailable() <-chan int64
func (MockMempool) Unlock ¶ added in v0.9.0
func (m MockMempool) Unlock()
type MockPV ¶ added in v0.19.0
type MockPV struct {
// contains filtered or unexported fields
}
MockPV implements PrivValidator without any safety or persistence. Only use it for testing.
func (*MockPV) GetAddress ¶ added in v0.19.0
Implements PrivValidator.
func (*MockPV) GetPubKey ¶ added in v0.19.0
func (pv *MockPV) GetPubKey() crypto.PubKey
Implements PrivValidator.
func (*MockPV) SignHeartbeat ¶ added in v0.19.0
signHeartbeat signs the heartbeat without any checking.
func (*MockPV) SignProposal ¶ added in v0.19.0
Implements PrivValidator.
type NopEventBus ¶ added in v0.13.0
type NopEventBus struct{}
func (NopEventBus) PublishEventCompleteProposal ¶ added in v0.13.0
func (NopEventBus) PublishEventCompleteProposal(rs EventDataRoundState) error
func (NopEventBus) PublishEventLock ¶ added in v0.13.0
func (NopEventBus) PublishEventLock(rs EventDataRoundState) error
func (NopEventBus) PublishEventNewBlock ¶ added in v0.13.0
func (NopEventBus) PublishEventNewBlock(block EventDataNewBlock) error
func (NopEventBus) PublishEventNewBlockHeader ¶ added in v0.13.0
func (NopEventBus) PublishEventNewBlockHeader(header EventDataNewBlockHeader) error
func (NopEventBus) PublishEventNewRound ¶ added in v0.13.0
func (NopEventBus) PublishEventNewRound(rs EventDataRoundState) error
func (NopEventBus) PublishEventNewRoundStep ¶ added in v0.13.0
func (NopEventBus) PublishEventNewRoundStep(rs EventDataRoundState) error
func (NopEventBus) PublishEventPolka ¶ added in v0.13.0
func (NopEventBus) PublishEventPolka(rs EventDataRoundState) error
func (NopEventBus) PublishEventRelock ¶ added in v0.13.0
func (NopEventBus) PublishEventRelock(rs EventDataRoundState) error
func (NopEventBus) PublishEventTimeoutPropose ¶ added in v0.13.0
func (NopEventBus) PublishEventTimeoutPropose(rs EventDataRoundState) error
func (NopEventBus) PublishEventTimeoutWait ¶ added in v0.13.0
func (NopEventBus) PublishEventTimeoutWait(rs EventDataRoundState) error
func (NopEventBus) PublishEventTx ¶ added in v0.13.0
func (NopEventBus) PublishEventTx(tx EventDataTx) error
func (NopEventBus) PublishEventUnlock ¶ added in v0.13.0
func (NopEventBus) PublishEventUnlock(rs EventDataRoundState) error
func (NopEventBus) PublishEventVote ¶ added in v0.13.0
func (NopEventBus) PublishEventVote(vote EventDataVote) error
func (NopEventBus) Unsubscribe ¶ added in v0.13.0
func (NopEventBus) UnsubscribeAll ¶ added in v0.13.0
func (NopEventBus) UnsubscribeAll(ctx context.Context, subscriber string) error
type P2PID ¶ added in v0.17.0
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 int `json:"index"` Bytes cmn.HexBytes `json:"bytes"` Proof merkle.SimpleProof `json:"proof"` // contains filtered or unexported fields }
func (*Part) StringIndented ¶
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.
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 ¶ added in v0.19.1
func (*PartSet) StringShort ¶
type PartSetHeader ¶
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
type PartSetReader ¶
type PartSetReader struct {
// contains filtered or unexported fields
}
func NewPartSetReader ¶
func NewPartSetReader(parts []*Part) *PartSetReader
type PrivValidator ¶
type PrivValidator interface { GetAddress() Address // redundant since .PubKey().Address() GetPubKey() crypto.PubKey SignVote(chainID string, vote *Vote) error SignProposal(chainID string, proposal *Proposal) error SignHeartbeat(chainID string, heartbeat *Heartbeat) error }
PrivValidator defines the functionality of a local Tendermint validator that signs votes, proposals, and heartbeats, and never double signs.
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 { Height int64 `json:"height"` Round int `json:"round"` Timestamp time.Time `json:"timestamp"` BlockPartsHeader PartSetHeader `json:"block_parts_header"` POLRound int `json:"pol_round"` // -1 if null. POLBlockID BlockID `json:"pol_block_id"` // zero if null. Signature crypto.Signature `json:"signature"` }
Proposal defines a block proposal for the consensus. It refers to the block only by its PartSetHeader. 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 and POLBlockID.
func NewProposal ¶
func NewProposal(height int64, round int, blockPartsHeader PartSetHeader, polRound int, polBlockID BlockID) *Proposal
NewProposal returns a new Proposal. If there is no POLRound, polRound should be -1.
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 marshalling.
type SignedHeader ¶ added in v0.12.0
SignedHeader is a header along with the commits that prove it
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. Alternatively, it may make sense to add types here and let []byte be type 0x1 so we can have versioned txs if need be in the future.
type TxEventBuffer ¶ added in v0.13.0
type TxEventBuffer struct {
// contains filtered or unexported fields
}
TxEventBuffer is a buffer of events, which uses a slice to temporarily store events.
func NewTxEventBuffer ¶ added in v0.13.0
func NewTxEventBuffer(next TxEventPublisher, capacity int) *TxEventBuffer
NewTxEventBuffer accepts a TxEventPublisher and returns a new buffer with the given capacity.
func (*TxEventBuffer) Flush ¶ added in v0.13.0
func (b *TxEventBuffer) Flush() error
Flush publishes events by running next.PublishWithTags on all cached events. Blocks. Clears cached events.
func (TxEventBuffer) Len ¶ added in v0.13.0
func (b TxEventBuffer) Len() int
Len returns the number of events cached.
func (*TxEventBuffer) PublishEventTx ¶ added in v0.13.0
func (b *TxEventBuffer) PublishEventTx(e EventDataTx) error
PublishEventTx buffers an event to be fired upon finality.
type TxEventPublisher ¶ added in v0.13.0
type TxEventPublisher interface {
PublishEventTx(EventDataTx) error
}
type TxProof ¶ added in v0.9.1
TxProof represents a Merkle proof of the presence of a transaction in the Merkle tree.
type TxResult ¶ added in v0.9.1
type TxResult struct { Height int64 `json:"height"` Index uint32 `json:"index"` Tx Tx `json:"tx"` Result abci.ResponseDeliverTx `json:"result"` }
TxResult contains results of executing the transaction.
One usage is indexing transaction results.
type TxSize ¶ added in v0.15.0
TxSize contain limits on the tx size.
func DefaultTxSize ¶ added in v0.15.0
func DefaultTxSize() TxSize
DefaultTxSize returns a default TxSize.
type Txs ¶
type Txs []Tx
Txs is a slice of Tx.
func (Txs) Index ¶ added in v0.9.1
Index returns the index of this transaction in the list, or -1 if not found
func (Txs) IndexByHash ¶ added in v0.9.1
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"` Accum int64 `json:"accum"` }
Volatile state for each Validator NOTE: The Accum is not included in Validator.Hash(); make sure to update that method if changes are made here
func NewValidator ¶ added in v0.8.0
func (*Validator) CompareAccum ¶
Returns the one with higher Accum.
func (*Validator) Copy ¶
Creates a new copy of the validator so we can mutate accum. Panics if the validator is nil.
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 .Address, so the indices are fixed for all rounds of a given blockchain height. On the other hand, the .AccumPower of each validator and the designated .GetProposer() of a set changes every round, upon calling .IncrementAccum(). NOTE: Not goroutine-safe. NOTE: All get/set to validators should copy the value for safety.
func NewValidatorSet ¶
func NewValidatorSet(vals []*Validator) *ValidatorSet
func (*ValidatorSet) Add ¶
func (valSet *ValidatorSet) Add(val *Validator) (added bool)
Add adds val to the validator set and returns true. It returns false if val is already in the set.
func (*ValidatorSet) Copy ¶
func (valSet *ValidatorSet) Copy() *ValidatorSet
Copy each validator into a new ValidatorSet
func (*ValidatorSet) GetByAddress ¶
func (valSet *ValidatorSet) GetByAddress(address []byte) (index int, val *Validator)
GetByAddress returns an index of the validator with address and validator itself if found. Otherwise, -1 and nil are returned.
func (*ValidatorSet) GetByIndex ¶
func (valSet *ValidatorSet) GetByIndex(index int) (address []byte, val *Validator)
GetByIndex returns the validator's address and validator itself by index. It returns nil values if index is less than 0 or greater or equal to len(ValidatorSet.Validators).
func (*ValidatorSet) GetProposer ¶ added in v0.9.0
func (valSet *ValidatorSet) GetProposer() (proposer *Validator)
GetProposer returns the current proposer. If the validator set is empty, nil is returned.
func (*ValidatorSet) HasAddress ¶
func (valSet *ValidatorSet) HasAddress(address []byte) bool
HasAddress returns true if address given is in the validator set, false - otherwise.
func (*ValidatorSet) Hash ¶
func (valSet *ValidatorSet) Hash() []byte
Hash returns the Merkle root hash build using validators (as leaves) in the set.
func (*ValidatorSet) IncrementAccum ¶
func (valSet *ValidatorSet) IncrementAccum(times int)
incrementAccum and update the proposer
func (*ValidatorSet) Iterate ¶
func (valSet *ValidatorSet) Iterate(fn func(index int, val *Validator) bool)
Iterate will run the given function over the set.
func (*ValidatorSet) Remove ¶
func (valSet *ValidatorSet) Remove(address []byte) (val *Validator, removed bool)
Remove deletes the validator with address. It returns the validator removed and true. If returns nil and false if validator is not present in the set.
func (*ValidatorSet) Size ¶
func (valSet *ValidatorSet) Size() int
Size returns the length of the validator set.
func (*ValidatorSet) String ¶
func (valSet *ValidatorSet) String() string
func (*ValidatorSet) StringIndented ¶
func (valSet *ValidatorSet) StringIndented(indent string) string
String
func (*ValidatorSet) TotalVotingPower ¶
func (valSet *ValidatorSet) TotalVotingPower() int64
TotalVotingPower returns the sum of the voting powers of all validators.
func (*ValidatorSet) Update ¶
func (valSet *ValidatorSet) Update(val *Validator) (updated bool)
Update updates val and returns true. It returns false if val is not present in the set.
func (*ValidatorSet) VerifyCommit ¶
func (valSet *ValidatorSet) VerifyCommit(chainID string, blockID BlockID, height int64, commit *Commit) error
Verify that +2/3 of the set had signed the given signBytes
func (*ValidatorSet) VerifyCommitAny ¶ added in v0.9.0
func (valSet *ValidatorSet) VerifyCommitAny(newSet *ValidatorSet, chainID string, blockID BlockID, height int64, commit *Commit) error
VerifyCommitAny will check to see if the set would be valid with a different validator set.
valSet is the validator set that we know * over 2/3 of the power in old signed this block
newSet is the validator set that signed this block
- only votes from old are sufficient for 2/3 majority in the new set as well
That means that: * 10% of the valset can't just declare themselves kings * If the validator set is 3x old size, we need more proof to trust
type ValidatorsByAddress ¶
type ValidatorsByAddress []*Validator
Sort validators by address
func (ValidatorsByAddress) Len ¶
func (vs ValidatorsByAddress) Len() int
func (ValidatorsByAddress) Less ¶
func (vs ValidatorsByAddress) Less(i, j int) bool
func (ValidatorsByAddress) Swap ¶
func (vs ValidatorsByAddress) Swap(i, j int)
type Vote ¶
type Vote struct { ValidatorAddress Address `json:"validator_address"` ValidatorIndex int `json:"validator_index"` Height int64 `json:"height"` Round int `json:"round"` Timestamp time.Time `json:"timestamp"` Type byte `json:"type"` BlockID BlockID `json:"block_id"` // zero if vote is nil. Signature crypto.Signature `json:"signature"` }
Represents a prevote, precommit, or commit vote from validators for consensus.
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 NewVoteSet ¶
Constructs a new VoteSet struct used to accumulate votes for given height/round.
func (*VoteSet) AddVote ¶ added in v0.8.0
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 ¶ added in v0.8.0
func (*VoteSet) BitArrayString ¶ added in v0.19.3
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
func (*VoteSet) HasTwoThirdsAny ¶
func (*VoteSet) HasTwoThirdsMajority ¶
func (*VoteSet) MakeCommit ¶
func (*VoteSet) MarshalJSON ¶ added in v0.19.1
Marshal the VoteSet to JSON. Same as String(), just in JSON, and without the height/round/type_ (since its already included in the votes).
func (*VoteSet) SetPeerMaj23 ¶ added in v0.8.0
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 ¶
func (*VoteSet) StringShort ¶
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 ¶ added in v0.19.3
Returns a list of votes compressed to more readable strings.
type VoteSetJSON ¶ added in v0.19.3
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 unmarshalling from (compressed votes) TODO: make the peerMaj23s nicer to read (eg just the block hash)
Source Files ¶
- block.go
- block_meta.go
- canonical_json.go
- event_buffer.go
- event_bus.go
- events.go
- evidence.go
- genesis.go
- heartbeat.go
- keys.go
- nop_event_bus.go
- params.go
- part_set.go
- priv_validator.go
- proposal.go
- protobuf.go
- results.go
- services.go
- signable.go
- test_util.go
- tx.go
- validator.go
- validator_set.go
- vote.go
- vote_set.go
- wire.go