Versions in this module Expand all Collapse all v1 v1.5.0 May 6, 2020 Changes in this version + type KeyValueHistories []*KeyValueHistory + func (k KeyValueHistories) String() string + type KeyValueHistory struct + Key []byte + ValueUpdateHistory *ValueUpdateHistory + func (k *KeyValueHistory) String() string + type ValueHistoryResult struct + Key []byte + Total uint32 + ValueUpdateHistories []*ValueUpdateHistory + type ValueUpdateHistory struct + BlockHeight uint64 + TimeStamp uint64 + TxHash []byte + TxIndex uint32 + Value []byte + func (v *ValueUpdateHistory) String() string v1.4.4 Feb 7, 2020 v1.4.3 Jan 16, 2020 Changes in this version type TxPool + GetPendingMaxNonce func([]byte) (uint64, error) v1.4.2 Dec 27, 2019 v1.4.1 Nov 7, 2019 v1.4.0 Oct 15, 2019 Changes in this version type Block + func (b *Block) ValidateCommit() error type Header + Extra []byte v1.3.4 Sep 2, 2019 Changes in this version + const AdminOpChangeValidator + const EventDataTypeFork + const EventDataTypeHookCommit + const EventDataTypeHookExecute + const EventDataTypeHookNewRound + const EventDataTypeHookPrecommit + const EventDataTypeHookPrevote + const EventDataTypeHookPropose + const EventDataTypeNewBlock + const EventDataTypeNewBlockHeader + const EventDataTypeRoundState + const EventDataTypeSwitchToConsensus + const EventDataTypeTx + const EventDataTypeVote + const MaxBlockSize + const PRIV_FILE_NAME + const QueryTx + const QueryTxExecution + const ResultTypeBlock + const ResultTypeBlockchainInfo + const ResultTypeBroadcastTx + const ResultTypeBroadcastTxCommit + const ResultTypeCoreVersion + const ResultTypeDialSeeds + const ResultTypeDumpConsensusState + const ResultTypeEvent + const ResultTypeGenesis + const ResultTypeHealthInfo + const ResultTypeInfo + const ResultTypeLastHeight + const ResultTypeNetInfo + const ResultTypeNumArchivedBlocks + const ResultTypeNumLimitTx + const ResultTypeQuery + const ResultTypeRefuseList + const ResultTypeRequestAdminOP + const ResultTypeShards + const ResultTypeStatus + const ResultTypeSubscribe + const ResultTypeSurveillance + const ResultTypeUnconfirmedTxs + const ResultTypeUnsafeFlushMempool + const ResultTypeUnsafeSetConfig + const ResultTypeUnsafeStartCPUProfiler + const ResultTypeUnsafeStopCPUProfiler + const ResultTypeUnsafeWriteHeapProfile + const ResultTypeUnsubscribe + const ResultTypeValidators + const VoteTypePrecommit + const VoteTypePrevote + var AdminTag = []byte("zaop") + var CodeType_name = map[int32]string + var CodeType_value = map[string]int32 + var ErrBranchIsUsed = errors.New("priv_validator:branch name is used") + var ErrFileNotFound = errors.New("priv_validator.json not found") + var ErrInvalidBlockPartHash = errors.New("Error invalid block part hash") + var ErrInvalidBlockPartSignature = errors.New("Error invalid block part signature") + var ErrPVRevertFromBackup = errors.New("priv_validator:revert from backup, not find data") + 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 round vote signature") + var ErrVoteInvalidValidatorAddress = errors.New("Invalid round vote validator address") + var ErrVoteInvalidValidatorIndex = errors.New("Invalid round vote validator index") + var ErrVoteUnexpectedStep = errors.New("Unexpected step") + var GenDocKey = []byte("GenDocKey") + var PeerMempoolChKey = "MempoolReactor.peerMempoolCh" + var PeerStateKey = "ConsensusReactor.peerState" + var ValidatorCodec = validatorCodec + func AddListenerForEvent(evsw EventSwitch, id, event string, cb func(data TMEventData)) + func Byte64Tobyte(bytes64 [64]byte) (bytes []byte) + func BytesToByte64(bytes []byte) (b64 [64]byte) + func EventStringBond() string + func EventStringCompleteProposal() string + func EventStringDupeout() string + func EventStringFork() string + func EventStringHookCommit() string + func EventStringHookExecute() string + func EventStringHookNewRound() string + func EventStringHookPrecommit() string + func EventStringHookPrevote() string + func EventStringHookPropose() string + func EventStringLock() string + func EventStringNewBlock() string + func EventStringNewBlockHeader() string + func EventStringNewRound() string + func EventStringNewRoundStep() string + func EventStringPolka() string + func EventStringRebond() string + func EventStringRelock() string + func EventStringSwitchToConsensus() string + func EventStringTimeoutPropose() string + func EventStringTimeoutWait() string + func EventStringTx(tx Tx) string + func EventStringUnbond() string + func EventStringUnlock() string + func EventStringVote() string + func FireEventCompleteProposal(fireable events.Fireable, rs EventDataRoundState) + func FireEventHookCommit(fireable events.Fireable, d EventDataHookCommit) + func FireEventHookExecute(fireable events.Fireable, d EventDataHookExecute) + func FireEventHookNewRound(fireable events.Fireable, d EventDataHookNewRound) + func FireEventHookPrecommit(fireable events.Fireable, d EventDataHookPrecommit) + func FireEventHookPrevote(fireable events.Fireable, d EventDataHookPrevote) + func FireEventHookPropose(fireable events.Fireable, d EventDataHookPropose) + func FireEventLock(fireable events.Fireable, rs EventDataRoundState) + func FireEventNewBlock(fireable events.Fireable, block EventDataNewBlock) + func FireEventNewBlockHeader(fireable events.Fireable, header EventDataNewBlockHeader) + func FireEventNewRound(fireable events.Fireable, rs EventDataRoundState) + func FireEventNewRoundStep(fireable events.Fireable, rs EventDataRoundState) + func FireEventPolka(fireable events.Fireable, rs EventDataRoundState) + func FireEventRelock(fireable events.Fireable, rs EventDataRoundState) + func FireEventSwitchToConsensus(fireable events.Fireable) + func FireEventTimeoutPropose(fireable events.Fireable, rs EventDataRoundState) + func FireEventTimeoutWait(fireable events.Fireable, rs EventDataRoundState) + func FireEventTx(fireable events.Fireable, tx EventDataTx) + func FireEventUnlock(fireable events.Fireable, rs EventDataRoundState) + func FireEventVote(fireable events.Fireable, vote EventDataVote) + func GenTxsForTest(numtx, numExTx int) ([]Tx, []Tx) + func HashSignBytes(chainID string, o Signable) []byte + func IsAdminOP(tx []byte) bool + func IsVoteTypeValid(type_ byte) bool + func MakeBlock(height int64, chainID string, txs []Tx, extxs []Tx, commit *Commit, ...) (*Block, *PartSet) + func PrivKeyByteToByte64(bytes []byte) (byte64 [64]byte) + func RandValidator(randPower bool, minPower int64) (*Validator, *PrivValidator) + func RandValidatorSet(numValidators int, votingPower int64) (*ValidatorSet, []*PrivValidator) + func SignBytes(chainID string, o Signable) []byte + func SignCA(priv crypto.PrivKey, pubbytes []byte) string + func StrToSmallStr(str string) (smallstr string) + func StringTo32byte(key string) ([32]byte, error) + func StringTo64byte(key string) ([64]byte, error) + func StringToAnybyte(key string) ([]byte, error) + func Substr(str string, start int, length int) string + func TagAdminOPTx(tx []byte) []byte + func TxsLenForTest() int + func TxsNumForTest() int + func UnwrapTx(tx []byte) []byte + func WrapTx(prefix []byte, tx []byte) []byte + type AdminOPCmd struct + CmdType string + Msg []byte + Nonce uint64 + SInfos []SigInfo + SelfSign []byte + Time time.Time + func (cmd *AdminOPCmd) ExtractMsg(o interface{}) (interface{}, error) + func (cmd *AdminOPCmd) LoadMsg(o interface{}) error + type AdminVoteResult struct + PubKey []byte + Result []byte + Signature []byte + type Application interface + CheckTx func([]byte) error + CompatibleWithAngine func() + GetAngineHooks func() Hooks + Info func() ResultInfo + Query func([]byte) Result + SetCore func(Core) + Start func() error + Stop func() + type BaseApplication struct + Database db.DB + InitializedState bool + func (ba *BaseApplication) InitBaseApplication(name string, datadir string) (err error) + func (ba *BaseApplication) Initialized() bool + func (ba *BaseApplication) LoadLastBlock(t interface{}) (res interface{}, err error) + func (ba *BaseApplication) SaveLastBlock(lastBlock interface{}) + func (ba *BaseApplication) SaveLastBlockByKey(key []byte, lastBlock interface{}) + func (ba *BaseApplication) Stop() + type Block struct + LastCommit *Commit + func GenBlockForTest(height int64, ntxs, nexTxs int) *Block + func GenBlocksForTest(num int) []*Block + func (b *Block) FillHeader() + func (b *Block) Hash() []byte + 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) TxsIsNil() bool + func (b *Block) ValidateBasic(chainID string, lastBlockHeight int64, lastBlockID BlockID, ...) error + type BlockID struct + Hash []byte + PartsHeader PartSetHeader + func GenBlockID() BlockID + func (blockID BlockID) Equals(other BlockID) bool + func (blockID BlockID) IsZero() bool + func (blockID BlockID) Key() string + func (blockID BlockID) String() string + func (blockID BlockID) WriteSignBytes(w io.Writer, n *int, err *error) + type BlockMeta struct + Hash []byte + Header *Header + PartsHeader PartSetHeader + func NewBlockMeta(block *Block, blockParts *PartSet) *BlockMeta + type CanonicalJSONBlockID struct + Hash []byte + PartsHeader CanonicalJSONPartSetHeader + func CanonicalBlockID(blockID BlockID) CanonicalJSONBlockID + type CanonicalJSONOnceProposal struct + ChainID string + Proposal CanonicalJSONProposal + type CanonicalJSONOnceVote struct + ChainID string + Vote CanonicalJSONVote + type CanonicalJSONPartSetHeader struct + Hash []byte + Total int + func CanonicalPartSetHeader(psh PartSetHeader) CanonicalJSONPartSetHeader + type CanonicalJSONProposal struct + BlockPartsHeader CanonicalJSONPartSetHeader + Height int64 + POLBlockID CanonicalJSONBlockID + POLRound int64 + Round int64 + func CanonicalProposal(proposal *Proposal) CanonicalJSONProposal + type CanonicalJSONVote struct + BlockID CanonicalJSONBlockID + Height int64 + Round int64 + Type byte + func CanonicalVote(vote *Vote) CanonicalJSONVote + type CmdType string + type CodeType int32 + const CodeType_BadNonce + const CodeType_BaseDuplicateAddress + const CodeType_BaseEncodingError + const CodeType_BaseInsufficientFees + const CodeType_BaseInsufficientFunds + const CodeType_BaseInsufficientGasPrice + const CodeType_BaseInvalidInput + const CodeType_BaseInvalidOutput + const CodeType_BaseInvalidPubKey + const CodeType_BaseInvalidSequence + const CodeType_BaseInvalidSignature + const CodeType_BaseUnknownAddress + const CodeType_BaseUnknownPlugin + const CodeType_BaseUnknownPubKey + const CodeType_EncodingError + const CodeType_GovDuplicateGroup + const CodeType_GovDuplicateMember + const CodeType_GovDuplicateProposal + const CodeType_GovDuplicateVote + const CodeType_GovInvalidMember + const CodeType_GovInvalidVote + const CodeType_GovInvalidVotingPower + const CodeType_GovUnknownEntity + const CodeType_GovUnknownGroup + const CodeType_GovUnknownProposal + const CodeType_InsufficientFunds + const CodeType_InternalError + const CodeType_InvalidTx + const CodeType_OK + const CodeType_SaveFailed + const CodeType_Unauthorized + const CodeType_UnknownRequest + const CodeType_WrongRLP + func (x CodeType) String() string + type Commit struct + BlockID BlockID + Precommits []*Vote + func GenCommitForTest(height int64, chainID string) *Commit + func (commit *Commit) BitArray() *gcmn.BitArray + func (commit *Commit) FirstPrecommit() *Vote + func (commit *Commit) GetByIndex(index int) *Vote + func (commit *Commit) Hash() []byte + func (commit *Commit) Height() int64 + func (commit *Commit) IsCommit() bool + func (commit *Commit) Round() int64 + func (commit *Commit) Size() int + func (commit *Commit) StringIndented(indent string) string + func (commit *Commit) Type() byte + func (commit *Commit) ValidateBasic() error + type CommitResult struct + AppHash []byte + ReceiptsHash []byte + type Core interface + GetBlockMeta func(height int64) (*BlockMeta, error) + Query func(byte, []byte) (interface{}, error) + type Data struct + ExTxs Txs + Txs Txs + func (data *Data) Hash() []byte + func (data *Data) StringIndented(indent string) string + type DefaultSigner struct + func NewDefaultSigner(priv crypto.PrivKey) *DefaultSigner + func (ds *DefaultSigner) Sign(msg []byte) crypto.Signature + type ErrVoteConflictingVotes struct + VoteA *Vote + VoteB *Vote + func (err *ErrVoteConflictingVotes) Error() string + type EventCache interface + Flush func() + func NewEventCache(evsw EventSwitch) EventCache + type EventDataHookCommit struct + Block *Block + Height int64 + ResCh chan CommitResult + Round int64 + func NewEventDataHookCommit(height, round int64, block *Block) EventDataHookCommit + func (_ EventDataHookCommit) AssertIsTMEventData() + type EventDataHookExecute struct + Block *Block + Height int64 + ResCh chan ExecuteResult + Round int64 + func NewEventDataHookExecute(height, round int64, block *Block) EventDataHookExecute + func (_ EventDataHookExecute) AssertIsTMEventData() + type EventDataHookNewRound struct + Height int64 + ResCh chan NewRoundResult + Round int64 + func NewEventDataHookNewRound(height, round int64) EventDataHookNewRound + func (_ EventDataHookNewRound) AssertIsTMEventData() + type EventDataHookPrecommit struct + Block *Block + Height int64 + Round int64 + func (_ EventDataHookPrecommit) AssertIsTMEventData() + type EventDataHookPrevote struct + Block *Block + Height int64 + Round int64 + func (_ EventDataHookPrevote) AssertIsTMEventData() + type EventDataHookPropose struct + Block *Block + Height int64 + Round int64 + func (_ EventDataHookPropose) AssertIsTMEventData() + type EventDataNewBlock struct + Block *Block + func (_ EventDataNewBlock) AssertIsTMEventData() + type EventDataNewBlockHeader struct + Header *Header + func (_ EventDataNewBlockHeader) AssertIsTMEventData() + type EventDataRoundState struct + Height int64 + Round int64 + RoundState interface{} + Step string + func (_ EventDataRoundState) AssertIsTMEventData() + type EventDataSwitchToConsensus struct + State interface{} + func (_ EventDataSwitchToConsensus) AssertIsTMEventData() + type EventDataTx struct + Code CodeType + Data []byte + Error string + Log string + Tx Tx + func (_ EventDataTx) AssertIsTMEventData() + type EventDataVote struct + Vote *Vote + func (_ EventDataVote) AssertIsTMEventData() + type EventSwitch interface + func NewEventSwitch() EventSwitch + type Eventable interface + SetEventSwitch func(EventSwitch) + type ExecuteInvalidTx struct + Bytes []byte + Error error + type ExecuteResult struct + Error error + InvalidTxs []ExecuteInvalidTx + ValidTxs Txs + type Fireable interface + type GenesisDoc struct + AppHash []byte + ChainID string + GenesisTime time.Time + Plugins string + Validators []GenesisValidator + func GenesisDocFromJSON(jsonBlob []byte) *GenesisDoc + func GenesisDocFromJSONRet(jsonBlob []byte) (genState *GenesisDoc, err error) + func (genDoc *GenesisDoc) JSONBytes() []byte + func (genDoc *GenesisDoc) SaveAs(file string) error + type GenesisValidator struct + Amount int64 + IsCA bool + Name string + PubKey crypto.PubKey + RPCAddress string + func (gv *GenesisValidator) UnmarshalJSON(b []byte) error + type GenesisValidatorJson struct + Amount int64 + IsCA bool + Name string + PubKey []byte + RPCAddress string + type Header struct + AppHash []byte + ChainID string + DataHash []byte + Height int64 + LastBlockID BlockID + LastCommitHash []byte + NumTxs int64 + ProposerAddress []byte + ReceiptsHash []byte + Time time.Time + ValidatorsHash []byte + func (h *Header) Hash() []byte + func (h *Header) StringIndented(indent string) string + type Hook struct + func NewHook(cb func(int64, int64, *Block) (interface{}, error)) *Hook + func (h *Hook) Async(height, round int64, block *Block, cb func(interface{}), onError func(error)) + func (h *Hook) Error() error + func (h *Hook) Result() interface{} + func (h *Hook) Sync(height, round int64, block *Block) (interface{}, error) + type Hooker interface + Async func(int, int, *Block) + Result func() interface{} + Sync func(int, int, *Block) (interface{}, error) + type Hooks struct + OnCommit *Hook + OnExecute *Hook + OnNewRound *Hook + OnPrecommit *Hook + OnPrevote *Hook + OnPropose *Hook + type IFilter interface + CheckTx func(Tx) (bool, error) + type IMempool interface + Lock func() + Unlock func() + Update func(height int64, txs []Tx) + type NewRoundResult struct + type Part struct + Bytes []byte + Index int + Proof merkle.SimpleProof + func (part *Part) Hash() []byte + func (part *Part) String() string + func (part *Part) StringIndented(indent string) string + type PartSet struct + func NewPartSetFromData(data []byte, partSize int) *PartSet + func NewPartSetFromHeader(header PartSetHeader) *PartSet + func (ps *PartSet) AddPart(part *Part, verify bool) (bool, error) + func (ps *PartSet) BitArray() *gcmn.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) StringShort() string + func (ps *PartSet) Total() int + type PartSetHeader struct + Hash []byte + Total int + func (psh PartSetHeader) Equals(other PartSetHeader) bool + func (psh PartSetHeader) IsZero() bool + func (psh PartSetHeader) String() string + func (psh PartSetHeader) WriteSignBytes(w io.Writer, n *int, err *error) + type PartSetReader struct + func NewPartSetReader(parts []*Part) *PartSetReader + func (psr *PartSetReader) Read(p []byte) (n int, err error) + type Peer struct + ConnectionStatus p2p.ConnectionStatus + IsOutbound bool + type PrivValidator struct + Address []byte + LastHeight int64 + LastRound int64 + LastSignBytes []byte + LastSignature crypto.Signature + LastStep int8 + PrivKey crypto.PrivKey + PubKey crypto.PubKey + func GenPrivValidator(cryptoType string, privkey crypto.PrivKey) (*PrivValidator, error) + func LoadOrGenPrivValidator(filePath string) *PrivValidator + func LoadPrivValidator(filePath string) (*PrivValidator, error) + func (privVal *PrivValidator) GetAddress() []byte + func (privVal *PrivValidator) GetPrivateKey() crypto.PrivKey + func (privVal *PrivValidator) Reset() + func (privVal *PrivValidator) Save() error + func (privVal *PrivValidator) SetFile(filePath string) + func (privVal *PrivValidator) SetSigner(s Signer) + func (privVal *PrivValidator) SignProposal(chainID string, proposal *Proposal) error + func (privVal *PrivValidator) SignVote(chainID string, vote *Vote) error + func (privVal *PrivValidator) String() string + func (pv *PrivValidator) CopyReset() (cp PrivValidator) + func (pv *PrivValidator) GetLastSignature() crypto.Signature + func (pv *PrivValidator) GetPrivKey() crypto.PrivKey + func (pv *PrivValidator) GetPubKey() crypto.PubKey + func (pv *PrivValidator) UnmarshalJSON(data []byte) error + type PrivValidatorTool struct + func (pt *PrivValidatorTool) BackupData(branchName string) error + func (pt *PrivValidatorTool) DelBackup(branchName string) + func (pt *PrivValidatorTool) Init(dir string) error + func (pt *PrivValidatorTool) RevertFromBackup(branchName string) error + func (pt *PrivValidatorTool) SaveNewPrivV(toHeight int64) 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 + BlockPartsHeader PartSetHeader + Height int64 + POLBlockID BlockID + POLRound int64 + Round int64 + Signature crypto.Signature + func NewProposal(height int64, round int64, blockPartsHeader PartSetHeader, polRound int64, ...) *Proposal + func (p *Proposal) String() string + func (p *Proposal) WriteSignBytes(chainID string, w io.Writer, n *int, err *error) + type RPCResult interface + type Result struct + Code CodeType + Data []byte + Log string + func NewError(code CodeType, log string) Result + func NewResult(code CodeType, data []byte, log string) Result + func NewResultOK(data []byte, log string) Result + func (res Result) AppendLog(log string) Result + func (res Result) Error() string + func (res Result) IsErr() bool + func (res Result) IsOK() bool + func (res Result) PrependLog(log string) Result + func (res Result) SetData(data []byte) Result + func (res Result) SetLog(log string) Result + func (res Result) String() string + type ResultBlock struct + Block *Block + BlockMeta *BlockMeta + type ResultBlockchainInfo struct + BlockMetas []*BlockMeta + LastHeight int64 + type ResultBroadcastTx struct + Code CodeType + Data []byte + Log string + TxHash string + type ResultBroadcastTxCommit struct + Code CodeType + Data []byte + Log string + TxHash string + type ResultCoreVersion struct + AppName string + AppVersion string + Hash string + Version string + type ResultDialSeeds struct + type ResultDumpConsensusState struct + PeerRoundStates []string + RoundState string + type ResultEvent struct + Data TMEventData + Name string + type ResultGenesis struct + Genesis *GenesisDoc + type ResultHealthInfo struct + Status int + type ResultInfo struct + Data string + LastBlockAppHash []byte + LastBlockHeight int64 + Version string + type ResultLastHeight struct + LastHeight int64 + type ResultNetInfo struct + Listeners []string + Listening bool + Peers []*Peer + type ResultNumArchivedBlocks struct + Num int64 + type ResultNumLimitTx struct + Num uint64 + type ResultQuery struct + Result Result + type ResultRefuseList struct + Result []string + type ResultRequestAdminOP struct + Code CodeType + Data []byte + Log string + type ResultShards struct + Names []string + type ResultStatus struct + LatestAppHash []byte + LatestBlockHash []byte + LatestBlockHeight int64 + LatestBlockTime int64 + NodeInfo *p2p.NodeInfo + PubKey crypto.PubKey + type ResultSubscribe struct + type ResultSurveillance struct + Addr string + Height int64 + IsValidator bool + NanoSecsPerTx time.Duration + NumPeers int + NumValidators int + PubKey string + RunningTime time.Duration + type ResultTransaction struct + BlockHash []byte + BlockHeight uint64 + RawTransaction []byte + Timestamp uint64 + TransactionIndex uint64 + type ResultUnconfirmedTxs struct + N int + Txs []Tx + type ResultUnsafeFlushMempool struct + type ResultUnsafeProfile struct + type ResultUnsafeSetConfig struct + type ResultUnsubscribe struct + type ResultValidator struct + Accum int64 + Address []byte + IsCA bool + PubKey string + VotingPower int64 + func MakeResultValidators(vs []*Validator) []*ResultValidator + type ResultValidators struct + BlockHeight int64 + Validators []*ResultValidator + type SigInfo struct + PubKey []byte + Signature []byte + type Signable interface + WriteSignBytes func(chainID string, w io.Writer, n *int, err *error) + type Signer interface + Sign func(msg []byte) crypto.Signature + type TMEventData interface + AssertIsTMEventData func() + type Tx []byte + func (tx Tx) Hash() []byte + func (tx Tx) Size() int + type TxExecutionResult struct + BlockHash []byte + Height uint64 + Index uint64 + func (i *TxExecutionResult) FromBytes(data []byte) error + func (i *TxExecutionResult) ToBytes() ([]byte, error) + type TxInPool struct + Counter int64 + Height int64 + Tx Tx + func (memTx *TxInPool) GetHeight() int64 + type TxPool interface + Flush func() + Lock func() + Reap func(count int) []Tx + ReceiveTx func(tx Tx) error + RegisterFilter func(filter IFilter) + Size func() int + TxsFrontWait func() *clist.CElement + Unlock func() + Update func(height int64, txs []Tx) + type TxPoolApplication interface + GetTxPool func() TxPool + type TxpoolFilter struct + func NewTxpoolFilter(f func([]byte) (bool, error)) TxpoolFilter + func (m TxpoolFilter) CheckTx(tx Tx) (bool, error) + type Txs []Tx + func (txs Txs) Hash() []byte + func (txs Txs) ToBytes() [][]byte + type Validator struct + Accum int64 + Address []byte + IsCA bool + PubKey crypto.PubKey + VotingPower int64 + func NewValidator(pubKey crypto.PubKey, votingPower int64, isCA bool) *Validator + func (v *Validator) CompareAccum(other *Validator) *Validator + func (v *Validator) Copy() *Validator + func (v *Validator) Hash() []byte + func (v *Validator) String() string + type ValidatorAttr struct + Addr []byte + Cmd ValidatorCmd + Nonce uint64 + Power int64 + PubKey []byte + func (m *ValidatorAttr) GetIsCA() bool + func (m *ValidatorAttr) GetPower() int64 + func (m *ValidatorAttr) GetPubKey() []byte + func (m *ValidatorAttr) Reset() + func (m *ValidatorAttr) String() string + type ValidatorCmd string + const ValidatorCmdAddPeer + const ValidatorCmdRemoveNode + const ValidatorCmdUpdateNode + type ValidatorSet struct + Validators []*Validator + func NewValidatorSet(vals []*Validator) *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) HasAddress(address []byte) bool + func (valSet *ValidatorSet) Hash() []byte + func (valSet *ValidatorSet) IncrementAccum(times int64) + func (valSet *ValidatorSet) Iterate(fn func(index int, val *Validator) bool) + func (valSet *ValidatorSet) Proposer() (proposer *Validator) + 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 + type ValidatorsByAddress []*Validator + func (vs ValidatorsByAddress) Len() int + func (vs ValidatorsByAddress) Less(i, j int) bool + func (vs ValidatorsByAddress) Swap(i, j int) + type Vote struct + BlockID BlockID + Height int64 + Round int64 + Signature crypto.Signature + Type byte + ValidatorAddress []byte + ValidatorIndex int + func (vote *Vote) Copy() *Vote + func (vote *Vote) String() string + func (vote *Vote) WriteSignBytes(chainID string, w io.Writer, n *int, err *error) + type VoteSet struct + func NewVoteSet(chainID string, height int64, round int64, type_ byte, valSet *ValidatorSet) *VoteSet + func (voteSet *VoteSet) AddVote(vote *Vote) (added bool, err error) + func (voteSet *VoteSet) BitArray() *gcmn.BitArray + func (voteSet *VoteSet) BitArrayByBlockID(blockID BlockID) *gcmn.BitArray + 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) Round() int64 + func (voteSet *VoteSet) SetPeerMaj23(peerID string, blockID BlockID) + 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 + type VoteSetReader interface + BitArray func() *gcmn.BitArray + GetByIndex func(int) *Vote + Height func() int64 + IsCommit func() bool + Round func() int64 + Size func() int + Type func() byte