Versions in this module Expand all Collapse all v0 v0.1.7 Jun 25, 2023 Changes in this version + var WasmStoreCode = false v0.1.6 Jun 15, 2023 v0.1.5 Jun 6, 2023 v0.1.4 Jun 2, 2023 Changes in this version + const MILESTONE_MERCURY + func GetMercuryHeight() int64 + func HigherThanMercury(h int64) bool + func InitMilestoneMercuryHeight(h int64) + func SetMilestoneMercuryHeight(h int64) + func UnittestOnlySetMilestoneMercuryHeight(h int64) v0.1.3 May 18, 2023 v0.1.2 May 16, 2023 Changes in this version + func InitMilestoneEarthHeight(h int64) + func IsPrivateNet() bool + type WrapCMTx struct + Nonce uint64 + Tx Tx + func (wtx *WrapCMTx) GetNonce() uint64 + func (wtx *WrapCMTx) GetTx() Tx v0.1.1 Mar 29, 2023 v0.1.0 Mar 27, 2023 Changes in this version + const ABCIEvidenceTypeDuplicateVote + const ABCIEvidenceTypeMock + const ABCIPubKeyTypeEd25519 + const ABCIPubKeyTypeSecp256k1 + const ABCIPubKeyTypeSr25519 + const AddressStringLen + const BlockHeightKey + const CompressDividing + const CongestionHigherGpMode + const DuplicateVoteEvidenceName + const EventBlockPart + const EventBlockTime + const EventCompleteProposal + const EventLock + const EventNewBlock + const EventNewBlockHeader + const EventNewRound + const EventNewRoundStep + const EventPendingTx + const EventPolka + const EventProposeRequest + const EventRelock + const EventRmPendingTx + const EventSignVote + const EventTimeoutPropose + const EventTimeoutWait + const EventTx + const EventTxs + const EventTypeKey + const EventUnlock + const EventValidBlock + const EventValidatorSetUpdates + const EventVote + const FlagAppendPid + const FlagBlockCompressFlag + const FlagBlockCompressThreshold + const FlagBlockCompressType + const FlagBufferSize + const FlagDDSCompressFlag + const FlagDDSCompressType + const FlagDeltaVersion + const FlagDownloadDDS + const FlagFastQuery + const FlagRedisAuth + const FlagRedisDB + const FlagRedisExpire + const FlagRedisUrl + const FlagSigCacheSize + const FlagUploadDDS + const MILESTONE_EARTH + const MILESTONE_Venus4 + const MainNet + const MaxAminoOverheadForBlock + const MaxBlockSizeBytes + const MaxChainIDLen + const MaxEvidenceBytes + const MaxEvidenceBytesDenominator + const MaxHeaderBytes + const MaxTotalVotingPower + const MaxVoteBytes + const MaxVotesCount + const MinimalGpMode + const NoGasUsedCap + const NormalGpMode + const PriorityWindowSizeFactor + const TestNet + const TimeFormat + const TimeoutCommit + const TxHashKey + const TxHashLen + const TxHeightKey + var ABCIPubKeyTypesToAminoNames = map[string]string + var BlockCompressFlag = 0 + var BlockCompressThreshold = 1024000 + var BlockCompressType = 0x00 + var BlockPartSizeBytes = 65536 + var DBBackend = string(dbm.GoLevelDBBackend) + var DeltaVersion = 10 + var DownloadDelta = false + var EnableEventBlockTime = false + 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 FastQuery = false + var Json = jsoniter.ConfigCompatibleWithStandardLibrary + var MaxBlockPartsCount = (MaxBlockSizeBytes / BlockPartSizeBytes) + 1 + var MaxSignatureSize = tmmath.MaxInt(ed25519.SignatureSize, 64) + var PB2TM = pb2tm + var PeerStateKey = "ConsensusReactor.peerState" + var TM2PB = tm2pb + var UploadDelta = false + func Bytes2Hash(txBytes []byte) string + func CanonicalTime(t time.Time) string + func ComputeAminoOverhead(tx Tx, fieldNum int) int64 + func EventQueryTxFor(tx Tx) tmpubsub.Query + func EvidenceToProto(evidence Evidence) (*tmproto.Evidence, error) + func GetCodec() *amino.Codec + func GetEarthHeight() int64 + func GetNodePruneHeight() int64 + func GetStartBlockHeight() int64 + func GetVenus4Height() int64 + func HigherThanEarth(h int64) bool + func HigherThanVenus4(h int64) bool + func IBCCanonicalizeBlockID(rbid *BlockID) *tmproto.CanonicalBlockID + func IBCCanonicalizePartSetHeader(psh PartSetHeader) tmproto.CanonicalPartSetHeader + func IBCCanonicalizeProposal(chainID string, proposal *Proposal) tmproto.CanonicalProposal + func IBCCanonicalizeVote(chainID string, vote *Vote) tmproto.CanonicalVote + func InitSignatureCache() + func IsBlockDataCompressed(payload []byte) bool + func IsErrNotEnoughVotingPowerSigned(err error) bool + func IsMainNet() bool + func IsTestNet() 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 ProposalSignBytes(chainID string, p *Proposal) []byte + 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 SetMilestoneEarthHeight(h int64) + func SetMilestoneVenus4Height(h int64) + func SetupMainNetEnvironment(pruneH int64) + func SetupTestNetEnvironment(pruneH int64) + func UncompressBlockFromBytes(payload []byte) (res []byte, compressSign int, err error) + func UncompressBlockFromBytesTo(payload []byte, buf *bytes.Buffer) (compressSign int, err error) + func UncompressBlockFromReader(pbpReader io.Reader) (io.Reader, error) + func UnittestOnlySetMilestoneEarthHeight(h int64) + func UnittestOnlySetMilestoneVenus4Height(h int64) + func UpdateBlockPartSizeBytes(size int) + func ValidateHash(h []byte) error + func ValidateTime(t time.Time) error + func ValidatorListString(vals []*Validator) string + func VoteSignBytes(chainID string, vote *Vote) []byte + type ABCIResult struct + Code uint32 + Data bytes.HexBytes + func NewResultFromResponse(response *abci.ResponseDeliverTx) ABCIResult + func (a ABCIResult) AminoSize() int + func (a ABCIResult) Bytes() []byte + func (a ABCIResult) MarshalToAmino(_ *amino.Codec) ([]byte, error) + 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 BigIntArray []*big.Int + func (s BigIntArray) Len() int + func (s BigIntArray) Less(i, j int) bool + func (s BigIntArray) Swap(i, j int) + type Block struct + Evidence EvidenceData + LastCommit *Commit + func MakeBlock(height int64, txs []Tx, lastCommit *Commit, evidence []Evidence) *Block + func (b *Block) AminoSize(cdc *amino.Codec) int + func (b *Block) FastSize() (size int) + func (b *Block) Hash() tmbytes.HexBytes + func (b *Block) HashesTo(hash []byte) bool + func (b *Block) MakePartSet(partSize int) *PartSet + func (b *Block) MakePartSetByExInfo(exInfo *BlockExInfo) *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) UnmarshalFromAmino(cdc *amino.Codec, data []byte) error + func (b *Block) ValidateBasic() error + func (b Block) To() CM40Block + type BlockEventPublisher interface + PublishEventLatestBlockTime func(time EventDataBlockTime) error + PublishEventNewBlock func(block EventDataNewBlock) error + PublishEventNewBlockHeader func(header EventDataNewBlockHeader) error + PublishEventPendingTx func(EventDataTx) error + PublishEventRmPendingTx func(EventDataRmPendingTx) error + PublishEventTx func(EventDataTx) error + PublishEventTxs func(EventDataTxs) error + PublishEventValidatorSetUpdates func(EventDataValidatorSetUpdates) error + type BlockExInfo struct + BlockCompressFlag int + BlockCompressType int + BlockPartSize int + func (info BlockExInfo) IsCompressed() bool + type BlockGPResults struct + func NewBlockGPResults(checkBlocksNum int) *BlockGPResults + func (rs *BlockGPResults) ExecuteSamplingBy(lastPrice *big.Int, adoptHigherGp bool) []*big.Int + func (rs *BlockGPResults) Pop() (*SingleBlockGPs, error) + func (rs *BlockGPResults) Push(gp *SingleBlockGPs) error + func (rs BlockGPResults) Cap() int + func (rs BlockGPResults) Front() int + func (rs BlockGPResults) IsEmpty() bool + func (rs BlockGPResults) IsFull() bool + func (rs BlockGPResults) Rear() int + type BlockID struct + Hash tmbytes.HexBytes + PartsHeader PartSetHeader + func BlockIDFromProto(bID *tmproto.BlockID) (*BlockID, error) + func (blockID *BlockID) ToIBCProto() tmproto.BlockID + func (blockID *BlockID) ToProto() tmproto.BlockID + func (blockID *BlockID) UnmarshalFromAmino(cdc *amino.Codec, data []byte) error + func (blockID BlockID) AminoSize(_ *amino.Codec) int + 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 BlockIDFlag byte + const BlockIDFlagAbsent + const BlockIDFlagCommit + const BlockIDFlagNil + type BlockMeta struct + BlockID BlockID + BlockSize int + Header Header + NumTxs int + 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 + func (bm *BlockMeta) UnmarshalFromAmino(cdc *amino.Codec, data []byte) error + func (bm *BlockMeta) ValidateBasic() error + type BlockParams struct + MaxBytes int64 + MaxGas int64 + TimeIotaMs int64 + func DefaultBlockParams() BlockParams + type CM40Block struct + Evidence EvidenceData + LastCommit *IBCCommit + func (b CM40Block) From(block Block) CM40Block + type CM40EventDataNewBlock struct + Block *CM40Block + ResultBeginBlock abci.ResponseBeginBlock + ResultEndBlock abci.ResponseEndBlock + func (e CM40EventDataNewBlock) From(block EventDataNewBlock) CM40EventDataNewBlock + type Cache struct + func SignatureCache() *Cache + func (c *Cache) Add(key []byte, value string) + func (c *Cache) Get(key []byte) (string, bool) + func (c *Cache) HitCount() int64 + func (c *Cache) ReadCount() int64 + func (c *Cache) Remove(key []byte) + type CanonicalBlockID struct + Hash bytes.HexBytes + PartsHeader CanonicalPartSetHeader + func CanonicalizeBlockID(blockID BlockID) CanonicalBlockID + type CanonicalPartSetHeader struct + Hash bytes.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 + Height int64 + Round int + Signatures []CommitSig + func CommitFromProto(cp *tmproto.Commit) (*Commit, error) + func MakeCommit(blockID BlockID, height int64, round int, voteSet *VoteSet, ...) (*Commit, error) + func NewCommit(height int64, round int, blockID BlockID, commitSigs []CommitSig) *Commit + func (c Commit) To() IBCCommit + func (commit *Commit) BitArray() *bits.BitArray + func (commit *Commit) GetByIndex(valIdx int) *Vote + func (commit *Commit) GetHeight() int64 + func (commit *Commit) GetRound() int + func (commit *Commit) GetVote(valIdx int) *Vote + func (commit *Commit) Hash() tmbytes.HexBytes + func (commit *Commit) IBCVoteSignBytes(chainID string, valIdx int) []byte + 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) UnmarshalFromAmino(cdc *amino.Codec, data []byte) error + func (commit *Commit) ValidateBasic() error + func (commit *Commit) VoteSignBytes(chainID string, valIdx int) []byte + func (commit Commit) AminoSize(cdc *amino.Codec) int + type CommitSig struct + BlockIDFlag BlockIDFlag + Signature []byte + Timestamp time.Time + ValidatorAddress Address + func NewCommitSigAbsent() CommitSig + func NewCommitSigForBlock(signature []byte, valAddr Address, ts time.Time) CommitSig + func (cs *CommitSig) FromProto(csp tmproto.CommitSig) error + func (cs *CommitSig) ToProto() *tmproto.CommitSig + func (cs *CommitSig) UnmarshalFromAmino(_ *amino.Codec, data []byte) error + func (cs CommitSig) Absent() bool + func (cs CommitSig) AminoSize(_ *amino.Codec) int + func (cs CommitSig) BlockID(commitBlockID BlockID) BlockID + func (cs CommitSig) ForBlock() bool + func (cs CommitSig) String() string + func (cs CommitSig) ValidateBasic() error + 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 (d *Data) UnmarshalFromAmino(_ *amino.Codec, data []byte) error + func (d Data) AminoSize(_ *amino.Codec) int + func (data *Data) Hash(height int64) tmbytes.HexBytes + func (data *Data) StringIndented(indent string) string + type DeltaPayload struct + ABCIRsp []byte + DeltasBytes []byte + WasmWatchBytes []byte + WatchBytes []byte + func (payload *DeltaPayload) AminoSize(_ *amino.Codec) int + func (payload *DeltaPayload) MarshalAminoTo(_ *amino.Codec, buf *bytes.Buffer) error + func (payload *DeltaPayload) MarshalToAmino(cdc *amino.Codec) ([]byte, error) + func (payload *DeltaPayload) UnmarshalFromAmino(_ *amino.Codec, data []byte) error + type Deltas struct + CompressFlag int + CompressType int + From string + Height int64 + Payload DeltaPayload + func (d *Deltas) ABCIRsp() []byte + func (d *Deltas) CompressOrUncompressElapsed() time.Duration + func (d *Deltas) DeltasBytes() []byte + func (d *Deltas) HashElapsed() time.Duration + func (d *Deltas) Marshal() ([]byte, error) + func (d *Deltas) MarshalOrUnmarshalElapsed() time.Duration + func (d *Deltas) Size() int + func (d *Deltas) String() string + func (d *Deltas) Unmarshal(bs []byte) error + func (d *Deltas) WasmWatchBytes() []byte + func (d *Deltas) WatchBytes() []byte + func (dds *Deltas) Validate(height int64) bool + type DeltasMessage struct + CompressType int + From string + Height int64 + Metadata []byte + MetadataHash []byte + func (m *DeltasMessage) AminoSize(_ *amino.Codec) int + func (m *DeltasMessage) MarshalAminoTo(_ *amino.Codec, buf *bytes.Buffer) error + func (m *DeltasMessage) MarshalToAmino(cdc *amino.Codec) ([]byte, error) + func (m *DeltasMessage) UnmarshalFromAmino(_ *amino.Codec, data []byte) error + type DuplicateVoteEvidence struct + PubKey crypto.PubKey + VoteA *Vote + VoteB *Vote + func NewDuplicateVoteEvidence(pubkey crypto.PubKey, vote1 *Vote, vote2 *Vote) *DuplicateVoteEvidence + 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) Time() time.Time + func (dve *DuplicateVoteEvidence) UnmarshalFromAmino(cdc *amino.Codec, data []byte) error + func (dve *DuplicateVoteEvidence) ValidateBasic() error + func (dve *DuplicateVoteEvidence) Verify(chainID string, pubKey crypto.PubKey) error + func (dve DuplicateVoteEvidence) AminoSize(cdc *amino.Codec) int + 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 ErrInvalidCommitSignatures struct + Actual int + Expected int + func NewErrInvalidCommitSignatures(expected, actual int) ErrInvalidCommitSignatures + func (e ErrInvalidCommitSignatures) Error() string + type ErrNotEnoughVotingPowerSigned struct + Got int64 + Needed int64 + func (e ErrNotEnoughVotingPowerSigned) Error() string + type ErrVoteConflictingVotes struct + func NewConflictingVoteError(val *Validator, vote1, vote2 *Vote) *ErrVoteConflictingVotes + func (err *ErrVoteConflictingVotes) Error() string + type ErroringMockPV struct + func NewErroringMockPV() *ErroringMockPV + func (pv *ErroringMockPV) SignProposal(chainID string, proposal *Proposal) error + func (pv *ErroringMockPV) SignVote(chainID string, vote *Vote) error + type EventBus struct + func NewEventBus() *EventBus + func NewEventBusWithBufferCapacity(cap int) *EventBus + func (b *EventBus) NumClientSubscriptions(clientID string) int + func (b *EventBus) NumClients() int + func (b *EventBus) OnStart() error + func (b *EventBus) OnStop() + func (b *EventBus) Publish(eventType string, eventData TMEventData) error + func (b *EventBus) PublishEventCompleteProposal(data EventDataCompleteProposal) error + func (b *EventBus) PublishEventLatestBlockTime(data EventDataBlockTime) 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) PublishEventPendingTx(data EventDataTx) error + func (b *EventBus) PublishEventPolka(data EventDataRoundState) error + func (b *EventBus) PublishEventRelock(data EventDataRoundState) error + func (b *EventBus) PublishEventRmPendingTx(data EventDataRmPendingTx) 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) PublishEventTxs(data EventDataTxs) 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 EventDataBlockTime struct + Available bool + Height int64 + TimeNow int64 + TxNum int + type EventDataCompleteProposal struct + BlockID BlockID + Height int64 + Round int + Step string + type EventDataNewBlock struct + Block *Block + ResultBeginBlock abci.ResponseBeginBlock + ResultEndBlock abci.ResponseEndBlock + func (e EventDataNewBlock) Upgrade() interface{} + type EventDataNewBlockHeader struct + Header Header + NumTxs int64 + ResultBeginBlock abci.ResponseBeginBlock + ResultEndBlock abci.ResponseEndBlock + type EventDataNewRound struct + Height int64 + Proposer ValidatorInfo + Round int + Step string + type EventDataRmPendingTx struct + From string + Hash []byte + Nonce uint64 + Reason RmPendingTxReason + type EventDataRoundState struct + Height int64 + Round int + Step string + type EventDataString string + type EventDataTx struct + Nonce uint64 + type EventDataTxs struct + Height int64 + Results []*abci.ResponseDeliverTx + 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 + Time func() time.Time + ValidateBasic func() error + Verify func(chainID string, pubKey crypto.PubKey) error + func EvidenceFromProto(evidence *tmproto.Evidence) (Evidence, error) + type EvidenceData struct + Evidence EvidenceList + func (d *EvidenceData) UnmarshalFromAmino(cdc *amino.Codec, data []byte) error + func (d EvidenceData) AminoSize(cdc *amino.Codec) int + func (data *EvidenceData) Hash() tmbytes.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 + MaxAgeDuration time.Duration + MaxAgeNumBlocks int64 + func DefaultEvidenceParams() EvidenceParams + type GenesisDoc struct + AppHash tmbytes.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 + type GenesisValidator struct + Address Address + Name string + Power int64 + PubKey crypto.PubKey + type HashedParams struct + BlockMaxBytes int64 + BlockMaxGas int64 + type Header struct + AppHash tmbytes.HexBytes + ChainID string + ConsensusHash tmbytes.HexBytes + DataHash tmbytes.HexBytes + EvidenceHash tmbytes.HexBytes + Height int64 + LastBlockID BlockID + LastCommitHash tmbytes.HexBytes + LastResultsHash tmbytes.HexBytes + NextValidatorsHash tmbytes.HexBytes + ProposerAddress Address + Time time.Time + ValidatorsHash tmbytes.HexBytes + Version version.Consensus + func HeaderFromProto(ph *tmproto.Header) (Header, error) + func (h *Header) Hash() tmbytes.HexBytes + func (h *Header) IBCHash() tmbytes.HexBytes + func (h *Header) Populate(version version.Consensus, chainID string, timestamp time.Time, ...) + func (h *Header) PureIBCHash() tmbytes.HexBytes + func (h *Header) StringIndented(indent string) string + func (h *Header) ToProto() *tmproto.Header + func (h *Header) UnmarshalFromAmino(cdc *amino.Codec, data []byte) error + func (h Header) AminoSize(cdc *amino.Codec) int + func (h Header) ValidateBasic() error + type IBCBlockID struct + Hash tmbytes.HexBytes + PartSetHeader IBCPartSetHeader + func (b IBCBlockID) From(bb BlockID) IBCBlockID + func (b IBCBlockID) ToBlockID() BlockID + type IBCCommit struct + BlockID IBCBlockID + Height int64 + Round int32 + Signatures []CommitSig + func (c *IBCCommit) ToCommit() *Commit + func (c IBCCommit) From(cc Commit) IBCCommit + type IBCHeader struct + AppHash tmbytes.HexBytes + ChainID string + ConsensusHash tmbytes.HexBytes + DataHash tmbytes.HexBytes + EvidenceHash tmbytes.HexBytes + Height int64 + LastBlockID IBCBlockID + LastCommitHash tmbytes.HexBytes + LastResultsHash tmbytes.HexBytes + NextValidatorsHash tmbytes.HexBytes + ProposerAddress Address + Time time.Time + ValidatorsHash tmbytes.HexBytes + Version tmversion.Consensus + func (h IBCHeader) From(header Header) IBCHeader + func (h IBCHeader) ToCM39Header() Header + type IBCPartSetHeader struct + Hash tmbytes.HexBytes + Total uint32 + func (p IBCPartSetHeader) From(header PartSetHeader) IBCPartSetHeader + type IBCSignedHeader struct + Commit *IBCCommit + type MockEvidence struct + EvidenceAddress []byte + EvidenceHeight int64 + EvidenceTime time.Time + func NewMockEvidence(height int64, eTime time.Time, idx int, address []byte) MockEvidence + func (e MockEvidence) Address() []byte + func (e MockEvidence) Bytes() []byte + func (e MockEvidence) Equal(ev Evidence) bool + func (e MockEvidence) Hash() []byte + func (e MockEvidence) Height() int64 + func (e MockEvidence) String() string + func (e MockEvidence) Time() time.Time + func (e MockEvidence) ValidateBasic() error + func (e MockEvidence) Verify(chainID string, pubKey crypto.PubKey) error + type MockPV struct + PrivKey crypto.PrivKey + func NewMockPV() MockPV + func NewMockPVWithParams(privKey crypto.PrivKey, breakProposalSigning, breakVoteSigning bool) MockPV + func (pv MockPV) DisableChecks() + func (pv MockPV) GetPubKey() (crypto.PubKey, error) + func (pv MockPV) SignBytes(bz []byte) ([]byte, 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 MockRandomEvidence struct + func NewMockRandomEvidence(height int64, eTime time.Time, address []byte, randBytes []byte) MockRandomEvidence + func (e MockRandomEvidence) Hash() []byte + type NopEventBus struct + func (NopEventBus) PublishEventCompleteProposal(data EventDataRoundState) error + func (NopEventBus) PublishEventLatestBlockTime(data EventDataBlockTime) 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) PublishEventPendingTx(data EventDataTx) error + func (NopEventBus) PublishEventPolka(data EventDataRoundState) error + func (NopEventBus) PublishEventRelock(data EventDataRoundState) error + func (NopEventBus) PublishEventRmPendingTx(EventDataRmPendingTx) error + func (NopEventBus) PublishEventTimeoutPropose(data EventDataRoundState) error + func (NopEventBus) PublishEventTimeoutWait(data EventDataRoundState) error + func (NopEventBus) PublishEventTx(data EventDataTx) error + func (NopEventBus) PublishEventTxs(data EventDataTxs) 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 tmbytes.HexBytes + Index int + Proof merkle.SimpleProof + func (part *Part) String() string + func (part *Part) StringIndented(indent string) string + func (part *Part) UnmarshalFromAmino(cdc *amino.Codec, data []byte) error + 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() *bits.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 tmbytes.HexBytes + Total int + func PartSetHeaderFromProto(ppsh *tmproto.PartSetHeader) (*PartSetHeader, error) + func (psh *PartSetHeader) ToIBCProto() tmproto.PartSetHeader + func (psh *PartSetHeader) ToProto() tmproto.PartSetHeader + func (psh *PartSetHeader) UnmarshalFromAmino(_ *amino.Codec, data []byte) error + func (psh PartSetHeader) AminoSize() 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, error) + SignBytes func(bz []byte) ([]byte, error) + 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 + HasVC bool + 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 ProposalFromProto(pp *tmproto.Proposal) (*Proposal, error) + func (p *Proposal) SignBytes(chainID string) []byte + func (p *Proposal) String() string + func (p *Proposal) ToProto() *tmproto.Proposal + func (p *Proposal) ValidateBasic() error + type RmPendingTxReason int + const Confirmed + const MinGasPrice + const Recheck + type Signable interface + SignBytes func(chainID string) []byte + type SignedHeader struct + Commit *Commit + func SignedHeaderFromProto(shp *tmproto.SignedHeader) (*SignedHeader, error) + func (sh *SignedHeader) ToProto() *tmproto.SignedHeader + func (sh SignedHeader) String() string + func (sh SignedHeader) StringIndented(indent string) string + func (sh SignedHeader) ValidateBasic(chainID string) error + func (sh SignedHeader) ValidateBasicForIBC(chainID string) error + type SignedMsgType byte + const PrecommitType + const PrevoteType + const ProposalType + type SingleBlockGPs struct + func NewSingleBlockGPs() *SingleBlockGPs + func (bgp *SingleBlockGPs) AddSampledGP(gp *big.Int) + func (bgp *SingleBlockGPs) Clear() + func (bgp *SingleBlockGPs) Copy() *SingleBlockGPs + func (bgp *SingleBlockGPs) SampleGP(adoptHigherGp bool) + func (bgp *SingleBlockGPs) Update(gp *big.Int, gas uint64) + func (bgp SingleBlockGPs) GetAll() []*big.Int + func (bgp SingleBlockGPs) GetGasUsed() uint64 + func (bgp SingleBlockGPs) GetSampled() []*big.Int + type Subscription interface + Cancelled func() <-chan struct{} + Err func() error + Out func() <-chan tmpubsub.Message + type TMEventData interface + type TreeDelta struct + IavlTreeDelta iavl.TreeDeltaMap + MptTreeDelta trie.MptDeltaMap + func NewTreeDelta() *TreeDelta + func (td *TreeDelta) Marshal() []byte + func (td *TreeDelta) Unmarshal(deltaBytes []byte) error + type TreeDeltaImp struct + IavlBytes []byte + MptBytes []byte + type Tx []byte + func (tx Tx) Hash() []byte + func (tx Tx) String() string + type TxEventPublisher interface + PublishEventPendingTx func(EventDataTx) error + PublishEventRmPendingTx func(EventDataRmPendingTx) error + PublishEventTx func(EventDataTx) error + type TxProof struct + Data Tx + Proof merkle.SimpleProof + RootHash tmbytes.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 + func (txResult *TxResult) UnmarshalFromAmino(cdc *amino.Codec, data []byte) error + 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 UpgradeAble interface + Upgrade func() interface{} + type Validator struct + Address Address + ProposerPriority int64 + PubKey crypto.PubKey + VotingPower int64 + func NewValidator(pubKey crypto.PubKey, votingPower int64) *Validator + func ValidatorFromProto(vp *tmproto.Validator) (*Validator, error) + func (v *Validator) Bytes() []byte + func (v *Validator) CompareProposerPriority(other *Validator) *Validator + func (v *Validator) Copy() *Validator + func (v *Validator) HeightBytes(h int64) []byte + func (v *Validator) IBCHeightBytes() []byte + func (v *Validator) OriginBytes() []byte + func (v *Validator) String() string + func (v *Validator) ToProto() (*tmproto.Validator, error) + 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 ValidatorSetFromProto(vp *tmproto.ValidatorSet) (*ValidatorSet, error) + 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(h int64) []byte + func (vals *ValidatorSet) IBCGetByAddress(address []byte) (index int, val *Validator) + func (vals *ValidatorSet) IBCHash() []byte + func (vals *ValidatorSet) IBCVerifyCommitLight(chainID string, blockID BlockID, height int64, commit *Commit) error + func (vals *ValidatorSet) IBCVerifyCommitLightTrusting(chainID string, blockID BlockID, height int64, commit *Commit, ...) error + 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) ToProto() (*tmproto.ValidatorSet, error) + 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) VerifyCommitLight(chainID string, blockID BlockID, height int64, commit *Commit) error + func (vals *ValidatorSet) VerifyCommitLightTrusting(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 ValidatorsByVotingPower []*Validator + func (valz ValidatorsByVotingPower) Len() int + func (valz ValidatorsByVotingPower) Less(i, j int) bool + func (valz ValidatorsByVotingPower) Swap(i, j int) + type Vote struct + BlockID BlockID + HasVC bool + Height int64 + Round int + Signature []byte + Timestamp time.Time + Type SignedMsgType + ValidatorAddress Address + ValidatorIndex int + func MakeVote(height int64, blockID BlockID, valSet *ValidatorSet, privVal PrivValidator, ...) (*Vote, error) + func VoteFromProto(pv *tmproto.Vote) (*Vote, error) + 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) ToProto() *tmproto.Vote + func (vote *Vote) UnmarshalFromAmino(cdc *amino.Codec, data []byte) error + func (vote *Vote) ValidateBasic() error + func (vote *Vote) Verify(chainID string, pubKey crypto.PubKey) error + func (vote Vote) AminoSize(cdc *amino.Codec) int + type VoteSet struct + func CommitToVoteSet(chainID string, commit *Commit, vals *ValidatorSet) *VoteSet + func NewVoteSet(chainID string, height int64, round int, signedMsgType SignedMsgType, ...) *VoteSet + func (voteSet *VoteSet) AddVote(vote *Vote) (added bool, err error) + func (voteSet *VoteSet) BitArray() *bits.BitArray + func (voteSet *VoteSet) BitArrayByBlockID(blockID BlockID) *bits.BitArray + func (voteSet *VoteSet) BitArrayString() string + func (voteSet *VoteSet) ChainID() string + func (voteSet *VoteSet) GetByAddress(address []byte) *Vote + func (voteSet *VoteSet) GetByIndex(valIndex int) *Vote + func (voteSet *VoteSet) GetHeight() int64 + func (voteSet *VoteSet) GetRound() int + func (voteSet *VoteSet) HasAll() bool + func (voteSet *VoteSet) HasTwoThirdsAny() bool + func (voteSet *VoteSet) HasTwoThirdsMajority() bool + func (voteSet *VoteSet) IsCommit() bool + 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 struct + PeerMaj23s map[P2PID]BlockID + Votes []string + VotesBitArray string + type VoteSetReader interface + BitArray func() *bits.BitArray + GetByIndex func(int) *Vote + GetHeight func() int64 + GetRound func() int + IsCommit func() bool + Size func() int + Type func() byte