Versions in this module Expand all Collapse all v1 v1.999.0 Nov 17, 2022 Changes in this version + func NewOneShardCoordinatorMock() *oneShardCoordinatorMock + type AccountsDBSyncerStub struct + GetSyncedTriesCalled func() map[string]common.Trie + SyncAccountsCalled func(rootHash []byte) error + func (a *AccountsDBSyncerStub) GetSyncedTries() map[string]common.Trie + func (a *AccountsDBSyncerStub) IsInterfaceNil() bool + func (a *AccountsDBSyncerStub) SyncAccounts(rootHash []byte) error + type AccountsDBSyncersStub struct + AddCalled func(key string, val update.AccountsDBSyncer) error + AddMultipleCalled func(keys []string, interceptors []update.AccountsDBSyncer) error + GetCalled func(key string) (update.AccountsDBSyncer, error) + LenCalled func() int + RemoveCalled func(key string) + ReplaceCalled func(key string, val update.AccountsDBSyncer) error + StartSyncingCalled func(rootHash []byte) error + TrieCalled func() common.Trie + func (a *AccountsDBSyncersStub) Add(key string, val update.AccountsDBSyncer) error + func (a *AccountsDBSyncersStub) AddMultiple(keys []string, interceptors []update.AccountsDBSyncer) error + func (a *AccountsDBSyncersStub) Get(key string) (update.AccountsDBSyncer, error) + func (a *AccountsDBSyncersStub) IsInterfaceNil() bool + func (a *AccountsDBSyncersStub) Len() int + func (a *AccountsDBSyncersStub) Remove(key string) + func (a *AccountsDBSyncersStub) Replace(key string, val update.AccountsDBSyncer) error + type AddressMock struct + func NewAddressMock() *AddressMock + func (address *AddressMock) Bytes() []byte + func (address *AddressMock) IsInterfaceNil() bool + type ChainStorerMock struct + AddStorerCalled func(key dataRetriever.UnitType, s storage.Storer) + DestroyCalled func() error + GetAllCalled func(unitType dataRetriever.UnitType, keys [][]byte) (map[string][]byte, error) + GetAllStorersCalled func() map[dataRetriever.UnitType]storage.Storer + GetCalled func(unitType dataRetriever.UnitType, key []byte) ([]byte, error) + GetStorerCalled func(unitType dataRetriever.UnitType) storage.Storer + HasCalled func(unitType dataRetriever.UnitType, key []byte) error + PutCalled func(unitType dataRetriever.UnitType, key []byte, value []byte) error + func (bc *ChainStorerMock) AddStorer(key dataRetriever.UnitType, s storage.Storer) + func (bc *ChainStorerMock) CloseAll() error + func (bc *ChainStorerMock) Destroy() error + func (bc *ChainStorerMock) Get(unitType dataRetriever.UnitType, key []byte) ([]byte, error) + func (bc *ChainStorerMock) GetAll(unitType dataRetriever.UnitType, keys [][]byte) (map[string][]byte, error) + func (bc *ChainStorerMock) GetAllStorers() map[dataRetriever.UnitType]storage.Storer + func (bc *ChainStorerMock) GetStorer(unitType dataRetriever.UnitType) storage.Storer + func (bc *ChainStorerMock) Has(unitType dataRetriever.UnitType, key []byte) error + func (bc *ChainStorerMock) IsInterfaceNil() bool + func (bc *ChainStorerMock) Put(unitType dataRetriever.UnitType, key []byte, value []byte) error + func (bc *ChainStorerMock) SetEpochForPutOperation(_ uint32) + type CloserStub struct + CloseCalled func() error + func (cs *CloserStub) Close() error + func (cs *CloserStub) IsInterfaceNil() bool + type CoordinatorStub struct + CommunicationIdentifierCalled func(destShardID uint32) string + ComputeIdCalled func(address []byte) uint32 + NumberOfShardsCalled func() uint32 + SameShardCalled func(firstAddress, secondAddress []byte) bool + SelfIdCalled func() uint32 + func (coordinator *CoordinatorStub) CommunicationIdentifier(destShardID uint32) string + func (coordinator *CoordinatorStub) ComputeId(address []byte) uint32 + func (coordinator *CoordinatorStub) IsInterfaceNil() bool + func (coordinator *CoordinatorStub) NumberOfShards() uint32 + func (coordinator *CoordinatorStub) SameShard(firstAddress, secondAddress []byte) bool + func (coordinator *CoordinatorStub) SelfId() uint32 + type EpochHandlerStub struct + ForceEpochStartCalled func(round uint64) + MetaEpochCalled func() uint32 + func (ehs *EpochHandlerStub) ForceEpochStart(round uint64) + func (ehs *EpochHandlerStub) IsInterfaceNil() bool + func (ehs *EpochHandlerStub) MetaEpoch() uint32 + type EpochStartNotifierStub struct + NotifyAllCalled func(hdr data.HeaderHandler) + NotifyAllPrepareCalled func(hdr data.HeaderHandler, body data.BodyHandler) + NotifyEpochChangeConfirmedCalled func(epoch uint32) + RegisterForEpochChangeConfirmedCalled func(handler func(epoch uint32)) + RegisterHandlerCalled func(handler epochStart.ActionHandler) + UnregisterHandlerCalled func(handler epochStart.ActionHandler) + func (esnm *EpochStartNotifierStub) IsInterfaceNil() bool + func (esnm *EpochStartNotifierStub) NotifyAll(hdr data.HeaderHandler) + func (esnm *EpochStartNotifierStub) NotifyAllPrepare(metaHdr data.HeaderHandler, body data.BodyHandler) + func (esnm *EpochStartNotifierStub) NotifyEpochChangeConfirmed(epoch uint32) + func (esnm *EpochStartNotifierStub) RegisterForEpochChangeConfirmed(handler func(epoch uint32)) + func (esnm *EpochStartNotifierStub) RegisterHandler(handler epochStart.ActionHandler) + func (esnm *EpochStartNotifierStub) UnregisterHandler(handler epochStart.ActionHandler) + type EpochStartPendingMiniBlocksSyncHandlerMock struct + GetMiniBlocksCalled func() (map[string]*block.MiniBlock, error) + SyncPendingMiniBlocksFromMetaCalled func(epochStart data.MetaHeaderHandler, ...) error + func (ep *EpochStartPendingMiniBlocksSyncHandlerMock) GetMiniBlocks() (map[string]*block.MiniBlock, error) + func (ep *EpochStartPendingMiniBlocksSyncHandlerMock) IsInterfaceNil() bool + func (ep *EpochStartPendingMiniBlocksSyncHandlerMock) SyncPendingMiniBlocksFromMeta(epochStart data.MetaHeaderHandler, ...) error + type EpochStartTriesSyncHandlerMock struct + GetTriesCalled func() (map[string]common.Trie, error) + SyncTriesFromCalled func(meta data.MetaHeaderHandler) error + func (es *EpochStartTriesSyncHandlerMock) GetTries() (map[string]common.Trie, error) + func (es *EpochStartTriesSyncHandlerMock) IsInterfaceNil() bool + func (es *EpochStartTriesSyncHandlerMock) SyncTriesFrom(meta data.MetaHeaderHandler) error + type EpochStartTriggerStub struct + EpochCalled func() uint32 + EpochStartMetaHdrHashCalled func() []byte + EpochStartRoundCalled func() uint64 + ForceEpochStartCalled func(round uint64) error + IsEpochStartCalled func() bool + ProcessedCalled func(header data.HeaderHandler) + ReceivedHeaderCalled func(handler data.HeaderHandler) + UpdateCalled func(round uint64) + func (e *EpochStartTriggerStub) Epoch() uint32 + func (e *EpochStartTriggerStub) EpochFinalityAttestingRound() uint64 + func (e *EpochStartTriggerStub) EpochStartMetaHdrHash() []byte + func (e *EpochStartTriggerStub) EpochStartRound() uint64 + func (e *EpochStartTriggerStub) ForceEpochStart(round uint64) error + func (e *EpochStartTriggerStub) GetRoundsPerEpoch() uint64 + func (e *EpochStartTriggerStub) IsEpochStart() bool + func (e *EpochStartTriggerStub) IsInterfaceNil() bool + func (e *EpochStartTriggerStub) NotifyAll(_ data.HeaderHandler) + func (e *EpochStartTriggerStub) ReceivedHeader(header data.HeaderHandler) + func (e *EpochStartTriggerStub) Revert() + func (e *EpochStartTriggerStub) SetCurrentEpochStartRound(_ uint64) + func (e *EpochStartTriggerStub) SetEpoch(_ uint32) + func (e *EpochStartTriggerStub) SetFinalityAttestingRound(_ uint64) + func (e *EpochStartTriggerStub) SetProcessed(header data.HeaderHandler) + func (e *EpochStartTriggerStub) SetRoundsPerEpoch(_ uint64) + func (e *EpochStartTriggerStub) SetTrigger(_ epochStart.TriggerHandler) + func (e *EpochStartTriggerStub) Update(round uint64) + type ExportFactoryHandlerStub struct + CreateCalled func() (update.ExportHandler, error) + func (e *ExportFactoryHandlerStub) Create() (update.ExportHandler, error) + func (e *ExportFactoryHandlerStub) IsInterfaceNil() bool + type ExportHandlerStub struct + ExportAllCalled func(epoch uint32) error + func (e *ExportHandlerStub) ExportAll(epoch uint32) error + func (e *ExportHandlerStub) IsInterfaceNil() bool + type GenesisNodesSetupHandlerStub struct + GetAdaptivityCalled func() bool + GetChainIdCalled func() string + GetHysteresisCalled func() float32 + GetMetaConsensusGroupSizeCalled func() uint32 + GetMinTransactionVersionCalled func() uint32 + GetRoundDurationCalled func() uint64 + GetShardConsensusGroupSizeCalled func() uint32 + GetStartTimeCalled func() int64 + InitialNodesInfoCalled func() (map[uint32][]nodesCoordinator.GenesisNodeInfoHandler, ...) + InitialNodesInfoForShardCalled func(shardId uint32) ([]nodesCoordinator.GenesisNodeInfoHandler, ...) + MinNumberOfMetaNodesCalled func() uint32 + MinNumberOfNodesCalled func() uint32 + MinNumberOfShardNodesCalled func() uint32 + NumberOfShardsCalled func() uint32 + func (g *GenesisNodesSetupHandlerStub) GetAdaptivity() bool + func (g *GenesisNodesSetupHandlerStub) GetChainId() string + func (g *GenesisNodesSetupHandlerStub) GetHysteresis() float32 + func (g *GenesisNodesSetupHandlerStub) GetMetaConsensusGroupSize() uint32 + func (g *GenesisNodesSetupHandlerStub) GetMinTransactionVersion() uint32 + func (g *GenesisNodesSetupHandlerStub) GetRoundDuration() uint64 + func (g *GenesisNodesSetupHandlerStub) GetShardConsensusGroupSize() uint32 + func (g *GenesisNodesSetupHandlerStub) GetStartTime() int64 + func (g *GenesisNodesSetupHandlerStub) InitialNodesInfo() (map[uint32][]nodesCoordinator.GenesisNodeInfoHandler, ...) + func (g *GenesisNodesSetupHandlerStub) InitialNodesInfoForShard(shardId uint32) ([]nodesCoordinator.GenesisNodeInfoHandler, ...) + func (g *GenesisNodesSetupHandlerStub) IsInterfaceNil() bool + func (g *GenesisNodesSetupHandlerStub) MinNumberOfMetaNodes() uint32 + func (g *GenesisNodesSetupHandlerStub) MinNumberOfNodes() uint32 + func (g *GenesisNodesSetupHandlerStub) MinNumberOfShardNodes() uint32 + func (g *GenesisNodesSetupHandlerStub) NumberOfShards() uint32 + type HardForkBlockProcessor struct + CreateBlockCalled func(body *block.Body, chainID string, round uint64, nonce uint64, epoch uint32) (data.HeaderHandler, error) + CreateBodyCalled func() (*block.Body, []*update.MbInfo, error) + CreatePostMiniBlocksCalled func(mbsInfo []*update.MbInfo) (*block.Body, []*update.MbInfo, error) + func (hfbp *HardForkBlockProcessor) CreateBlock(body *block.Body, chainID string, round uint64, nonce uint64, epoch uint32) (data.HeaderHandler, error) + func (hfbp *HardForkBlockProcessor) CreateBody() (*block.Body, []*update.MbInfo, error) + func (hfbp *HardForkBlockProcessor) CreatePostMiniBlocks(mbsInfo []*update.MbInfo) (*block.Body, []*update.MbInfo, error) + func (hfbp *HardForkBlockProcessor) IsInterfaceNil() bool + type HardforkStorerStub struct + CloseCalled func() error + FinishedIdentifierCalled func(identifier string) error + GetCalled func(identifier string, key []byte) ([]byte, error) + RangeKeysCalled func(handler func(identifier string, keys [][]byte) bool) + WriteCalled func(identifier string, key []byte, value []byte) error + func (hss *HardforkStorerStub) Close() error + func (hss *HardforkStorerStub) FinishedIdentifier(identifier string) error + func (hss *HardforkStorerStub) Get(identifier string, key []byte) ([]byte, error) + func (hss *HardforkStorerStub) IsInterfaceNil() bool + func (hss *HardforkStorerStub) RangeKeys(handler func(identifier string, keys [][]byte) bool) + func (hss *HardforkStorerStub) Write(identifier string, key []byte, value []byte) error + type HasherStub struct + ComputeCalled func(s string) []byte + EmptyHashCalled func() []byte + func (hash *HasherStub) Compute(s string) []byte + func (hash *HasherStub) EmptyHash() []byte + func (hash *HasherStub) IsInterfaceNil() bool + func (hash *HasherStub) Size() int + type HeaderSyncHandlerStub struct + GetEpochStartMetaBlockCalled func() (data.MetaHeaderHandler, error) + GetUnFinishedMetaBlocksCalled func() (map[string]data.MetaHeaderHandler, error) + SyncUnFinishedMetaHeadersCalled func(epoch uint32) error + func (hsh *HeaderSyncHandlerStub) GetEpochStartMetaBlock() (data.MetaHeaderHandler, error) + func (hsh *HeaderSyncHandlerStub) GetUnFinishedMetaBlocks() (map[string]data.MetaHeaderHandler, error) + func (hsh *HeaderSyncHandlerStub) IsInterfaceNil() bool + func (hsh *HeaderSyncHandlerStub) SyncUnFinishedMetaHeaders(epoch uint32) error + type HeaderValidatorStub struct + IsHeaderConstructionValidCalled func(currHdr, prevHdr data.HeaderHandler) error + func (hvs *HeaderValidatorStub) IsHeaderConstructionValid(currHdr, prevHdr data.HeaderHandler) error + func (hvs *HeaderValidatorStub) IsInterfaceNil() bool + type HeadersCacherStub struct + AddCalled func(headerHash []byte, header data.HeaderHandler) + ClearCalled func() + GetHeaderByHashCalled func(hash []byte) (data.HeaderHandler, error) + GetHeaderByNonceAndShardIdCalled func(hdrNonce uint64, shardId uint32) ([]data.HeaderHandler, [][]byte, error) + GetNumHeadersCalled func(shardId uint32) int + LenCalled func() int + MaxSizeCalled func() int + NoncesCalled func(shardId uint32) []uint64 + RegisterHandlerCalled func(handler func(header data.HeaderHandler, shardHeaderHash []byte)) + RemoveHeaderByHashCalled func(headerHash []byte) + RemoveHeaderByNonceAndShardIdCalled func(hdrNonce uint64, shardId uint32) + func (hcs *HeadersCacherStub) AddHeader(headerHash []byte, header data.HeaderHandler) + func (hcs *HeadersCacherStub) Clear() + func (hcs *HeadersCacherStub) GetHeaderByHash(hash []byte) (data.HeaderHandler, error) + func (hcs *HeadersCacherStub) GetHeadersByNonceAndShardId(hdrNonce uint64, shardId uint32) ([]data.HeaderHandler, [][]byte, error) + func (hcs *HeadersCacherStub) GetNumHeaders(shardId uint32) int + func (hcs *HeadersCacherStub) IsInterfaceNil() bool + func (hcs *HeadersCacherStub) Len() int + func (hcs *HeadersCacherStub) MaxSize() int + func (hcs *HeadersCacherStub) Nonces(shardId uint32) []uint64 + func (hcs *HeadersCacherStub) RegisterHandler(handler func(header data.HeaderHandler, shardHeaderHash []byte)) + func (hcs *HeadersCacherStub) RemoveHeaderByHash(headerHash []byte) + func (hcs *HeadersCacherStub) RemoveHeaderByNonceAndShardId(hdrNonce uint64, shardId uint32) + type ImportHandlerStub struct + CloseCalled func() error + GetAccountsDBForShardCalled func(shardID uint32) state.AccountsAdapter + GetHardForkMetaBlockCalled func() data.MetaHeaderHandler + GetMiniBlocksCalled func() map[string]*block.MiniBlock + GetTransactionsCalled func() map[string]data.TransactionHandler + GetUnFinishedMetaBlocksCalled func() map[string]data.MetaHeaderHandler + GetValidatorAccountsDBCalled func() state.AccountsAdapter + ImportAllCalled func() error + func (ihs *ImportHandlerStub) Close() error + func (ihs *ImportHandlerStub) GetAccountsDBForShard(shardID uint32) state.AccountsAdapter + func (ihs *ImportHandlerStub) GetHardForkMetaBlock() data.MetaHeaderHandler + func (ihs *ImportHandlerStub) GetMiniBlocks() map[string]*block.MiniBlock + func (ihs *ImportHandlerStub) GetTransactions() map[string]data.TransactionHandler + func (ihs *ImportHandlerStub) GetUnFinishedMetaBlocks() map[string]data.MetaHeaderHandler + func (ihs *ImportHandlerStub) GetValidatorAccountsDB() state.AccountsAdapter + func (ihs *ImportHandlerStub) ImportAll() error + func (ihs *ImportHandlerStub) IsInterfaceNil() bool + type ImportStartHandlerStub struct + IsAfterExportBeforeImportCalled func() bool + ResetStartImportCalled func() error + SetStartImportCalled func() error + ShouldStartImportCalled func() bool + func (ish *ImportStartHandlerStub) IsAfterExportBeforeImport() bool + func (ish *ImportStartHandlerStub) IsInterfaceNil() bool + func (ish *ImportStartHandlerStub) ResetStartImport() error + func (ish *ImportStartHandlerStub) SetStartImport() error + func (ish *ImportStartHandlerStub) ShouldStartImport() bool + type MarshalizerFake struct + Fail bool + func (mm *MarshalizerFake) IsInterfaceNil() bool + func (mm *MarshalizerFake) Marshal(obj interface{}) ([]byte, error) + func (mm *MarshalizerFake) Unmarshal(obj interface{}, buff []byte) error + type MarshalizerMock struct + Fail bool + func (mm *MarshalizerMock) IsInterfaceNil() bool + func (mm *MarshalizerMock) Marshal(obj interface{}) ([]byte, error) + func (mm *MarshalizerMock) Unmarshal(obj interface{}, buff []byte) error + type PendingTransactionProcessorStub struct + CommitCalled func() ([]byte, error) + ProcessTransactionsDstMeCalled func(mbInfo *update.MbInfo) (*block.MiniBlock, error) + RootHashCalled func() ([]byte, error) + func (ptps *PendingTransactionProcessorStub) Commit() ([]byte, error) + func (ptps *PendingTransactionProcessorStub) IsInterfaceNil() bool + func (ptps *PendingTransactionProcessorStub) ProcessTransactionsDstMe(mbInfo *update.MbInfo) (*block.MiniBlock, error) + func (ptps *PendingTransactionProcessorStub) RootHash() ([]byte, error) + type PubkeyConverterStub struct + DecodeCalled func(humanReadable string) ([]byte, error) + EncodeCalled func(pkBytes []byte) string + LenCalled func() int + func (pcs *PubkeyConverterStub) Decode(humanReadable string) ([]byte, error) + func (pcs *PubkeyConverterStub) Encode(pkBytes []byte) string + func (pcs *PubkeyConverterStub) IsInterfaceNil() bool + func (pcs *PubkeyConverterStub) Len() int + type RoundHandlerStub struct + IndexCalled func() int64 + RemainingTimeCalled func(startTime time.Time, maxTime time.Duration) time.Duration + RoundIndex int64 + TimeDurationCalled func() time.Duration + TimeStampCalled func() time.Time + UpdateRoundCalled func(time.Time, time.Time) + func (rhs *RoundHandlerStub) Index() int64 + func (rhs *RoundHandlerStub) IsInterfaceNil() bool + func (rhs *RoundHandlerStub) RemainingTime(startTime time.Time, maxTime time.Duration) time.Duration + func (rhs *RoundHandlerStub) TimeDuration() time.Duration + func (rhs *RoundHandlerStub) TimeStamp() time.Time + func (rhs *RoundHandlerStub) UpdateRound(genesisRoundTimeStamp time.Time, timeStamp time.Time) + type StateSyncStub struct + GetAllMiniBlocksCalled func() (map[string]*block.MiniBlock, error) + GetAllTransactionsCalled func() (map[string]data.TransactionHandler, error) + GetAllTriesCalled func() (map[string]common.Trie, error) + GetEpochStartMetaBlockCalled func() (data.MetaHeaderHandler, error) + GetUnFinishedMetaBlocksCalled func() (map[string]data.MetaHeaderHandler, error) + SyncAllStateCalled func(epoch uint32) error + func (sss *StateSyncStub) GetAllMiniBlocks() (map[string]*block.MiniBlock, error) + func (sss *StateSyncStub) GetAllTransactions() (map[string]data.TransactionHandler, error) + func (sss *StateSyncStub) GetAllTries() (map[string]common.Trie, error) + func (sss *StateSyncStub) GetEpochStartMetaBlock() (data.MetaHeaderHandler, error) + func (sss *StateSyncStub) GetUnFinishedMetaBlocks() (map[string]data.MetaHeaderHandler, error) + func (sss *StateSyncStub) IsInterfaceNil() bool + func (sss *StateSyncStub) SyncAllState(epoch uint32) error + type TransactionCoordinatorMock struct + AddIntermediateTransactionsCalled func(mapSCRs map[block.Type][]data.TransactionHandler) error + AddTransactionsCalled func(txHandlers []data.TransactionHandler, blockType block.Type) + AddTxsFromMiniBlocksCalled func(miniBlocks block.MiniBlockSlice) + ComputeTransactionTypeCalled func(tx data.TransactionHandler) (process.TransactionType, error) + CreateBlockStartedCalled func() + CreateMarshalizedDataCalled func(body *block.Body) map[string][][]byte + CreateMbsAndProcessCrossShardTransactionsDstMeCalled func(header data.HeaderHandler, ...) (block.MiniBlockSlice, uint32, bool, error) + CreateMbsAndProcessTransactionsFromMeCalled func(haveTime func() bool) block.MiniBlockSlice + CreatePostProcessMiniBlocksCalled func() block.MiniBlockSlice + GetAllCurrentUsedTxsCalled func(blockType block.Type) map[string]data.TransactionHandler + GetAllIntermediateTxsCalled func() map[block.Type]map[string]data.TransactionHandler + GetCreatedInShardMiniBlocksCalled func() []*block.MiniBlock + IsDataPreparedForProcessingCalled func(haveTime func() time.Duration) error + ProcessBlockTransactionCalled func(header data.HeaderHandler, body *block.Body, haveTime func() time.Duration) error + RemoveBlockDataFromPoolCalled func(body *block.Body) error + RemoveTxsFromPoolCalled func(body *block.Body) error + RequestBlockTransactionsCalled func(body *block.Body) + RequestMiniBlocksCalled func(header data.HeaderHandler) + RestoreBlockDataFromStorageCalled func(body *block.Body) (int, error) + SaveTxsToStorageCalled func(body *block.Body) + VerifyCreatedBlockTransactionsCalled func(hdr data.HeaderHandler, body *block.Body) error + VerifyCreatedMiniBlocksCalled func(hdr data.HeaderHandler, body *block.Body) error + func (tcm *TransactionCoordinatorMock) AddIntermediateTransactions(mapSCRs map[block.Type][]data.TransactionHandler) error + func (tcm *TransactionCoordinatorMock) AddTransactions(txHandlers []data.TransactionHandler, blockType block.Type) + func (tcm *TransactionCoordinatorMock) AddTxsFromMiniBlocks(miniBlocks block.MiniBlockSlice) + func (tcm *TransactionCoordinatorMock) CreateBlockStarted() + func (tcm *TransactionCoordinatorMock) CreateMarshalizedData(body *block.Body) map[string][][]byte + func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessCrossShardTransactionsDstMe(header data.HeaderHandler, ...) (block.MiniBlockSlice, uint32, bool, error) + func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessTransactionsFromMe(haveTime func() bool, _ []byte) block.MiniBlockSlice + func (tcm *TransactionCoordinatorMock) CreatePostProcessMiniBlocks() block.MiniBlockSlice + func (tcm *TransactionCoordinatorMock) CreateReceiptsHash() ([]byte, error) + func (tcm *TransactionCoordinatorMock) GetAllCurrentLogs() []*data.LogData + func (tcm *TransactionCoordinatorMock) GetAllCurrentUsedTxs(blockType block.Type) map[string]data.TransactionHandler + func (tcm *TransactionCoordinatorMock) GetAllIntermediateTxs() map[block.Type]map[string]data.TransactionHandler + func (tcm *TransactionCoordinatorMock) GetCreatedInShardMiniBlocks() []*block.MiniBlock + func (tcm *TransactionCoordinatorMock) IsDataPreparedForProcessing(haveTime func() time.Duration) error + func (tcm *TransactionCoordinatorMock) IsInterfaceNil() bool + func (tcm *TransactionCoordinatorMock) ProcessBlockTransaction(header data.HeaderHandler, body *block.Body, haveTime func() time.Duration) error + func (tcm *TransactionCoordinatorMock) RemoveBlockDataFromPool(body *block.Body) error + func (tcm *TransactionCoordinatorMock) RemoveTxsFromPool(body *block.Body) error + func (tcm *TransactionCoordinatorMock) RequestBlockTransactions(body *block.Body) + func (tcm *TransactionCoordinatorMock) RequestMiniBlocks(header data.HeaderHandler) + func (tcm *TransactionCoordinatorMock) RestoreBlockDataFromStorage(body *block.Body) (int, error) + func (tcm *TransactionCoordinatorMock) SaveTxsToStorage(body *block.Body) + func (tcm *TransactionCoordinatorMock) VerifyCreatedBlockTransactions(hdr data.HeaderHandler, body *block.Body) error + func (tcm *TransactionCoordinatorMock) VerifyCreatedMiniBlocks(hdr data.HeaderHandler, body *block.Body) error + type TrieFactoryStub struct + CreateCalled func(config config.StorageConfig, s string, b bool) (common.StorageManager, common.Trie, error) + func (t *TrieFactoryStub) Create(config config.StorageConfig, s string, b bool) (common.StorageManager, common.Trie, error) + func (t *TrieFactoryStub) IsInterfaceNil() bool + type TrieSyncersStub struct + AddCalled func(key string, val update.TrieSyncer) error + AddMultipleCalled func(keys []string, interceptors []update.TrieSyncer) error + GetCalled func(key string) (update.TrieSyncer, error) + LenCalled func() int + RemoveCalled func(key string) + ReplaceCalled func(key string, val update.TrieSyncer) error + StartSyncingCalled func(rootHash []byte, ctx context.Context) error + TrieCalled func() common.Trie + func (tss *TrieSyncersStub) Add(key string, val update.TrieSyncer) error + func (tss *TrieSyncersStub) AddMultiple(keys []string, interceptors []update.TrieSyncer) error + func (tss *TrieSyncersStub) Get(key string) (update.TrieSyncer, error) + func (tss *TrieSyncersStub) IsInterfaceNil() bool + func (tss *TrieSyncersStub) Len() int + func (tss *TrieSyncersStub) Remove(key string) + func (tss *TrieSyncersStub) Replace(key string, val update.TrieSyncer) error + func (tss *TrieSyncersStub) StartSyncing(rootHash []byte, ctx context.Context) error + func (tss *TrieSyncersStub) Trie() common.Trie + type Uint64ByteSliceConverterStub struct + ToByteSliceCalled func(uint64) []byte + ToUint64Called func([]byte) (uint64, error) + func (u *Uint64ByteSliceConverterStub) IsInterfaceNil() bool + func (u *Uint64ByteSliceConverterStub) ToByteSlice(p uint64) []byte + func (u *Uint64ByteSliceConverterStub) ToUint64(p []byte) (uint64, error)