Versions in this module Expand all Collapse all v0 v0.1.2 Dec 17, 2020 Changes in this version + const MaxBlockPartsCount + const MaxVotesCount type Vote + func MakeVote(height int64, blockID BlockID, valSet *ValidatorSet, privVal PrivValidator, ...) (*Vote, error) v0.1.1 Dec 17, 2020 Changes in this version + const ABCIEvidenceTypeDuplicateVote + const ABCIEvidenceTypeMockGood + const ABCIPubKeyTypeEd25519 + const ABCIPubKeyTypeSecp256k1 + const BlockPartSizeBytes + const EventCompleteProposal + const EventLock + const EventNewBlock + const EventNewBlockHeader + const EventNewRound + const EventNewRoundStep + const EventPolka + const EventRelock + const EventTimeoutPropose + const EventTimeoutWait + const EventTx + const EventTypeKey + const EventUnlock + const EventValidBlock + const EventValidatorSetUpdates + const EventVote + const MaxAminoOverheadForBlock + const MaxBlockSizeBytes + const MaxChainIDLen + const MaxEvidenceBytes + const MaxEvidenceBytesDenominator + const MaxHeaderBytes + const MaxTotalVotingPower + const MaxVoteBytes + const PriorityWindowSizeFactor + const TimeFormat + const TxHashKey + const TxHeightKey + var ABCIPubKeyTypesToAminoNames = map[string]string + var ErrInvalidBlockPartHash = errors.New("Error invalid block part hash") + var ErrInvalidBlockPartSignature = errors.New("Error invalid block part signature") + var ErrPartSetInvalidProof = errors.New("Error part set invalid proof") + var ErrPartSetUnexpectedIndex = errors.New("Error part set unexpected index") + var ErrVoteInvalidBlockHash = errors.New("Invalid block hash") + var ErrVoteInvalidSignature = errors.New("Invalid signature") + var ErrVoteInvalidValidatorAddress = errors.New("Invalid validator address") + var ErrVoteInvalidValidatorIndex = errors.New("Invalid validator index") + var ErrVoteNil = errors.New("Nil vote") + var ErrVoteNonDeterministicSignature = errors.New("Non-deterministic signature") + var ErrVoteUnexpectedStep = errors.New("Unexpected step") + var ErroringMockPVErr = errors.New("erroringMockPV always returns an error") + var EventQueryCompleteProposal = QueryForEvent(EventCompleteProposal) + var EventQueryLock = QueryForEvent(EventLock) + var EventQueryNewBlock = QueryForEvent(EventNewBlock) + var EventQueryNewBlockHeader = QueryForEvent(EventNewBlockHeader) + var EventQueryNewRound = QueryForEvent(EventNewRound) + var EventQueryNewRoundStep = QueryForEvent(EventNewRoundStep) + var EventQueryPolka = QueryForEvent(EventPolka) + var EventQueryRelock = QueryForEvent(EventRelock) + var EventQueryTimeoutPropose = QueryForEvent(EventTimeoutPropose) + var EventQueryTimeoutWait = QueryForEvent(EventTimeoutWait) + var EventQueryTx = QueryForEvent(EventTx) + var EventQueryUnlock = QueryForEvent(EventUnlock) + var EventQueryValidBlock = QueryForEvent(EventValidBlock) + var EventQueryValidatorSetUpdates = QueryForEvent(EventValidatorSetUpdates) + var EventQueryVote = QueryForEvent(EventVote) + var MaxSignatureSize = cmn.MaxInt(ed25519.SignatureSize, 64) + var PB2TM = pb2tm + var PeerStateKey = "ConsensusReactor.peerState" + var TM2PB = tm2pb + func CanonicalTime(t time.Time) string + func ComputeAminoOverhead(tx Tx, fieldNum int) int64 + func EventQueryTxFor(tx Tx) tmpubsub.Query + func GetCodec() *amino.Codec + func IsErrTooMuchChange(err error) bool + func IsVoteTypeValid(t SignedMsgType) bool + func MaxDataBytes(maxBytes int64, valsCount, evidenceCount int) int64 + func MaxDataBytesUnknownEvidence(maxBytes int64, valsCount int) int64 + func MaxEvidencePerBlock(blockMaxBytes int64) (int64, int64) + func NewErroringMockPV() *erroringMockPV + func QueryForEvent(eventType string) tmpubsub.Query + func RandValidator(randPower bool, minPower int64) (*Validator, PrivValidator) + func RandValidatorSet(numValidators int, votingPower int64) (*ValidatorSet, []PrivValidator) + func RegisterBlockAmino(cdc *amino.Codec) + func RegisterEventDatas(cdc *amino.Codec) + func RegisterEvidences(cdc *amino.Codec) + func RegisterMockEvidences(cdc *amino.Codec) + func RegisterMockEvidencesGlobal() + func ValidateHash(h []byte) error + func ValidateTime(t time.Time) error + func ValidatorListString(vals []*Validator) string + type ABCIResult struct + Code uint32 + Data cmn.HexBytes + func NewResultFromResponse(response *abci.ResponseDeliverTx) ABCIResult + func (a ABCIResult) Bytes() []byte + type ABCIResults []ABCIResult + func NewResults(responses []*abci.ResponseDeliverTx) ABCIResults + func (a ABCIResults) Bytes() []byte + func (a ABCIResults) Hash() []byte + func (a ABCIResults) ProveResult(i int) merkle.SimpleProof + type Address = crypto.Address + type Block struct + Evidence EvidenceData + LastCommit *Commit + func MakeBlock(height int64, txs []Tx, lastCommit *Commit, evidence []Evidence) *Block + func (b *Block) Hash() cmn.HexBytes + func (b *Block) HashesTo(hash []byte) bool + func (b *Block) MakePartSet(partSize int) *PartSet + func (b *Block) Marshal() ([]byte, error) + func (b *Block) MarshalTo(data []byte) (int, error) + func (b *Block) Size() int + func (b *Block) String() string + func (b *Block) StringIndented(indent string) string + func (b *Block) StringShort() string + func (b *Block) Unmarshal(bs []byte) error + func (b *Block) ValidateBasic() error + type BlockEventPublisher interface + PublishEventNewBlock func(block EventDataNewBlock) error + PublishEventNewBlockHeader func(header EventDataNewBlockHeader) error + PublishEventTx func(EventDataTx) error + PublishEventValidatorSetUpdates func(EventDataValidatorSetUpdates) error + type BlockID struct + Hash cmn.HexBytes + PartsHeader PartSetHeader + func (blockID BlockID) Equals(other BlockID) bool + func (blockID BlockID) IsComplete() bool + func (blockID BlockID) IsZero() bool + func (blockID BlockID) Key() string + func (blockID BlockID) String() string + func (blockID BlockID) ValidateBasic() error + type BlockMeta struct + BlockID BlockID + Header Header + func NewBlockMeta(block *Block, blockParts *PartSet) *BlockMeta + func (bm *BlockMeta) Marshal() ([]byte, error) + func (bm *BlockMeta) MarshalTo(data []byte) (int, error) + func (bm *BlockMeta) Size() int + func (bm *BlockMeta) Unmarshal(bs []byte) error + type BlockParams struct + MaxBytes int64 + MaxGas int64 + TimeIotaMs int64 + func DefaultBlockParams() BlockParams + type CanonicalBlockID struct + Hash cmn.HexBytes + PartsHeader CanonicalPartSetHeader + func CanonicalizeBlockID(blockID BlockID) CanonicalBlockID + type CanonicalPartSetHeader struct + Hash cmn.HexBytes + Total int + func CanonicalizePartSetHeader(psh PartSetHeader) CanonicalPartSetHeader + type CanonicalProposal struct + BlockID CanonicalBlockID + ChainID string + Height int64 + POLRound int64 + Round int64 + Timestamp time.Time + Type SignedMsgType + func CanonicalizeProposal(chainID string, proposal *Proposal) CanonicalProposal + type CanonicalVote struct + BlockID CanonicalBlockID + ChainID string + Height int64 + Round int64 + Timestamp time.Time + Type SignedMsgType + func CanonicalizeVote(chainID string, vote *Vote) CanonicalVote + type Commit struct + BlockID BlockID + Precommits []*CommitSig + func MakeCommit(blockID BlockID, height int64, round int, voteSet *VoteSet, ...) (*Commit, error) + func NewCommit(blockID BlockID, precommits []*CommitSig) *Commit + func (commit *Commit) BitArray() *cmn.BitArray + func (commit *Commit) GetByIndex(valIdx int) *Vote + func (commit *Commit) GetVote(valIdx 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 + func (commit *Commit) VoteSignBytes(chainID string, valIdx int) []byte + type CommitSig Vote + func (cs *CommitSig) String() string + type ConsensusParams struct + Block BlockParams + Evidence EvidenceParams + Validator ValidatorParams + func DefaultConsensusParams() *ConsensusParams + func (params *ConsensusParams) Equals(params2 *ConsensusParams) bool + func (params *ConsensusParams) Hash() []byte + func (params *ConsensusParams) Validate() error + func (params ConsensusParams) Update(params2 *abci.ConsensusParams) ConsensusParams + type Data struct + Txs Txs + func (data *Data) Hash() cmn.HexBytes + func (data *Data) StringIndented(indent string) string + type DuplicateVoteEvidence struct + PubKey crypto.PubKey + VoteA *Vote + VoteB *Vote + func (dve *DuplicateVoteEvidence) Address() []byte + func (dve *DuplicateVoteEvidence) Bytes() []byte + func (dve *DuplicateVoteEvidence) Equal(ev Evidence) bool + func (dve *DuplicateVoteEvidence) Hash() []byte + func (dve *DuplicateVoteEvidence) Height() int64 + func (dve *DuplicateVoteEvidence) String() string + func (dve *DuplicateVoteEvidence) ValidateBasic() error + func (dve *DuplicateVoteEvidence) Verify(chainID string, pubKey crypto.PubKey) error + type ErrEvidenceInvalid struct + ErrorValue error + Evidence Evidence + func NewErrEvidenceInvalid(ev Evidence, err error) *ErrEvidenceInvalid + func (err *ErrEvidenceInvalid) Error() string + type ErrEvidenceOverflow struct + GotNum int64 + MaxNum int64 + func NewErrEvidenceOverflow(max, got int64) *ErrEvidenceOverflow + func (err *ErrEvidenceOverflow) Error() string + type ErrInvalidCommitHeight struct + Actual int64 + Expected int64 + func NewErrInvalidCommitHeight(expected, actual int64) ErrInvalidCommitHeight + func (e ErrInvalidCommitHeight) Error() string + type ErrInvalidCommitPrecommits struct + Actual int + Expected int + func NewErrInvalidCommitPrecommits(expected, actual int) ErrInvalidCommitPrecommits + func (e ErrInvalidCommitPrecommits) Error() string + type ErrVoteConflictingVotes struct + func NewConflictingVoteError(val *Validator, voteA, voteB *Vote) *ErrVoteConflictingVotes + func (err *ErrVoteConflictingVotes) Error() string + type EventBus struct + func NewEventBus() *EventBus + func NewEventBusWithBufferCapacity(cap int) *EventBus + func (b *EventBus) NumClientSubscriptions(clientID string) int + func (b *EventBus) NumClients() int + func (b *EventBus) OnStart() error + func (b *EventBus) OnStop() + func (b *EventBus) Publish(eventType string, eventData TMEventData) error + func (b *EventBus) PublishEventCompleteProposal(data EventDataCompleteProposal) error + func (b *EventBus) PublishEventLock(data EventDataRoundState) error + func (b *EventBus) PublishEventNewBlock(data EventDataNewBlock) error + func (b *EventBus) PublishEventNewBlockHeader(data EventDataNewBlockHeader) error + func (b *EventBus) PublishEventNewRound(data EventDataNewRound) error + func (b *EventBus) PublishEventNewRoundStep(data EventDataRoundState) error + func (b *EventBus) PublishEventPolka(data EventDataRoundState) error + func (b *EventBus) PublishEventRelock(data EventDataRoundState) error + func (b *EventBus) PublishEventTimeoutPropose(data EventDataRoundState) error + func (b *EventBus) PublishEventTimeoutWait(data EventDataRoundState) error + func (b *EventBus) PublishEventTx(data EventDataTx) error + func (b *EventBus) 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, subscriber string, query tmpubsub.Query) error + func (b *EventBus) UnsubscribeAll(ctx context.Context, subscriber string) error + type EventBusSubscriber interface + NumClientSubscriptions func(clientID string) int + NumClients func() int + Subscribe func(ctx context.Context, subscriber string, query tmpubsub.Query, ...) (Subscription, error) + Unsubscribe func(ctx context.Context, subscriber string, query tmpubsub.Query) error + UnsubscribeAll func(ctx context.Context, subscriber string) error + type EventDataCompleteProposal struct + BlockID BlockID + Height int64 + Round int + Step string + type EventDataNewBlock struct + Block *Block + ResultBeginBlock abci.ResponseBeginBlock + ResultEndBlock abci.ResponseEndBlock + type EventDataNewBlockHeader struct + Header Header + ResultBeginBlock abci.ResponseBeginBlock + ResultEndBlock abci.ResponseEndBlock + type EventDataNewRound struct + Height int64 + Proposer ValidatorInfo + Round int + Step string + type EventDataRoundState struct + Height int64 + Round int + Step string + type EventDataString string + type EventDataTx struct + type EventDataValidatorSetUpdates struct + ValidatorUpdates []*Validator + type EventDataVote struct + Vote *Vote + type Evidence interface + Address func() []byte + Bytes func() []byte + Equal func(Evidence) bool + Hash func() []byte + Height func() int64 + String func() string + ValidateBasic func() error + Verify func(chainID string, pubKey crypto.PubKey) error + type EvidenceData struct + Evidence EvidenceList + func (data *EvidenceData) Hash() cmn.HexBytes + func (data *EvidenceData) StringIndented(indent string) string + type EvidenceList []Evidence + func (evl EvidenceList) Has(evidence Evidence) bool + func (evl EvidenceList) Hash() []byte + func (evl EvidenceList) String() string + type EvidenceParams struct + MaxAge int64 + func DefaultEvidenceParams() EvidenceParams + type GenesisDoc struct + AppHash cmn.HexBytes + AppState json.RawMessage + ChainID string + ConsensusParams *ConsensusParams + GenesisTime time.Time + Validators []GenesisValidator + func GenesisDocFromFile(genDocFile string) (*GenesisDoc, error) + func GenesisDocFromJSON(jsonBlob []byte) (*GenesisDoc, error) + func (genDoc *GenesisDoc) SaveAs(file string) error + func (genDoc *GenesisDoc) ValidateAndComplete() error + func (genDoc *GenesisDoc) ValidatorHash() []byte + type GenesisValidator struct + Address Address + Name string + Power int64 + PubKey crypto.PubKey + type HashedParams struct + BlockMaxBytes int64 + BlockMaxGas int64 + type Header struct + AppHash cmn.HexBytes + ChainID string + ConsensusHash cmn.HexBytes + DataHash cmn.HexBytes + EvidenceHash cmn.HexBytes + Height int64 + LastBlockID BlockID + LastCommitHash cmn.HexBytes + LastResultsHash cmn.HexBytes + NextValidatorsHash cmn.HexBytes + NumTxs int64 + ProposerAddress Address + Time time.Time + TotalTxs int64 + ValidatorsHash cmn.HexBytes + Version version.Consensus + func (h *Header) Hash() cmn.HexBytes + func (h *Header) Populate(version version.Consensus, chainID string, timestamp time.Time, ...) + func (h *Header) StringIndented(indent string) string + type MockBadEvidence struct + func (e MockBadEvidence) Equal(ev Evidence) bool + func (e MockBadEvidence) String() string + func (e MockBadEvidence) ValidateBasic() error + func (e MockBadEvidence) Verify(chainID string, pubKey crypto.PubKey) error + type MockGoodEvidence struct + Address_ []byte + Height_ int64 + func NewMockGoodEvidence(height int64, idx int, address []byte) MockGoodEvidence + func (e MockGoodEvidence) Address() []byte + func (e MockGoodEvidence) Bytes() []byte + func (e MockGoodEvidence) Equal(ev Evidence) bool + func (e MockGoodEvidence) Hash() []byte + func (e MockGoodEvidence) Height() int64 + func (e MockGoodEvidence) String() string + func (e MockGoodEvidence) ValidateBasic() error + func (e MockGoodEvidence) Verify(chainID string, pubKey crypto.PubKey) error + type MockPV struct + func NewMockPV() *MockPV + func NewMockPVWithParams(privKey crypto.PrivKey, breakProposalSigning, breakVoteSigning bool) *MockPV + func (pv *MockPV) DisableChecks() + func (pv *MockPV) GetPubKey() crypto.PubKey + func (pv *MockPV) SignProposal(chainID string, proposal *Proposal) error + func (pv *MockPV) SignVote(chainID string, vote *Vote) error + func (pv *MockPV) String() string + type MockRandomGoodEvidence struct + func NewMockRandomGoodEvidence(height int64, address []byte, randBytes []byte) MockRandomGoodEvidence + func (e MockRandomGoodEvidence) Hash() []byte + type NopEventBus struct + 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) PublishEventNewRound(data EventDataRoundState) error + func (NopEventBus) PublishEventNewRoundStep(data EventDataRoundState) error + func (NopEventBus) PublishEventPolka(data EventDataRoundState) error + func (NopEventBus) PublishEventRelock(data EventDataRoundState) 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, subscriber string, query tmpubsub.Query) error + func (NopEventBus) UnsubscribeAll(ctx context.Context, subscriber string) error + type P2PID string + type Part struct + Bytes cmn.HexBytes + Index int + Proof merkle.SimpleProof + func (part *Part) String() string + func (part *Part) StringIndented(indent string) string + func (part *Part) ValidateBasic() error + type PartSet struct + func NewPartSetFromData(data []byte, partSize int) *PartSet + func NewPartSetFromHeader(header PartSetHeader) *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 struct + Hash cmn.HexBytes + Total int + func (psh PartSetHeader) Equals(other PartSetHeader) bool + func (psh PartSetHeader) IsZero() bool + func (psh PartSetHeader) String() string + func (psh PartSetHeader) ValidateBasic() error + type PartSetReader struct + func NewPartSetReader(parts []*Part) *PartSetReader + func (psr *PartSetReader) Read(p []byte) (n int, err error) + type PrivValidator interface + GetPubKey func() crypto.PubKey + SignProposal func(chainID string, proposal *Proposal) error + SignVote func(chainID string, vote *Vote) error + type PrivValidatorsByAddress []PrivValidator + func (pvs PrivValidatorsByAddress) Len() int + func (pvs PrivValidatorsByAddress) Less(i, j int) bool + func (pvs PrivValidatorsByAddress) Swap(i, j int) + type Proposal struct + BlockID BlockID + Height int64 + POLRound int + Round int + Signature []byte + Timestamp time.Time + Type SignedMsgType + func NewProposal(height int64, round int, polRound int, blockID BlockID) *Proposal + func (p *Proposal) SignBytes(chainID string) []byte + func (p *Proposal) String() string + func (p *Proposal) ValidateBasic() error + type Signable interface + SignBytes func(chainID string) []byte + type SignedHeader struct + Commit *Commit + func (sh SignedHeader) String() string + func (sh SignedHeader) StringIndented(indent string) string + func (sh SignedHeader) ValidateBasic(chainID string) error + type SignedMsgType byte + const PrecommitType + const PrevoteType + const ProposalType + type Subscription interface + Cancelled func() <-chan struct{} + Err func() error + Out func() <-chan tmpubsub.Message + type TMEventData interface + type Tx []byte + func (tx Tx) Hash() []byte + func (tx Tx) String() string + type TxEventPublisher interface + PublishEventTx func(EventDataTx) error + type TxProof struct + Data Tx + Proof merkle.SimpleProof + RootHash cmn.HexBytes + func (tp TxProof) Leaf() []byte + func (tp TxProof) Validate(dataHash []byte) error + type TxResult struct + Height int64 + Index uint32 + Result abci.ResponseDeliverTx + Tx Tx + type Txs []Tx + func (txs Txs) Hash() []byte + func (txs Txs) Index(tx Tx) int + func (txs Txs) IndexByHash(hash []byte) int + func (txs Txs) Proof(i int) TxProof + type Validator struct + Address Address + ProposerPriority int64 + PubKey crypto.PubKey + VotingPower int64 + func NewValidator(pubKey crypto.PubKey, votingPower int64) *Validator + func (v *Validator) Bytes() []byte + func (v *Validator) CompareProposerPriority(other *Validator) *Validator + func (v *Validator) Copy() *Validator + func (v *Validator) String() string + type ValidatorInfo struct + Address Address + Index int + type ValidatorParams struct + PubKeyTypes []string + func DefaultValidatorParams() ValidatorParams + func (params *ValidatorParams) IsValidPubkeyType(pubkeyType string) bool + type ValidatorSet struct + Proposer *Validator + Validators []*Validator + func NewValidatorSet(valz []*Validator) *ValidatorSet + func (vals *ValidatorSet) Copy() *ValidatorSet + func (vals *ValidatorSet) CopyIncrementProposerPriority(times int) *ValidatorSet + func (vals *ValidatorSet) GetByAddress(address []byte) (index int, val *Validator) + func (vals *ValidatorSet) GetByIndex(index int) (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 int) + 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) TotalVotingPower() int64 + func (vals *ValidatorSet) UpdateWithChangeSet(changes []*Validator) error + func (vals *ValidatorSet) VerifyCommit(chainID string, blockID BlockID, height int64, commit *Commit) error + func (vals *ValidatorSet) VerifyFutureCommit(newSet *ValidatorSet, chainID string, blockID BlockID, height int64, ...) error + type ValidatorsByAddress []*Validator + func (valz ValidatorsByAddress) Len() int + func (valz ValidatorsByAddress) Less(i, j int) bool + func (valz ValidatorsByAddress) Swap(i, j int) + type Vote struct + BlockID BlockID + Height int64 + Round int + Signature []byte + Timestamp time.Time + Type SignedMsgType + ValidatorAddress Address + ValidatorIndex int + func (vote *Vote) CommitSig() *CommitSig + func (vote *Vote) Copy() *Vote + func (vote *Vote) SignBytes(chainID string) []byte + func (vote *Vote) String() string + func (vote *Vote) ValidateBasic() error + func (vote *Vote) Verify(chainID string, pubKey crypto.PubKey) error + type VoteSet struct + func CommitToVoteSet(chainID string, commit *Commit, vals *ValidatorSet) *VoteSet + func NewVoteSet(chainID string, height int64, round int, type_ SignedMsgType, ...) *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 struct + PeerMaj23s map[P2PID]BlockID + Votes []string + VotesBitArray string + type VoteSetReader interface + BitArray func() *cmn.BitArray + GetByIndex func(int) *Vote + Height func() int64 + IsCommit func() bool + Round func() int + Size func() int + Type func() byte