Versions in this module Expand all Collapse all v1 v1.999.0 Nov 17, 2022 Changes in this version + func NewCountingDB() *countingDB + func NewMultiShardsCoordinatorMock(nrShard uint32) *multipleShardsCoordinatorMock + func NewNetworkShardingCollectorMock() *networkShardingCollectorMock + func NewNilOutport() *nilOutport + func NewNodesHandlerMock(initialNodesSetup genesis.InitialNodesHandler) (*nodesHandlerMock, error) + func NewTestBootstrapperMock() *testBootstrapperMock + 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 AccountsFactoryStub struct + CreateAccountCalled func(address []byte) (vmcommon.AccountHandler, error) + func (afs *AccountsFactoryStub) CreateAccount(address []byte) (vmcommon.AccountHandler, error) + func (afs *AccountsFactoryStub) IsInterfaceNil() bool + type BlackListHandlerStub struct + AddCalled func(key string) error + AddWithSpanCalled func(key string, span time.Duration) error + HasCalled func(key string) bool + SweepCalled func() + func (blhs *BlackListHandlerStub) Add(key string) error + func (blhs *BlackListHandlerStub) AddWithSpan(key string, span time.Duration) error + func (blhs *BlackListHandlerStub) Has(key string) bool + func (blhs *BlackListHandlerStub) IsInterfaceNil() bool + func (blhs *BlackListHandlerStub) Sweep() + type BlockProcessorMock struct + AddLastNotarizedHdrCalled func(shardId uint32, processedHdr data.HeaderHandler) + CommitBlockCalled func(header data.HeaderHandler, body data.BodyHandler) error + CreateBlockCalled func(initialHdrData data.HeaderHandler, haveTime func() bool) (data.HeaderHandler, data.BodyHandler, error) + CreateNewHeaderCalled func(round uint64, nonce uint64) (data.HeaderHandler, error) + DecodeBlockBodyCalled func(dta []byte) data.BodyHandler + DecodeBlockHeaderCalled func(dta []byte) data.HeaderHandler + MarshalizedDataToBroadcastCalled func(header data.HeaderHandler, body data.BodyHandler) (map[uint32][]byte, map[string][][]byte, error) + Marshalizer marshal.Marshalizer + NrCommitBlockCalled uint32 + ProcessBlockCalled func(header data.HeaderHandler, body data.BodyHandler, ...) error + ProcessScheduledBlockCalled func(header data.HeaderHandler, body data.BodyHandler, ...) error + PruneStateOnRollbackCalled func(currHeader data.HeaderHandler, currHeaderHash []byte, ...) + RestoreBlockBodyIntoPoolsCalled func(body data.BodyHandler) error + RestoreBlockIntoPoolsCalled func(header data.HeaderHandler, body data.BodyHandler) error + RestoreLastNotarizedHrdsToGenesisCalled func() + RevertCurrentBlockCalled func() + RevertIndexedBlockCalled func(header data.HeaderHandler) + RevertStateToBlockCalled func(header data.HeaderHandler, rootHash []byte) error + func (bpm *BlockProcessorMock) AddLastNotarizedHdr(shardId uint32, processedHdr data.HeaderHandler) + func (bpm *BlockProcessorMock) Close() error + func (bpm *BlockProcessorMock) CommitBlock(header data.HeaderHandler, body data.BodyHandler) error + func (bpm *BlockProcessorMock) CreateBlock(initialHdrData data.HeaderHandler, haveTime func() bool) (data.HeaderHandler, data.BodyHandler, error) + func (bpm *BlockProcessorMock) CreateNewHeader(round uint64, nonce uint64) (data.HeaderHandler, error) + func (bpm *BlockProcessorMock) DecodeBlockBody(dta []byte) data.BodyHandler + func (bpm *BlockProcessorMock) DecodeBlockHeader(dta []byte) data.HeaderHandler + func (bpm *BlockProcessorMock) IsInterfaceNil() bool + func (bpm *BlockProcessorMock) MarshalizedDataToBroadcast(header data.HeaderHandler, body data.BodyHandler) (map[uint32][]byte, map[string][][]byte, error) + func (bpm *BlockProcessorMock) ProcessBlock(header data.HeaderHandler, body data.BodyHandler, ...) error + func (bpm *BlockProcessorMock) ProcessScheduledBlock(header data.HeaderHandler, body data.BodyHandler, ...) error + func (bpm *BlockProcessorMock) PruneStateOnRollback(currHeader data.HeaderHandler, currHeaderHash []byte, ...) + func (bpm *BlockProcessorMock) RestoreBlockBodyIntoPools(body data.BodyHandler) error + func (bpm *BlockProcessorMock) RestoreBlockIntoPools(header data.HeaderHandler, body data.BodyHandler) error + func (bpm *BlockProcessorMock) RestoreLastNotarizedHrdsToGenesis() + func (bpm *BlockProcessorMock) RevertCurrentBlock() + func (bpm *BlockProcessorMock) RevertIndexedBlock(header data.HeaderHandler) + func (bpm *BlockProcessorMock) RevertStateToBlock(header data.HeaderHandler, rootHash []byte) error + func (bpm *BlockProcessorMock) SetNumProcessedObj(_ uint64) + type BlockSizeThrottlerStub struct + AddCalled func(round uint64, size uint32) + ComputeCurrentMaxSizeCalled func() + GetCurrentMaxSizeCalled func() uint32 + SucceedCalled func(round uint64) + func (bsts *BlockSizeThrottlerStub) Add(round uint64, size uint32) + func (bsts *BlockSizeThrottlerStub) ComputeCurrentMaxSize() + func (bsts *BlockSizeThrottlerStub) GetCurrentMaxSize() uint32 + func (bsts *BlockSizeThrottlerStub) IsInterfaceNil() bool + func (bsts *BlockSizeThrottlerStub) Succeed(round uint64) + type BlockTrackerStub struct + AddCrossNotarizedHeaderCalled func(shardID uint32, crossNotarizedHeader data.HeaderHandler, ...) + AddSelfNotarizedHeaderCalled func(shardID uint32, selfNotarizedHeader data.HeaderHandler, ...) + AddTrackedHeaderCalled func(header data.HeaderHandler, hash []byte) + CheckBlockAgainstFinalCalled func(headerHandler data.HeaderHandler) error + CheckBlockAgainstRoundHandlerCalled func(headerHandler data.HeaderHandler) error + CheckBlockAgainstWhitelistCalled func(interceptedData process.InterceptedData) bool + CleanupHeadersBehindNonceCalled func(shardID uint32, selfNotarizedNonce uint64, crossNotarizedNonce uint64) + ComputeLongestChainCalled func(shardID uint32, header data.HeaderHandler) ([]data.HeaderHandler, [][]byte) + ComputeLongestMetaChainFromLastNotarizedCalled func() ([]data.HeaderHandler, [][]byte, error) + ComputeLongestShardsChainsFromLastNotarizedCalled func() ([]data.HeaderHandler, [][]byte, map[uint32][]data.HeaderHandler, error) + DisplayTrackedHeadersCalled func() + GetCrossNotarizedHeaderCalled func(shardID uint32, offset uint64) (data.HeaderHandler, []byte, error) + GetLastCrossNotarizedHeaderCalled func(shardID uint32) (data.HeaderHandler, []byte, error) + GetLastCrossNotarizedHeadersForAllShardsCalled func() (map[uint32]data.HeaderHandler, error) + GetLastSelfNotarizedHeaderCalled func(shardID uint32) (data.HeaderHandler, []byte, error) + GetSelfNotarizedHeaderCalled func(shardID uint32, offset uint64) (data.HeaderHandler, []byte, error) + GetTrackedHeadersCalled func(shardID uint32) ([]data.HeaderHandler, [][]byte) + GetTrackedHeadersForAllShardsCalled func() map[uint32][]data.HeaderHandler + GetTrackedHeadersWithNonceCalled func(shardID uint32, nonce uint64) ([]data.HeaderHandler, [][]byte) + IsShardStuckCalled func(shardId uint32) bool + RegisterCrossNotarizedHeadersHandlerCalled func(...) + RegisterFinalMetachainHeadersHandlerCalled func(...) + RegisterSelfNotarizedFromCrossHeadersHandlerCalled func(...) + RegisterSelfNotarizedHeadersHandlerCalled func(...) + RemoveLastNotarizedHeadersCalled func() + RestoreToGenesisCalled func() + ShouldAddHeaderCalled func(headerHandler data.HeaderHandler) bool + ShouldSkipMiniBlocksCreationFromSelfCalled func() bool + func (bts *BlockTrackerStub) AddCrossNotarizedHeader(shardID uint32, crossNotarizedHeader data.HeaderHandler, ...) + func (bts *BlockTrackerStub) AddSelfNotarizedHeader(shardID uint32, selfNotarizedHeader data.HeaderHandler, ...) + func (bts *BlockTrackerStub) AddTrackedHeader(header data.HeaderHandler, hash []byte) + func (bts *BlockTrackerStub) CheckBlockAgainstFinal(headerHandler data.HeaderHandler) error + func (bts *BlockTrackerStub) CheckBlockAgainstRoundHandler(headerHandler data.HeaderHandler) error + func (bts *BlockTrackerStub) CheckBlockAgainstWhitelist(interceptedData process.InterceptedData) bool + func (bts *BlockTrackerStub) CleanupHeadersBehindNonce(shardID uint32, selfNotarizedNonce uint64, crossNotarizedNonce uint64) + func (bts *BlockTrackerStub) CleanupInvalidCrossHeaders(_ uint32, _ uint64) + func (bts *BlockTrackerStub) ComputeLongestChain(shardID uint32, header data.HeaderHandler) ([]data.HeaderHandler, [][]byte) + func (bts *BlockTrackerStub) ComputeLongestMetaChainFromLastNotarized() ([]data.HeaderHandler, [][]byte, error) + func (bts *BlockTrackerStub) ComputeLongestShardsChainsFromLastNotarized() ([]data.HeaderHandler, [][]byte, map[uint32][]data.HeaderHandler, error) + func (bts *BlockTrackerStub) DisplayTrackedHeaders() + func (bts *BlockTrackerStub) GetCrossNotarizedHeader(shardID uint32, offset uint64) (data.HeaderHandler, []byte, error) + func (bts *BlockTrackerStub) GetLastCrossNotarizedHeader(shardID uint32) (data.HeaderHandler, []byte, error) + func (bts *BlockTrackerStub) GetLastCrossNotarizedHeadersForAllShards() (map[uint32]data.HeaderHandler, error) + func (bts *BlockTrackerStub) GetLastSelfNotarizedHeader(shardID uint32) (data.HeaderHandler, []byte, error) + func (bts *BlockTrackerStub) GetSelfNotarizedHeader(shardID uint32, offset uint64) (data.HeaderHandler, []byte, error) + func (bts *BlockTrackerStub) GetTrackedHeaders(shardID uint32) ([]data.HeaderHandler, [][]byte) + func (bts *BlockTrackerStub) GetTrackedHeadersForAllShards() map[uint32][]data.HeaderHandler + func (bts *BlockTrackerStub) GetTrackedHeadersWithNonce(shardID uint32, nonce uint64) ([]data.HeaderHandler, [][]byte) + func (bts *BlockTrackerStub) IsInterfaceNil() bool + func (bts *BlockTrackerStub) IsShardStuck(shardId uint32) bool + func (bts *BlockTrackerStub) RegisterCrossNotarizedHeadersHandler(...) + func (bts *BlockTrackerStub) RegisterFinalMetachainHeadersHandler(...) + func (bts *BlockTrackerStub) RegisterSelfNotarizedFromCrossHeadersHandler(...) + func (bts *BlockTrackerStub) RegisterSelfNotarizedHeadersHandler(...) + func (bts *BlockTrackerStub) RemoveLastNotarizedHeaders() + func (bts *BlockTrackerStub) RestoreToGenesis() + func (bts *BlockTrackerStub) ShouldAddHeader(headerHandler data.HeaderHandler) bool + func (bts *BlockTrackerStub) ShouldSkipMiniBlocksCreationFromSelf() bool + type BoostrapStorerMock struct + GetCalled func(round int64) (bootstrapStorage.BootstrapData, error) + GetHighestRoundCalled func() int64 + PutCalled func(round int64, bootData bootstrapStorage.BootstrapData) error + func (bsm *BoostrapStorerMock) Get(round int64) (bootstrapStorage.BootstrapData, error) + func (bsm *BoostrapStorerMock) GetHighestRound() int64 + func (bsm *BoostrapStorerMock) IsInterfaceNil() bool + func (bsm *BoostrapStorerMock) Put(round int64, bootData bootstrapStorage.BootstrapData) error + func (bsm *BoostrapStorerMock) SaveLastRound(_ int64) error + type BuiltInCostHandlerStub struct + func (b *BuiltInCostHandlerStub) ComputeBuiltInCost(_ data.TransactionWithFeeHandler) uint64 + func (b *BuiltInCostHandlerStub) IsBuiltInFuncCall(_ data.TransactionWithFeeHandler) bool + func (b *BuiltInCostHandlerStub) IsInterfaceNil() bool + type ChainStorerMock struct + AddStorerCalled func(key dataRetriever.UnitType, s storage.Storer) + CloseAllCalled func() error + 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 CoreComponentsStub struct + APIEconomicsHandler process.EconomicsDataHandler + AddressPubKeyConverterField core.PubkeyConverter + AlarmSchedulerField core.TimersScheduler + ArwenChangeLockerInternal common.Locker + ChainIdCalled func() string + ChanStopNodeProcessField chan endProcess.ArgEndProcess + EconomicsDataField process.EconomicsDataHandler + EpochNotifierField process.EpochNotifier + EpochStartNotifierWithConfirmField factory.EpochStartNotifierWithConfirm + GenesisNodesSetupField sharding.GenesisNodesSetupHandler + GenesisTimeField time.Time + HardforkTriggerPubKeyField []byte + HasherField hashing.Hasher + InternalMarshalizerField marshal.Marshalizer + MinTransactionVersionCalled func() uint32 + NodeTypeProviderField core.NodeTypeProviderHandler + NodesShufflerField nodesCoordinator.NodesShuffler + PathHandlerField storage.PathManagerHandler + ProcessStatusHandlerInternal common.ProcessStatusHandler + RaterField sharding.PeerAccountListAndRatingHandler + RatingsDataField process.RatingsInfoHandler + RoundHandlerField consensus.RoundHandler + RoundNotifierField process.RoundNotifier + StatusHandlerField core.AppStatusHandler + StatusHandlerUtilsField nodeFactory.StatusHandlersUtils + SyncTimerField ntp.SyncTimer + TxMarshalizerField marshal.Marshalizer + TxSignHasherField hashing.Hasher + TxVersionCheckField process.TxVersionCheckerHandler + Uint64ByteSliceConverterField typeConverters.Uint64ByteSliceConverter + ValidatorPubKeyConverterField core.PubkeyConverter + VmMarshalizerField marshal.Marshalizer + WatchdogField core.WatchdogTimer + func (ccs *CoreComponentsStub) APIEconomicsData() process.EconomicsDataHandler + func (ccs *CoreComponentsStub) AddressPubKeyConverter() core.PubkeyConverter + func (ccs *CoreComponentsStub) AlarmScheduler() core.TimersScheduler + func (ccs *CoreComponentsStub) ArwenChangeLocker() common.Locker + func (ccs *CoreComponentsStub) ChainID() string + func (ccs *CoreComponentsStub) ChanStopNodeProcess() chan endProcess.ArgEndProcess + func (ccs *CoreComponentsStub) CheckSubcomponents() error + func (ccs *CoreComponentsStub) Close() error + func (ccs *CoreComponentsStub) Create() error + func (ccs *CoreComponentsStub) EconomicsData() process.EconomicsDataHandler + func (ccs *CoreComponentsStub) EncodedAddressLen() uint32 + func (ccs *CoreComponentsStub) EpochNotifier() process.EpochNotifier + func (ccs *CoreComponentsStub) EpochStartNotifierWithConfirm() factory.EpochStartNotifierWithConfirm + func (ccs *CoreComponentsStub) GenesisNodesSetup() sharding.GenesisNodesSetupHandler + func (ccs *CoreComponentsStub) GenesisTime() time.Time + func (ccs *CoreComponentsStub) HardforkTriggerPubKey() []byte + func (ccs *CoreComponentsStub) Hasher() hashing.Hasher + func (ccs *CoreComponentsStub) InternalMarshalizer() marshal.Marshalizer + func (ccs *CoreComponentsStub) IsInterfaceNil() bool + func (ccs *CoreComponentsStub) MinTransactionVersion() uint32 + func (ccs *CoreComponentsStub) NodeTypeProvider() core.NodeTypeProviderHandler + func (ccs *CoreComponentsStub) NodesShuffler() nodesCoordinator.NodesShuffler + func (ccs *CoreComponentsStub) PathHandler() storage.PathManagerHandler + func (ccs *CoreComponentsStub) ProcessStatusHandler() common.ProcessStatusHandler + func (ccs *CoreComponentsStub) Rater() sharding.PeerAccountListAndRatingHandler + func (ccs *CoreComponentsStub) RatingsData() process.RatingsInfoHandler + func (ccs *CoreComponentsStub) RoundHandler() consensus.RoundHandler + func (ccs *CoreComponentsStub) RoundNotifier() process.RoundNotifier + func (ccs *CoreComponentsStub) SetInternalMarshalizer(m marshal.Marshalizer) error + func (ccs *CoreComponentsStub) StatusHandler() core.AppStatusHandler + func (ccs *CoreComponentsStub) StatusHandlerUtils() nodeFactory.StatusHandlersUtils + func (ccs *CoreComponentsStub) String() string + func (ccs *CoreComponentsStub) SyncTimer() ntp.SyncTimer + func (ccs *CoreComponentsStub) TxMarshalizer() marshal.Marshalizer + func (ccs *CoreComponentsStub) TxSignHasher() hashing.Hasher + func (ccs *CoreComponentsStub) TxVersionChecker() process.TxVersionCheckerHandler + func (ccs *CoreComponentsStub) Uint64ByteSliceConverter() typeConverters.Uint64ByteSliceConverter + func (ccs *CoreComponentsStub) ValidatorPubKeyConverter() core.PubkeyConverter + func (ccs *CoreComponentsStub) VmMarshalizer() marshal.Marshalizer + func (ccs *CoreComponentsStub) Watchdog() core.WatchdogTimer + type CryptoComponentsStub struct + BlKeyGen crypto.KeyGenerator + BlockSig crypto.SingleSigner + MsgSigVerifier vm.MessageSignVerifier + MultiSig crypto.MultiSigner + PeerSignHandler crypto.PeerSignatureHandler + PrivKey crypto.PrivateKey + PrivKeyBytes []byte + PubKey crypto.PublicKey + PubKeyBytes []byte + PubKeyString string + TxKeyGen crypto.KeyGenerator + TxSig crypto.SingleSigner + func (ccs *CryptoComponentsStub) BlockSignKeyGen() crypto.KeyGenerator + func (ccs *CryptoComponentsStub) BlockSigner() crypto.SingleSigner + func (ccs *CryptoComponentsStub) CheckSubcomponents() error + func (ccs *CryptoComponentsStub) Clone() interface{} + func (ccs *CryptoComponentsStub) Close() error + func (ccs *CryptoComponentsStub) Create() error + func (ccs *CryptoComponentsStub) IsInterfaceNil() bool + func (ccs *CryptoComponentsStub) MessageSignVerifier() vm.MessageSignVerifier + func (ccs *CryptoComponentsStub) MultiSigner() crypto.MultiSigner + func (ccs *CryptoComponentsStub) PeerSignatureHandler() crypto.PeerSignatureHandler + func (ccs *CryptoComponentsStub) PrivateKey() crypto.PrivateKey + func (ccs *CryptoComponentsStub) PrivateKeyBytes() []byte + func (ccs *CryptoComponentsStub) PublicKey() crypto.PublicKey + func (ccs *CryptoComponentsStub) PublicKeyBytes() []byte + func (ccs *CryptoComponentsStub) PublicKeyString() string + func (ccs *CryptoComponentsStub) SetMultiSigner(ms crypto.MultiSigner) error + func (ccs *CryptoComponentsStub) String() string + func (ccs *CryptoComponentsStub) TxSignKeyGen() crypto.KeyGenerator + func (ccs *CryptoComponentsStub) TxSingleSigner() crypto.SingleSigner + type CurrentNetworkEpochProviderStub struct + EpochConfirmedCalled func(epoch uint32, timestamp uint64) + EpochIsActiveInNetworkCalled func(epoch uint32) bool + SetNetworkEpochAtBootstrapCalled func(epoch uint32) + func (cneps *CurrentNetworkEpochProviderStub) EpochConfirmed(epoch uint32, timestamp uint64) + func (cneps *CurrentNetworkEpochProviderStub) EpochIsActiveInNetwork(epoch uint32) bool + func (cneps *CurrentNetworkEpochProviderStub) IsInterfaceNil() bool + type DataComponentsStub struct + BlockChain data.ChainHandler + DataPool dataRetriever.PoolsHolder + EconomicsData factory.EconomicsHandler + MbProvider factory.MiniBlockProvider + Store dataRetriever.StorageService + func (dcs *DataComponentsStub) Blockchain() data.ChainHandler + func (dcs *DataComponentsStub) CheckSubcomponents() error + func (dcs *DataComponentsStub) Clone() interface{} + func (dcs *DataComponentsStub) Close() error + func (dcs *DataComponentsStub) Create() error + func (dcs *DataComponentsStub) Datapool() dataRetriever.PoolsHolder + func (dcs *DataComponentsStub) EconomicsHandler() factory.EconomicsHandler + func (dcs *DataComponentsStub) IsInterfaceNil() bool + func (dcs *DataComponentsStub) MiniBlocksProvider() factory.MiniBlockProvider + func (dcs *DataComponentsStub) SetBlockchain(chain data.ChainHandler) + func (dcs *DataComponentsStub) StorageService() dataRetriever.StorageService + func (dcs *DataComponentsStub) String() string + type DatabaseWriterStub struct + DoBulkRemoveCalled func(index string, hashes []string) error + DoBulkRequestCalled func(buff *bytes.Buffer, index string) error + DoMultiGetCalled func(ids []string, index string, withSource bool, res interface{}) error + DoRequestCalled func(req *esapi.IndexRequest) error + func (dws *DatabaseWriterStub) CheckAndCreateAlias(_ string, _ string) error + func (dws *DatabaseWriterStub) CheckAndCreateIndex(_ string) error + func (dws *DatabaseWriterStub) CheckAndCreatePolicy(_ string, _ *bytes.Buffer) error + func (dws *DatabaseWriterStub) CheckAndCreateTemplate(_ string, _ *bytes.Buffer) error + func (dws *DatabaseWriterStub) DoBulkRequest(buff *bytes.Buffer, index string) error + func (dws *DatabaseWriterStub) DoCountRequest(_ string, _ []byte) (uint64, error) + func (dws *DatabaseWriterStub) DoMultiGet(ids []string, index string, withSource bool, res interface{}) error + func (dws *DatabaseWriterStub) DoQueryRemove(_ string, _ *bytes.Buffer) error + func (dws *DatabaseWriterStub) DoRequest(req *esapi.IndexRequest) error + func (dws *DatabaseWriterStub) DoScrollRequest(_ string, _ []byte, _ bool, _ func(responseBytes []byte) error) error + func (dws *DatabaseWriterStub) IsInterfaceNil() bool + type EpochEconomicsStub struct + ComputeEndOfEpochEconomicsCalled func(metaBlock *block.MetaBlock) (*block.Economics, error) + VerifyRewardsPerBlockCalled func(metaBlock *block.MetaBlock, correctedProtocolSustainability *big.Int, ...) error + func (e *EpochEconomicsStub) ComputeEndOfEpochEconomics(metaBlock *block.MetaBlock) (*block.Economics, error) + func (e *EpochEconomicsStub) IsInterfaceNil() bool + func (e *EpochEconomicsStub) VerifyRewardsPerBlock(metaBlock *block.MetaBlock, correctedProtocolSustainability *big.Int, ...) error + type EpochRewardsCreatorStub struct + CreateMarshalizedDataCalled func(body *block.Body) map[string][][]byte + CreateRewardsMiniBlocksCalled func(metaBlock data.MetaHeaderHandler, ...) (block.MiniBlockSlice, error) + DeleteTxsFromStorageCalled func(metaBlock data.MetaHeaderHandler, body *block.Body) + GetLocalTxCacheCalled func() epochStart.TransactionCacher + GetProtocolSustainCalled func() *big.Int + GetRewardsTxsCalled func(body *block.Body) map[string]data.TransactionHandler + RemoveBlockDataFromPoolsCalled func(metaBlock data.MetaHeaderHandler, body *block.Body) + SaveTxBlockToStorageCalled func(metaBlock data.MetaHeaderHandler, body *block.Body) + VerifyRewardsMiniBlocksCalled func(metaBlock data.MetaHeaderHandler, ...) error + func (e *EpochRewardsCreatorStub) CreateMarshalizedData(body *block.Body) map[string][][]byte + func (e *EpochRewardsCreatorStub) CreateRewardsMiniBlocks(metaBlock data.MetaHeaderHandler, ...) (block.MiniBlockSlice, error) + func (e *EpochRewardsCreatorStub) DeleteTxsFromStorage(metaBlock data.MetaHeaderHandler, body *block.Body) + func (e *EpochRewardsCreatorStub) GetLocalTxCache() epochStart.TransactionCacher + func (e *EpochRewardsCreatorStub) GetProtocolSustainabilityRewards() *big.Int + func (e *EpochRewardsCreatorStub) GetRewardsTxs(body *block.Body) map[string]data.TransactionHandler + func (e *EpochRewardsCreatorStub) IsInterfaceNil() bool + func (e *EpochRewardsCreatorStub) RemoveBlockDataFromPools(metaBlock data.MetaHeaderHandler, body *block.Body) + func (e *EpochRewardsCreatorStub) SaveTxBlockToStorage(metaBlock data.MetaHeaderHandler, body *block.Body) + func (e *EpochRewardsCreatorStub) VerifyRewardsMiniBlocks(metaBlock data.MetaHeaderHandler, ...) error + type EpochStartDataCreatorStub struct + CreateEpochStartDataCalled func() (*block.EpochStart, error) + VerifyEpochStartDataForMetablockCalled func(metaBlock *block.MetaBlock) error + func (e *EpochStartDataCreatorStub) CreateEpochStartData() (*block.EpochStart, error) + func (e *EpochStartDataCreatorStub) IsInterfaceNil() bool + func (e *EpochStartDataCreatorStub) VerifyEpochStartDataForMetablock(metaBlock *block.MetaBlock) error + type EpochStartNotifierStub struct + NotifyAllCalled func(hdr data.HeaderHandler) + NotifyAllPrepareCalled func(hdr data.HeaderHandler, body data.BodyHandler) + NotifyEpochChangeConfirmedCalled 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) RegisterHandler(handler epochStart.ActionHandler) + func (esnm *EpochStartNotifierStub) UnregisterHandler(handler epochStart.ActionHandler) + type EpochStartSystemSCStub struct + ProcessDelegationRewardsCalled func(miniBlocks block.MiniBlockSlice, txCache epochStart.TransactionCacher) error + ProcessSystemSmartContractCalled func(validatorInfos map[uint32][]*state.ValidatorInfo, nonce uint64, epoch uint32) error + ToggleUnStakeUnBondCalled func(value bool) error + func (e *EpochStartSystemSCStub) IsInterfaceNil() bool + func (e *EpochStartSystemSCStub) ProcessDelegationRewards(miniBlocks block.MiniBlockSlice, txCache epochStart.TransactionCacher) error + func (e *EpochStartSystemSCStub) ProcessSystemSmartContract(validatorInfos map[uint32][]*state.ValidatorInfo, nonce uint64, epoch uint32) error + func (e *EpochStartSystemSCStub) ToggleUnStakeUnBond(value bool) error + type EpochStartTriggerStub struct + EpochCalled func() uint32 + EpochStartRoundCalled func() uint64 + ForceEpochStartCalled func(round uint64) + IsEpochStartCalled func() bool + MetaEpochCalled func() uint32 + ProcessedCalled func(header data.HeaderHandler) + ReceivedHeaderCalled func(handler data.HeaderHandler) + UpdateCalled func(round uint64, nonce uint64) + func (e *EpochStartTriggerStub) Close() error + 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) + func (e *EpochStartTriggerStub) GetRoundsPerEpoch() uint64 + func (e *EpochStartTriggerStub) GetSavedStateKey() []byte + func (e *EpochStartTriggerStub) IsEpochStart() bool + func (e *EpochStartTriggerStub) IsInterfaceNil() bool + func (e *EpochStartTriggerStub) LoadState(_ []byte) error + func (e *EpochStartTriggerStub) MetaEpoch() uint32 + func (e *EpochStartTriggerStub) NotifyAll(_ data.HeaderHandler) + func (e *EpochStartTriggerStub) ReceivedHeader(header data.HeaderHandler) + func (e *EpochStartTriggerStub) RequestEpochStartIfNeeded(_ data.HeaderHandler) + func (e *EpochStartTriggerStub) Revert(_ data.HeaderHandler) + func (e *EpochStartTriggerStub) RevertStateToBlock(_ data.HeaderHandler) error + func (e *EpochStartTriggerStub) SetAppStatusHandler(_ core.AppStatusHandler) error + func (e *EpochStartTriggerStub) SetCurrentEpochStartRound(_ uint64) + func (e *EpochStartTriggerStub) SetEpoch(_ uint32) + func (e *EpochStartTriggerStub) SetFinalityAttestingRound(_ uint64) + func (e *EpochStartTriggerStub) SetMinRoundsBetweenEpochs(_ uint64) + func (e *EpochStartTriggerStub) SetProcessed(header data.HeaderHandler, _ data.BodyHandler) + func (e *EpochStartTriggerStub) SetRoundsPerEpoch(_ uint64) + func (e *EpochStartTriggerStub) SetTrigger(_ epochStart.TriggerHandler) + func (e *EpochStartTriggerStub) Update(round uint64, nonce uint64) + type EpochValidatorInfoCreatorStub struct + CreateMarshalizedDataCalled func(body block.Body) map[string][][]byte + CreateValidatorInfoMiniBlocksCalled func(validatorsInfo map[uint32][]*state.ValidatorInfo) (block.MiniBlockSlice, error) + DeleteTxsFromStorageCalled func(metaBlock data.HeaderHandler) + RemoveBlockDataFromPoolsCalled func(metaBlock data.HeaderHandler, body *block.Body) + SaveTxBlockToStorageCalled func(metaBlock data.HeaderHandler, body *block.Body) + VerifyValidatorInfoMiniBlocksCalled func(miniblocks []*block.MiniBlock, ...) error + func (e *EpochValidatorInfoCreatorStub) CreateValidatorInfoMiniBlocks(validatorInfo map[uint32][]*state.ValidatorInfo) (block.MiniBlockSlice, error) + func (e *EpochValidatorInfoCreatorStub) DeleteValidatorInfoBlocksFromStorage(metaBlock data.HeaderHandler) + func (e *EpochValidatorInfoCreatorStub) IsInterfaceNil() bool + func (e *EpochValidatorInfoCreatorStub) RemoveBlockDataFromPools(metaBlock data.HeaderHandler, body *block.Body) + func (e *EpochValidatorInfoCreatorStub) SaveValidatorInfoBlocksToStorage(metaBlock data.HeaderHandler, body *block.Body) + func (e *EpochValidatorInfoCreatorStub) VerifyValidatorInfoMiniBlocks(miniblocks []*block.MiniBlock, ...) error + 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 FeeHandlerStub struct + CheckValidityTxValuesCalled func(tx data.TransactionWithFeeHandler) error + ComputeFeeForProcessingCalled func(tx data.TransactionWithFeeHandler, gasToUse uint64) *big.Int + ComputeGasLimitBasedOnBalanceCalled func(tx data.TransactionWithFeeHandler, balance *big.Int) (uint64, error) + ComputeGasLimitCalled func(tx data.TransactionWithFeeHandler) uint64 + ComputeGasUsedAndFeeBasedOnRefundValueCalled func(tx data.TransactionWithFeeHandler, refundValue *big.Int) (uint64, *big.Int) + ComputeMoveBalanceFeeCalled func(tx data.TransactionWithFeeHandler) *big.Int + ComputeTxFeeBasedOnGasUsedCalled func(tx data.TransactionWithFeeHandler, gasUsed uint64) *big.Int + ComputeTxFeeCalled func(tx data.TransactionWithFeeHandler) *big.Int + DeveloperPercentageCalled func() float64 + GasPriceForMoveCalled func(tx data.TransactionWithFeeHandler) uint64 + GasPriceForProcessingCalled func(tx data.TransactionWithFeeHandler) uint64 + GasPriceModifierCalled func() float64 + GenesisTotalSupplyCalled func() *big.Int + MaxGasLimitPerBlockCalled func() uint64 + MaxGasLimitPerBlockForSafeCrossShardCalled func() uint64 + MaxGasLimitPerMiniBlockCalled func() uint64 + MaxGasLimitPerMiniBlockForSafeCrossShardCalled func() uint64 + MaxGasLimitPerTxCalled func() uint64 + MinGasPriceCalled func() uint64 + MinGasPriceForProcessingCalled func() uint64 + SetMaxGasLimitPerBlockCalled func(maxGasLimitPerBlock uint64) + SetMinGasLimitCalled func(minGasLimit uint64) + SetMinGasPriceCalled func(minGasPrice uint64) + SplitTxGasInCategoriesCalled func(tx data.TransactionWithFeeHandler) (uint64, uint64) + func (fhs *FeeHandlerStub) CheckValidityTxValues(tx data.TransactionWithFeeHandler) error + func (fhs *FeeHandlerStub) ComputeFeeForProcessing(tx data.TransactionWithFeeHandler, gasToUse uint64) *big.Int + func (fhs *FeeHandlerStub) ComputeGasLimit(tx data.TransactionWithFeeHandler) uint64 + func (fhs *FeeHandlerStub) ComputeGasLimitBasedOnBalance(tx data.TransactionWithFeeHandler, balance *big.Int) (uint64, error) + func (fhs *FeeHandlerStub) ComputeGasUsedAndFeeBasedOnRefundValue(tx data.TransactionWithFeeHandler, refundValue *big.Int) (uint64, *big.Int) + func (fhs *FeeHandlerStub) ComputeMoveBalanceFee(tx data.TransactionWithFeeHandler) *big.Int + func (fhs *FeeHandlerStub) ComputeTxFee(tx data.TransactionWithFeeHandler) *big.Int + func (fhs *FeeHandlerStub) ComputeTxFeeBasedOnGasUsed(tx data.TransactionWithFeeHandler, gasUsed uint64) *big.Int + func (fhs *FeeHandlerStub) DeveloperPercentage() float64 + func (fhs *FeeHandlerStub) GasPerDataByte() uint64 + func (fhs *FeeHandlerStub) GasPriceForMove(tx data.TransactionWithFeeHandler) uint64 + func (fhs *FeeHandlerStub) GasPriceForProcessing(tx data.TransactionWithFeeHandler) uint64 + func (fhs *FeeHandlerStub) GasPriceModifier() float64 + func (fhs *FeeHandlerStub) GenesisTotalSupply() *big.Int + func (fhs *FeeHandlerStub) IsInterfaceNil() bool + func (fhs *FeeHandlerStub) MaxGasLimitPerBlock(uint32) uint64 + func (fhs *FeeHandlerStub) MaxGasLimitPerBlockForSafeCrossShard() uint64 + func (fhs *FeeHandlerStub) MaxGasLimitPerMiniBlock(uint32) uint64 + func (fhs *FeeHandlerStub) MaxGasLimitPerMiniBlockForSafeCrossShard() uint64 + func (fhs *FeeHandlerStub) MaxGasLimitPerTx() uint64 + func (fhs *FeeHandlerStub) MinGasLimit() uint64 + func (fhs *FeeHandlerStub) MinGasPrice() uint64 + func (fhs *FeeHandlerStub) MinGasPriceForProcessing() uint64 + func (fhs *FeeHandlerStub) SetMaxGasLimitPerBlock(maxGasLimitPerBlock uint64) + func (fhs *FeeHandlerStub) SetMinGasLimit(minGasLimit uint64) + func (fhs *FeeHandlerStub) SetMinGasPrice(minGasPrice uint64) + func (fhs *FeeHandlerStub) SplitTxGasInCategories(tx data.TransactionWithFeeHandler) (uint64, uint64) + type ForkDetectorStub struct + AddHeaderCalled func(header data.HeaderHandler, hash []byte, state process.BlockHeaderState, ...) error + CheckForkCalled func() *process.ForkInfo + GetHighestFinalBlockHashCalled func() []byte + GetHighestFinalBlockNonceCalled func() uint64 + GetNotarizedHeaderHashCalled func(nonce uint64) []byte + ProbableHighestNonceCalled func() uint64 + RemoveHeaderCalled func(nonce uint64, hash []byte) + ResetForkCalled func() + ResetProbableHighestNonceCalled func() + RestoreToGenesisCalled func() + SetFinalToLastCheckpointCalled func() + SetRollBackNonceCalled func(nonce uint64) + func (fdm *ForkDetectorStub) AddHeader(header data.HeaderHandler, hash []byte, state process.BlockHeaderState, ...) error + func (fdm *ForkDetectorStub) CheckFork() *process.ForkInfo + func (fdm *ForkDetectorStub) GetHighestFinalBlockHash() []byte + func (fdm *ForkDetectorStub) GetHighestFinalBlockNonce() uint64 + func (fdm *ForkDetectorStub) GetNotarizedHeaderHash(nonce uint64) []byte + func (fdm *ForkDetectorStub) IsInterfaceNil() bool + func (fdm *ForkDetectorStub) ProbableHighestNonce() uint64 + func (fdm *ForkDetectorStub) RemoveHeader(nonce uint64, hash []byte) + func (fdm *ForkDetectorStub) ResetFork() + func (fdm *ForkDetectorStub) ResetProbableHighestNonce() + func (fdm *ForkDetectorStub) RestoreToGenesis() + func (fdm *ForkDetectorStub) SetFinalToLastCheckpoint() + func (fdm *ForkDetectorStub) SetRollBackNonce(nonce uint64) + type GasHandlerMock struct + ComputeGasProvidedByMiniBlockCalled func(miniBlock *block.MiniBlock, mapHashTx map[string]data.TransactionHandler) (uint64, uint64, error) + ComputeGasProvidedByTxCalled func(txSenderShardId uint32, txReceiverSharedId uint32, ...) (uint64, uint64, error) + GasPenalizedCalled func(hash []byte) uint64 + GasProvidedCalled func(hash []byte) uint64 + GasRefundedCalled func(hash []byte) uint64 + InitCalled func() + RemoveGasPenalizedCalled func(hashes [][]byte) + RemoveGasProvidedCalled func(hashes [][]byte) + RemoveGasRefundedCalled func(hashes [][]byte) + SetGasPenalizedCalled func(gasPenalized uint64, hash []byte) + SetGasProvidedCalled func(gasProvided uint64, hash []byte) + SetGasRefundedCalled func(gasRefunded uint64, hash []byte) + TotalGasPenalizedCalled func() uint64 + TotalGasProvidedCalled func() uint64 + TotalGasProvidedWithScheduledCalled func() uint64 + TotalGasRefundedCalled func() uint64 + func (ghm *GasHandlerMock) ComputeGasProvidedByMiniBlock(miniBlock *block.MiniBlock, mapHashTx map[string]data.TransactionHandler) (uint64, uint64, error) + func (ghm *GasHandlerMock) ComputeGasProvidedByTx(txSenderShardId uint32, txReceiverShardId uint32, ...) (uint64, uint64, error) + func (ghm *GasHandlerMock) GasPenalized(hash []byte) uint64 + func (ghm *GasHandlerMock) GasProvided(hash []byte) uint64 + func (ghm *GasHandlerMock) GasRefunded(hash []byte) uint64 + func (ghm *GasHandlerMock) Init() + func (ghm *GasHandlerMock) IsInterfaceNil() bool + func (ghm *GasHandlerMock) RemoveGasPenalized(hashes [][]byte) + func (ghm *GasHandlerMock) RemoveGasProvided(hashes [][]byte) + func (ghm *GasHandlerMock) RemoveGasRefunded(hashes [][]byte) + func (ghm *GasHandlerMock) SetGasPenalized(gasPenalized uint64, hash []byte) + func (ghm *GasHandlerMock) SetGasProvided(gasProvided uint64, hash []byte) + func (ghm *GasHandlerMock) SetGasRefunded(gasRefunded uint64, hash []byte) + func (ghm *GasHandlerMock) TotalGasPenalized() uint64 + func (ghm *GasHandlerMock) TotalGasProvided() uint64 + func (ghm *GasHandlerMock) TotalGasProvidedWithScheduled() uint64 + func (ghm *GasHandlerMock) TotalGasRefunded() uint64 + type GasScheduleNotifierMock struct + GasSchedule map[string]map[string]uint64 + Handlers []core.GasScheduleSubscribeHandler + func NewGasScheduleNotifierMock(gasSchedule map[string]map[string]uint64) *GasScheduleNotifierMock + func (g *GasScheduleNotifierMock) ChangeGasSchedule(gasSchedule map[string]map[string]uint64) + func (g *GasScheduleNotifierMock) IsInterfaceNil() bool + func (g *GasScheduleNotifierMock) LatestGasSchedule() map[string]map[string]uint64 + func (g *GasScheduleNotifierMock) RegisterNotifyHandler(handler core.GasScheduleSubscribeHandler) + func (g *GasScheduleNotifierMock) UnRegisterAll() + type HeaderIntegrityVerifierStub struct + GetVersionCalled func(epoch uint32) string + VerifyCalled func(header data.HeaderHandler) error + func (h *HeaderIntegrityVerifierStub) GetVersion(epoch uint32) string + func (h *HeaderIntegrityVerifierStub) IsInterfaceNil() bool + func (h *HeaderIntegrityVerifierStub) Verify(header data.HeaderHandler) error + type HeaderResolverStub struct + CloseCalled func() error + NumPeersToQueryCalled func() (int, int) + ProcessReceivedMessageCalled func(message p2p.MessageP2P) error + RequestDataFromEpochCalled func(identifier []byte) error + RequestDataFromHashCalled func(hash []byte, epoch uint32) error + RequestDataFromNonceCalled func(nonce uint64, epoch uint32) error + SetEpochHandlerCalled func(epochHandler dataRetriever.EpochHandler) error + SetNumPeersToQueryCalled func(intra int, cross int) + SetResolverDebugHandlerCalled func(handler dataRetriever.ResolverDebugHandler) error + func (hrs *HeaderResolverStub) Close() error + func (hrs *HeaderResolverStub) IsInterfaceNil() bool + func (hrs *HeaderResolverStub) NumPeersToQuery() (int, int) + func (hrs *HeaderResolverStub) ProcessReceivedMessage(message p2p.MessageP2P, _ core.PeerID) error + func (hrs *HeaderResolverStub) RequestDataFromEpoch(identifier []byte) error + func (hrs *HeaderResolverStub) RequestDataFromHash(hash []byte, epoch uint32) error + func (hrs *HeaderResolverStub) RequestDataFromNonce(nonce uint64, epoch uint32) error + func (hrs *HeaderResolverStub) SetEpochHandler(epochHandler dataRetriever.EpochHandler) error + func (hrs *HeaderResolverStub) SetNumPeersToQuery(intra int, cross int) + func (hrs *HeaderResolverStub) SetResolverDebugHandler(handler dataRetriever.ResolverDebugHandler) error + type HeaderSigVerifierStub struct + VerifyLeaderSignatureCalled func(header data.HeaderHandler) error + VerifyRandSeedAndLeaderSignatureCalled func(header data.HeaderHandler) error + VerifyRandSeedCalled func(header data.HeaderHandler) error + VerifySignatureCalled func(header data.HeaderHandler) error + func (hsvm *HeaderSigVerifierStub) IsInterfaceNil() bool + func (hsvm *HeaderSigVerifierStub) VerifyLeaderSignature(header data.HeaderHandler) error + func (hsvm *HeaderSigVerifierStub) VerifyRandSeed(header data.HeaderHandler) error + func (hsvm *HeaderSigVerifierStub) VerifyRandSeedAndLeaderSignature(header data.HeaderHandler) error + func (hsvm *HeaderSigVerifierStub) VerifySignature(header data.HeaderHandler) 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) + KeysCalled func(shardId uint32) []uint64 + LenCalled func() int + MaxSizeCalled func() int + RegisterHandlerCalled func(handler func(key []byte, value interface{})) + 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) IsInterfaceNil() bool + func (hcs *HeadersCacherStub) Keys(shardId uint32) []uint64 + func (hcs *HeadersCacherStub) Len() int + func (hcs *HeadersCacherStub) MaxSize() int + func (hcs *HeadersCacherStub) RegisterHandler(handler func(key []byte, value interface{})) + func (hcs *HeadersCacherStub) RemoveHeaderByHash(headerHash []byte) + func (hcs *HeadersCacherStub) RemoveHeaderByNonceAndShardId(hdrNonce uint64, shardId uint32) + type HeartbeatComponentsStub struct + HBMessenger heartbeat.MessageHandler + HBMonitor factory.HeartbeatMonitor + HBSender factory.HeartbeatSender + HBStorer factory.HeartbeatStorer + func (hbs *HeartbeatComponentsStub) CheckSubcomponents() error + func (hbs *HeartbeatComponentsStub) Close() error + func (hbs *HeartbeatComponentsStub) Create() error + func (hbs *HeartbeatComponentsStub) IsInterfaceNil() bool + func (hbs *HeartbeatComponentsStub) MessageHandler() heartbeat.MessageHandler + func (hbs *HeartbeatComponentsStub) Monitor() factory.HeartbeatMonitor + func (hbs *HeartbeatComponentsStub) Sender() factory.HeartbeatSender + func (hbs *HeartbeatComponentsStub) Storer() factory.HeartbeatStorer + type HeartbeatMessageHandlerStub struct + CreateHeartbeatFromP2PMessageCalled func(message p2p.MessageP2P) (*data.Heartbeat, error) + func (hbmh *HeartbeatMessageHandlerStub) CreateHeartbeatFromP2PMessage(message p2p.MessageP2P) (*data.Heartbeat, error) + func (hbmh *HeartbeatMessageHandlerStub) IsInterfaceNil() bool + type HeartbeatMonitorStub struct + CleanupCalled func() + GetHeartbeatsCalled func() []heartbeatData.PubKeyHeartbeat + ProcessReceivedMessageCalled func(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error + func (hbms *HeartbeatMonitorStub) Cleanup() + func (hbms *HeartbeatMonitorStub) Close() error + func (hbms *HeartbeatMonitorStub) GetHeartbeats() []heartbeatData.PubKeyHeartbeat + func (hbms *HeartbeatMonitorStub) IsInterfaceNil() bool + func (hbms *HeartbeatMonitorStub) ProcessReceivedMessage(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error + type HeartbeatSenderStub struct + SendHeartbeatCalled func() error + func (hbss *HeartbeatSenderStub) IsInterfaceNil() bool + func (hbss *HeartbeatSenderStub) SendHeartbeat() error + type HeartbeatStorerStub struct + LoadGenesisTimeCalled func() (time.Time, error) + LoadHeartBeatDTOCalled func(pubKey string) (*data.HeartbeatDTO, error) + LoadKeysCalled func() ([][]byte, error) + SaveKeysCalled func(peersSlice [][]byte) error + SavePubkeyDataCalled func(pubkey []byte, heartbeat *data.HeartbeatDTO) error + UpdateGenesisTimeCalled func(genesisTime time.Time) error + func (hss *HeartbeatStorerStub) IsInterfaceNil() bool + func (hss *HeartbeatStorerStub) LoadGenesisTime() (time.Time, error) + func (hss *HeartbeatStorerStub) LoadHeartBeatDTO(pubKey string) (*data.HeartbeatDTO, error) + func (hss *HeartbeatStorerStub) LoadKeys() ([][]byte, error) + func (hss *HeartbeatStorerStub) SaveKeys(peersSlice [][]byte) error + func (hss *HeartbeatStorerStub) SavePubkeyData(pubkey []byte, heartbeat *data.HeartbeatDTO) error + func (hss *HeartbeatStorerStub) UpdateGenesisTime(genesisTime time.Time) error + 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 InterimProcessorContainerMock struct + GetCalled func(key block.Type) (process.IntermediateTransactionHandler, error) + KeysCalled func() []block.Type + func (ipcm *InterimProcessorContainerMock) Add(_ block.Type, _ process.IntermediateTransactionHandler) error + func (ipcm *InterimProcessorContainerMock) AddMultiple(_ []block.Type, _ []process.IntermediateTransactionHandler) error + func (ipcm *InterimProcessorContainerMock) Get(key block.Type) (process.IntermediateTransactionHandler, error) + func (ipcm *InterimProcessorContainerMock) IsInterfaceNil() bool + func (ipcm *InterimProcessorContainerMock) Keys() []block.Type + func (ipcm *InterimProcessorContainerMock) Len() int + func (ipcm *InterimProcessorContainerMock) Remove(_ block.Type) + func (ipcm *InterimProcessorContainerMock) Replace(_ block.Type, _ process.IntermediateTransactionHandler) error + type IntermediateTransactionHandlerMock struct + AddIntermediateTransactionsCalled func(txs []data.TransactionHandler) error + CreateAllInterMiniBlocksCalled func() []*block.MiniBlock + CreateBlockStartedCalled func() + CreateMarshalizedDataCalled func(txHashes [][]byte) ([][]byte, error) + GetAllCurrentFinishedTxsCalled func() map[string]data.TransactionHandler + GetNumOfCrossInterMbsAndTxsCalled func() (int, int) + InitProcessedResultsCalled func(key []byte) + RemoveProcessedResultsCalled func(key []byte) [][]byte + SaveCurrentIntermediateTxToStorageCalled func() + VerifyInterMiniBlocksCalled func(body *block.Body) error + func (ith *IntermediateTransactionHandlerMock) AddIntermediateTransactions(txs []data.TransactionHandler) error + func (ith *IntermediateTransactionHandlerMock) Clean() + func (ith *IntermediateTransactionHandlerMock) CreateAllInterMiniBlocks() []*block.MiniBlock + func (ith *IntermediateTransactionHandlerMock) CreateBlockStarted() + func (ith *IntermediateTransactionHandlerMock) CreateMarshalizedData(txHashes [][]byte) ([][]byte, error) + func (ith *IntermediateTransactionHandlerMock) GetAllCurrentFinishedTxs() map[string]data.TransactionHandler + func (ith *IntermediateTransactionHandlerMock) GetCreatedInShardMiniBlock() *block.MiniBlock + func (ith *IntermediateTransactionHandlerMock) GetIntermediateTransactions() []data.TransactionHandler + func (ith *IntermediateTransactionHandlerMock) GetNumOfCrossInterMbsAndTxs() (int, int) + func (ith *IntermediateTransactionHandlerMock) InitProcessedResults(key []byte) + func (ith *IntermediateTransactionHandlerMock) IsInterfaceNil() bool + func (ith *IntermediateTransactionHandlerMock) RemoveProcessedResults(key []byte) [][]byte + func (ith *IntermediateTransactionHandlerMock) SaveCurrentIntermediateTxToStorage() + func (ith *IntermediateTransactionHandlerMock) VerifyInterMiniBlocks(body *block.Body) error + type KeyGenMock struct + func (keyGen *KeyGenMock) CheckPublicKeyValid(_ []byte) error + func (keyGen *KeyGenMock) GeneratePair() (crypto.PrivateKey, crypto.PublicKey) + func (keyGen *KeyGenMock) IsInterfaceNil() bool + func (keyGen *KeyGenMock) PrivateKeyFromByteArray(buff []byte) (crypto.PrivateKey, error) + func (keyGen *KeyGenMock) PublicKeyFromByteArray(buff []byte) (crypto.PublicKey, error) + func (keyGen *KeyGenMock) Suite() crypto.Suite + type LatestStorageDataProviderStub struct + GetCalled func() (storage.LatestDataFromStorage, error) + GetParentDirAndLastEpochCalled func() (string, uint32, error) + GetParentDirectoryCalled func() string + GetShardsFromDirectoryCalled func(path string) ([]string, error) + func (l *LatestStorageDataProviderStub) Get() (storage.LatestDataFromStorage, error) + func (l *LatestStorageDataProviderStub) GetParentDirAndLastEpoch() (string, uint32, error) + func (l *LatestStorageDataProviderStub) GetParentDirectory() string + func (l *LatestStorageDataProviderStub) GetShardsFromDirectory(path string) ([]string, error) + func (l *LatestStorageDataProviderStub) IsInterfaceNil() bool + type ListIndexUpdaterStub struct + UpdateListAndIndexCalled func(pubKey string, shardID uint32, list string, index uint32) error + func (lius *ListIndexUpdaterStub) IsInterfaceNil() bool + func (lius *ListIndexUpdaterStub) UpdateListAndIndex(pubKey string, shardID uint32, list string, index uint32) error + type MessageSignVerifierMock struct + func (m *MessageSignVerifierMock) IsInterfaceNil() bool + func (m *MessageSignVerifierMock) Verify(_ []byte, _ []byte, _ []byte) error + type MiniBlocksProviderStub struct + GetMiniBlocksCalled func(hashes [][]byte) ([]*block.MiniblockAndHash, [][]byte) + GetMiniBlocksFromPoolCalled func(hashes [][]byte) ([]*block.MiniblockAndHash, [][]byte) + GetMiniBlocksFromStorerCalled func(hashes [][]byte) ([]*block.MiniblockAndHash, [][]byte) + func (mbps *MiniBlocksProviderStub) GetMiniBlocks(hashes [][]byte) ([]*block.MiniblockAndHash, [][]byte) + func (mbps *MiniBlocksProviderStub) GetMiniBlocksFromPool(hashes [][]byte) ([]*block.MiniblockAndHash, [][]byte) + func (mbps *MiniBlocksProviderStub) GetMiniBlocksFromStorer(hashes [][]byte) ([]*block.MiniblockAndHash, [][]byte) + func (mbps *MiniBlocksProviderStub) IsInterfaceNil() bool + type MiniBlocksResolverStub struct + CloseCalled func() error + NumPeersToQueryCalled func() (int, int) + ProcessReceivedMessageCalled func(message p2p.MessageP2P) error + RequestDataFromHashArrayCalled func(hashes [][]byte, epoch uint32) error + RequestDataFromHashCalled func(hash []byte, epoch uint32) error + SetNumPeersToQueryCalled func(intra int, cross int) + func (mbrs *MiniBlocksResolverStub) Close() error + func (mbrs *MiniBlocksResolverStub) IsInterfaceNil() bool + func (mbrs *MiniBlocksResolverStub) NumPeersToQuery() (int, int) + func (mbrs *MiniBlocksResolverStub) ProcessReceivedMessage(message p2p.MessageP2P, _ core.PeerID) error + func (mbrs *MiniBlocksResolverStub) RequestDataFromHash(hash []byte, epoch uint32) error + func (mbrs *MiniBlocksResolverStub) RequestDataFromHashArray(hashes [][]byte, epoch uint32) error + func (mbrs *MiniBlocksResolverStub) SetNumPeersToQuery(intra int, cross int) + func (mbrs *MiniBlocksResolverStub) SetResolverDebugHandler(_ dataRetriever.ResolverDebugHandler) error + type MockDB struct + func (MockDB) Close() error + func (MockDB) Destroy() error + func (MockDB) DestroyClosed() error + func (MockDB) Get(_ []byte) ([]byte, error) + func (MockDB) Has(_ []byte) error + func (MockDB) Put(_, _ []byte) error + func (MockDB) RangeKeys(_ func(key []byte, val []byte) bool) + func (MockDB) Remove(_ []byte) error + func (s MockDB) IsInterfaceNil() bool + type NetworkComponentsStub struct + InputAntiFlood factory.P2PAntifloodHandler + Messenger p2p.Messenger + OutputAntiFlood factory.P2PAntifloodHandler + PeerBlackList process.PeerBlackListCacher + PeerHonesty factory.PeerHonestyHandler + PeersRatingHandlerField p2p.PeersRatingHandler + PreferredPeersHolder factory.PreferredPeersHolderHandler + func (ncs *NetworkComponentsStub) CheckSubcomponents() error + func (ncs *NetworkComponentsStub) Close() error + func (ncs *NetworkComponentsStub) Create() error + func (ncs *NetworkComponentsStub) InputAntiFloodHandler() factory.P2PAntifloodHandler + func (ncs *NetworkComponentsStub) IsInterfaceNil() bool + func (ncs *NetworkComponentsStub) NetworkMessenger() p2p.Messenger + func (ncs *NetworkComponentsStub) OutputAntiFloodHandler() factory.P2PAntifloodHandler + func (ncs *NetworkComponentsStub) PeerBlackListHandler() process.PeerBlackListCacher + func (ncs *NetworkComponentsStub) PeerHonestyHandler() factory.PeerHonestyHandler + func (ncs *NetworkComponentsStub) PeersRatingHandler() p2p.PeersRatingHandler + func (ncs *NetworkComponentsStub) PreferredPeersHolderHandler() factory.PreferredPeersHolderHandler + func (ncs *NetworkComponentsStub) PubKeyCacher() process.TimeCacher + func (ncs *NetworkComponentsStub) String() string + type NilAntifloodHandler struct + func (nah *NilAntifloodHandler) ApplyConsensusSize(_ int) + func (nah *NilAntifloodHandler) BlacklistPeer(_ core.PeerID, _ string, _ time.Duration) + func (nah *NilAntifloodHandler) CanProcessMessage(_ p2p.MessageP2P, _ core.PeerID) error + func (nah *NilAntifloodHandler) CanProcessMessagesOnTopic(_ core.PeerID, _ string, _ uint32, _ uint64, _ []byte) error + func (nah *NilAntifloodHandler) Close() error + func (nah *NilAntifloodHandler) IsInterfaceNil() bool + func (nah *NilAntifloodHandler) IsOriginatorEligibleForTopic(_ core.PeerID, _ string) error + func (nah *NilAntifloodHandler) ResetForTopic(_ string) + func (nah *NilAntifloodHandler) SetDebugger(_ process.AntifloodDebugger) error + func (nah *NilAntifloodHandler) SetMaxMessagesForTopic(_ string, _ uint32) + func (nah *NilAntifloodHandler) SetPeerValidatorMapper(_ process.PeerValidatorMapper) error + func (nah *NilAntifloodHandler) SetTopicsForAll(_ ...string) + type NodeInfoMock struct + func NewNodeInfo(address []byte, pubKey []byte, shardId uint32, initialRating uint32) *NodeInfoMock + func (n *NodeInfoMock) AddressBytes() []byte + func (n *NodeInfoMock) AssignedShard() uint32 + func (n *NodeInfoMock) GetInitialRating() uint32 + func (n *NodeInfoMock) IsInterfaceNil() bool + func (n *NodeInfoMock) PubKeyBytes() []byte + type NodesCoordinatorCacheStub struct + GetCalled func(key []byte) (value interface{}, ok bool) + PutCalled func(key []byte, value interface{}) (evicted bool) + func (rm *NodesCoordinatorCacheStub) Get(key []byte) (value interface{}, ok bool) + func (rm *NodesCoordinatorCacheStub) Put(key []byte, value interface{}) (evicted bool) + type NodesSetupStub struct + AllInitialNodesCalled func() []nodesCoordinator.GenesisNodeInfoHandler + GetAdaptivityCalled func() bool + GetChainIdCalled func() string + GetHysteresisCalled func() float32 + GetMetaConsensusGroupSizeCalled func() uint32 + GetMinTransactionVersionCalled func() uint32 + GetRoundDurationCalled func() uint64 + GetShardConsensusGroupSizeCalled func() uint32 + GetShardIDForPubKeyCalled func(pubkey []byte) (uint32, error) + GetStartTimeCalled func() int64 + InitialEligibleNodesPubKeysForShardCalled func(shardId uint32) ([]string, error) + InitialNodesInfoCalled func() (map[uint32][]nodesCoordinator.GenesisNodeInfoHandler, ...) + InitialNodesInfoForShardCalled func(shardId uint32) ([]nodesCoordinator.GenesisNodeInfoHandler, ...) + InitialNodesPubKeysCalled func() map[uint32][]string + MinNumberOfMetaNodesCalled func() uint32 + MinNumberOfNodesCalled func() uint32 + MinNumberOfNodesWithHysteresisCalled func() uint32 + MinNumberOfShardNodesCalled func() uint32 + NumberOfShardsCalled func() uint32 + func (n *NodesSetupStub) AllInitialNodes() []nodesCoordinator.GenesisNodeInfoHandler + func (n *NodesSetupStub) GetAdaptivity() bool + func (n *NodesSetupStub) GetChainId() string + func (n *NodesSetupStub) GetHysteresis() float32 + func (n *NodesSetupStub) GetMetaConsensusGroupSize() uint32 + func (n *NodesSetupStub) GetMinTransactionVersion() uint32 + func (n *NodesSetupStub) GetRoundDuration() uint64 + func (n *NodesSetupStub) GetShardConsensusGroupSize() uint32 + func (n *NodesSetupStub) GetShardIDForPubKey(pubkey []byte) (uint32, error) + func (n *NodesSetupStub) GetStartTime() int64 + func (n *NodesSetupStub) InitialEligibleNodesPubKeysForShard(shardId uint32) ([]string, error) + func (n *NodesSetupStub) InitialNodesInfo() (map[uint32][]nodesCoordinator.GenesisNodeInfoHandler, ...) + func (n *NodesSetupStub) InitialNodesInfoForShard(shardId uint32) ([]nodesCoordinator.GenesisNodeInfoHandler, ...) + func (n *NodesSetupStub) InitialNodesPubKeys() map[uint32][]string + func (n *NodesSetupStub) IsInterfaceNil() bool + func (n *NodesSetupStub) MinNumberOfMetaNodes() uint32 + func (n *NodesSetupStub) MinNumberOfNodes() uint32 + func (n *NodesSetupStub) MinNumberOfNodesWithHysteresis() uint32 + func (n *NodesSetupStub) MinNumberOfShardNodes() uint32 + func (n *NodesSetupStub) NumberOfShards() uint32 + type OneSCExecutorMockVM struct + GasForOperation uint64 + func NewOneSCExecutorMockVM(blockchainHook vmcommon.BlockchainHook, hasher hashing.Hasher) (*OneSCExecutorMockVM, error) + func (vm *OneSCExecutorMockVM) Close() error + func (vm *OneSCExecutorMockVM) GasScheduleChange(_ map[string]map[string]uint64) + func (vm *OneSCExecutorMockVM) GetVersion() string + func (vm *OneSCExecutorMockVM) IsInterfaceNil() bool + func (vm *OneSCExecutorMockVM) RunSmartContractCall(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error) + func (vm *OneSCExecutorMockVM) RunSmartContractCreate(input *vmcommon.ContractCreateInput) (*vmcommon.VMOutput, error) + type P2PAntifloodHandlerStub struct + ApplyConsensusSizeCalled func(size int) + BlacklistPeerCalled func(peer core.PeerID, reason string, duration time.Duration) + CanProcessMessageCalled func(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error + CanProcessMessagesOnTopicCalled func(peer core.PeerID, topic string, numMessages uint32, totalSize uint64, ...) error + IsOriginatorEligibleForTopicCalled func(pid core.PeerID, topic string) error + SetDebuggerCalled func(debugger process.AntifloodDebugger) error + func (p2pahs *P2PAntifloodHandlerStub) ApplyConsensusSize(size int) + func (p2pahs *P2PAntifloodHandlerStub) BlacklistPeer(peer core.PeerID, reason string, duration time.Duration) + func (p2pahs *P2PAntifloodHandlerStub) CanProcessMessage(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error + func (p2pahs *P2PAntifloodHandlerStub) CanProcessMessagesOnTopic(peer core.PeerID, topic string, numMessages uint32, totalSize uint64, ...) error + func (p2pahs *P2PAntifloodHandlerStub) Close() error + func (p2pahs *P2PAntifloodHandlerStub) IsInterfaceNil() bool + func (p2pahs *P2PAntifloodHandlerStub) IsOriginatorEligibleForTopic(pid core.PeerID, topic string) error + func (p2pahs *P2PAntifloodHandlerStub) ResetForTopic(_ string) + func (p2pahs *P2PAntifloodHandlerStub) SetDebugger(debugger process.AntifloodDebugger) error + func (p2pahs *P2PAntifloodHandlerStub) SetMaxMessagesForTopic(_ string, _ uint32) + func (p2pahs *P2PAntifloodHandlerStub) SetPeerValidatorMapper(_ process.PeerValidatorMapper) error + func (p2pahs *P2PAntifloodHandlerStub) SetTopicsForAll(_ ...string) + type PeerBlackListCacherStub struct + AddCalled func(pid core.PeerID) error + HasCalled func(pid core.PeerID) bool + SweepCalled func() + UpsertCalled func(pid core.PeerID, span time.Duration) error + func (pblhs *PeerBlackListCacherStub) Add(pid core.PeerID) error + func (pblhs *PeerBlackListCacherStub) Has(pid core.PeerID) bool + func (pblhs *PeerBlackListCacherStub) IsInterfaceNil() bool + func (pblhs *PeerBlackListCacherStub) Sweep() + func (pblhs *PeerBlackListCacherStub) Upsert(pid core.PeerID, span time.Duration) error + type PeerChangesHandler struct + PeerChangesCalled func() []block.PeerData + VerifyPeerChangesCalled func(peerChanges []block.PeerData) error + func (p *PeerChangesHandler) IsInterfaceNil() bool + func (p *PeerChangesHandler) PeerChanges() []block.PeerData + func (p *PeerChangesHandler) VerifyPeerChanges(peerChanges []block.PeerData) error + type PeerDenialEvaluatorStub struct + IsDeniedCalled func(pid core.PeerID) bool + UpsertPeerIDClled func(pid core.PeerID, duration time.Duration) error + func (pdes *PeerDenialEvaluatorStub) IsDenied(pid core.PeerID) bool + func (pdes *PeerDenialEvaluatorStub) IsInterfaceNil() bool + func (pdes *PeerDenialEvaluatorStub) UpsertPeerID(pid core.PeerID, duration time.Duration) error + type PeerHonestyHandlerStub struct + ChangeScoreCalled func(pk string, topic string, units int) + func (phhs *PeerHonestyHandlerStub) ChangeScore(pk string, topic string, units int) + func (phhs *PeerHonestyHandlerStub) Close() error + func (phhs *PeerHonestyHandlerStub) IsInterfaceNil() bool + type PeerShardMapperStub struct + GetLastKnownPeerIDCalled func(pk []byte) (core.PeerID, bool) + PutPeerIdShardIdCalled func(pid core.PeerID, shardID uint32) + PutPeerIdSubTypeCalled func(pid core.PeerID, peerSubType core.P2PPeerSubType) + UpdatePeerIDPublicKeyPairCalled func(pid core.PeerID, pk []byte) + func (psms *PeerShardMapperStub) GetLastKnownPeerID(pk []byte) (core.PeerID, bool) + func (psms *PeerShardMapperStub) GetPeerInfo(_ core.PeerID) core.P2PPeerInfo + func (psms *PeerShardMapperStub) IsInterfaceNil() bool + func (psms *PeerShardMapperStub) PutPeerIdShardId(pid core.PeerID, shardID uint32) + func (psms *PeerShardMapperStub) PutPeerIdSubType(pid core.PeerID, peerSubType core.P2PPeerSubType) + func (psms *PeerShardMapperStub) UpdatePeerIDPublicKeyPair(pid core.PeerID, pk []byte) + type PeerSignatureHandler struct + func (p *PeerSignatureHandler) GetPeerSignature(_ crypto.PrivateKey, _ []byte) ([]byte, error) + func (p *PeerSignatureHandler) IsInterfaceNil() bool + func (p *PeerSignatureHandler) VerifyPeerSignature(_ []byte, _ core.PeerID, _ []byte) error + type PeerTypeProviderStub struct + ComputeForPubKeyCalled func(pubKey []byte) (common.PeerType, uint32, error) + func (p *PeerTypeProviderStub) Close() error + func (p *PeerTypeProviderStub) ComputeForPubKey(pubKey []byte) (common.PeerType, uint32, error) + func (p *PeerTypeProviderStub) GetAllPeerTypeInfos() []*state.PeerTypeInfo + func (p *PeerTypeProviderStub) IsInterfaceNil() bool + type PendingMiniBlocksHandlerStub struct + AddProcessedHeaderCalled func(handler data.HeaderHandler) error + GetPendingMiniBlocksCalled func(shardID uint32) [][]byte + RevertHeaderCalled func(handler data.HeaderHandler) error + SetPendingMiniBlocksCalled func(shardID uint32, mbHashes [][]byte) + func (p *PendingMiniBlocksHandlerStub) AddProcessedHeader(handler data.HeaderHandler) error + func (p *PendingMiniBlocksHandlerStub) GetPendingMiniBlocks(shardID uint32) [][]byte + func (p *PendingMiniBlocksHandlerStub) IsInterfaceNil() bool + func (p *PendingMiniBlocksHandlerStub) RevertHeader(handler data.HeaderHandler) error + func (p *PendingMiniBlocksHandlerStub) SetPendingMiniBlocks(shardID uint32, mbHashes [][]byte) + type PrivateKeyMock struct + func (sk *PrivateKeyMock) GeneratePublic() crypto.PublicKey + func (sk *PrivateKeyMock) IsInterfaceNil() bool + func (sk *PrivateKeyMock) Scalar() crypto.Scalar + func (sk *PrivateKeyMock) Suite() crypto.Suite + func (sk *PrivateKeyMock) ToByteArray() ([]byte, error) + type ProcessComponentsStub struct + AccountsParserInternal genesis.AccountsParser + BlackListHdl process.TimeCacher + BlockProcess process.BlockProcessor + BlockTrack process.BlockTracker + BootSore process.BootStorer + CurrentEpochProviderInternal process.CurrentNetworkEpochProviderHandler + EpochNotifier factory.EpochStartNotifier + EpochTrigger epochStart.TriggerHandler + FallbackHdrValidator process.FallbackHeaderValidator + ForkDetect process.ForkDetector + HardforkTriggerField factory.HardforkTrigger + HeaderConstructValidator process.HeaderConstructionValidator + HeaderIntegrVerif process.HeaderIntegrityVerifier + HeaderSigVerif process.InterceptedHeaderSigVerifier + HistoryRepositoryInternal dblookupext.HistoryRepository + ImportStartHandlerInternal update.ImportStartHandler + IntContainer process.InterceptorsContainer + NodeRedundancyHandlerInternal consensus.NodeRedundancyHandler + NodesCoord nodesCoordinator.NodesCoordinator + PeerMapper process.NetworkShardingCollector + PendingMiniBlocksHdl process.PendingMiniBlocksHandler + ProcessedMiniBlocksTrackerInternal process.ProcessedMiniBlocksTracker + ReceiptsRepositoryInternal factory.ReceiptsRepository + ReqHandler process.RequestHandler + RequestedItemsHandlerInternal dataRetriever.RequestedItemsHandler + ResFinder dataRetriever.ResolversFinder + RoundHandlerField consensus.RoundHandler + ScheduledTxsExecutionHandlerInternal process.ScheduledTxsExecutionHandler + ShardCoord sharding.Coordinator + TxLogsProcess process.TransactionLogProcessorDatabase + TxSimulatorProcessor factory.TransactionSimulatorProcessor + TxsSenderHandlerField process.TxsSenderHandler + ValidatorProvider process.ValidatorsProvider + ValidatorStatistics process.ValidatorStatisticsProcessor + WhiteListHandlerInternal process.WhiteListHandler + WhiteListerVerifiedTxsInternal process.WhiteListHandler + func (pcs *ProcessComponentsStub) AccountsParser() genesis.AccountsParser + func (pcs *ProcessComponentsStub) BlackListHandler() process.TimeCacher + func (pcs *ProcessComponentsStub) BlockProcessor() process.BlockProcessor + func (pcs *ProcessComponentsStub) BlockTracker() process.BlockTracker + func (pcs *ProcessComponentsStub) BootStorer() process.BootStorer + func (pcs *ProcessComponentsStub) CheckSubcomponents() error + func (pcs *ProcessComponentsStub) Close() error + func (pcs *ProcessComponentsStub) Create() error + func (pcs *ProcessComponentsStub) CurrentEpochProvider() process.CurrentNetworkEpochProviderHandler + func (pcs *ProcessComponentsStub) EpochStartNotifier() factory.EpochStartNotifier + func (pcs *ProcessComponentsStub) EpochStartTrigger() epochStart.TriggerHandler + func (pcs *ProcessComponentsStub) FallbackHeaderValidator() process.FallbackHeaderValidator + func (pcs *ProcessComponentsStub) ForkDetector() process.ForkDetector + func (pcs *ProcessComponentsStub) HardforkTrigger() factory.HardforkTrigger + func (pcs *ProcessComponentsStub) HeaderConstructionValidator() process.HeaderConstructionValidator + func (pcs *ProcessComponentsStub) HeaderIntegrityVerifier() process.HeaderIntegrityVerifier + func (pcs *ProcessComponentsStub) HeaderSigVerifier() process.InterceptedHeaderSigVerifier + func (pcs *ProcessComponentsStub) HistoryRepository() dblookupext.HistoryRepository + func (pcs *ProcessComponentsStub) ImportStartHandler() update.ImportStartHandler + func (pcs *ProcessComponentsStub) InterceptorsContainer() process.InterceptorsContainer + func (pcs *ProcessComponentsStub) IsInterfaceNil() bool + func (pcs *ProcessComponentsStub) NodeRedundancyHandler() consensus.NodeRedundancyHandler + func (pcs *ProcessComponentsStub) NodesCoordinator() nodesCoordinator.NodesCoordinator + func (pcs *ProcessComponentsStub) PeerShardMapper() process.NetworkShardingCollector + func (pcs *ProcessComponentsStub) PendingMiniBlocksHandler() process.PendingMiniBlocksHandler + func (pcs *ProcessComponentsStub) ProcessedMiniBlocksTracker() process.ProcessedMiniBlocksTracker + func (pcs *ProcessComponentsStub) ReceiptsRepository() factory.ReceiptsRepository + func (pcs *ProcessComponentsStub) RequestHandler() process.RequestHandler + func (pcs *ProcessComponentsStub) RequestedItemsHandler() dataRetriever.RequestedItemsHandler + func (pcs *ProcessComponentsStub) ResolversFinder() dataRetriever.ResolversFinder + func (pcs *ProcessComponentsStub) RoundHandler() consensus.RoundHandler + func (pcs *ProcessComponentsStub) ScheduledTxsExecutionHandler() process.ScheduledTxsExecutionHandler + func (pcs *ProcessComponentsStub) ShardCoordinator() sharding.Coordinator + func (pcs *ProcessComponentsStub) String() string + func (pcs *ProcessComponentsStub) TransactionSimulatorProcessor() factory.TransactionSimulatorProcessor + func (pcs *ProcessComponentsStub) TxLogsProcessor() process.TransactionLogProcessorDatabase + func (pcs *ProcessComponentsStub) TxsSenderHandler() process.TxsSenderHandler + func (pcs *ProcessComponentsStub) ValidatorsProvider() process.ValidatorsProvider + func (pcs *ProcessComponentsStub) ValidatorsStatistics() process.ValidatorStatisticsProcessor + func (pcs *ProcessComponentsStub) WhiteListHandler() process.WhiteListHandler + func (pcs *ProcessComponentsStub) WhiteListerVerifiedTxs() process.WhiteListHandler + type PublicKeyMock struct + func (sspk *PublicKeyMock) IsInterfaceNil() bool + func (sspk *PublicKeyMock) Point() crypto.Point + func (sspk *PublicKeyMock) Suite() crypto.Suite + func (sspk *PublicKeyMock) ToByteArray() ([]byte, error) + type RaterMock struct + ComputeDecreaseProposerCalled func(shardId uint32, rating uint32, consecutiveMissedBlocks uint32) uint32 + ComputeDecreaseValidatorCalled func(shardId uint32, rating uint32) uint32 + ComputeIncreaseProposerCalled func(shardId uint32, rating uint32) uint32 + ComputeIncreaseValidatorCalled func(shardId uint32, rating uint32) uint32 + GetChanceCalled func(rating uint32) uint32 + GetRatingCalled func(string) uint32 + GetSignedBlocksThresholdCalled func() float32 + GetStartRatingCalled func() uint32 + RevertIncreaseProposerCalled func(shardId uint32, rating uint32, nrReverts uint32) uint32 + func (rm *RaterMock) ComputeDecreaseProposer(shardId uint32, currentRating uint32, consecutiveMisses uint32) uint32 + func (rm *RaterMock) ComputeDecreaseValidator(shardId uint32, currentRating uint32) uint32 + func (rm *RaterMock) ComputeIncreaseProposer(shardId uint32, currentRating uint32) uint32 + func (rm *RaterMock) ComputeIncreaseValidator(shardId uint32, currentRating uint32) uint32 + func (rm *RaterMock) GetChance(rating uint32) uint32 + func (rm *RaterMock) GetRating(pk string) uint32 + func (rm *RaterMock) GetSignedBlocksThreshold() float32 + func (rm *RaterMock) GetStartRating() uint32 + func (rm *RaterMock) IsInterfaceNil() bool + func (rm *RaterMock) RevertIncreaseValidator(shardId uint32, currentRating uint32, nrReverts uint32) uint32 + type RatingReaderMock struct + GetRatingCalled func(string) uint32 + GetRatingsCalled func([]string) map[string]uint32 + RatingsMap map[string]uint32 + func (rrm *RatingReaderMock) GetRating(pk string) uint32 + func (rrm *RatingReaderMock) IsInterfaceNil() bool + type RedundancyHandlerStub struct + AdjustInactivityIfNeededCalled func(selfPubKey string, consensusPubKeys []string, roundIndex int64) + IsMainMachineActiveCalled func() bool + IsRedundancyNodeCalled func() bool + ObserverPrivateKeyCalled func() crypto.PrivateKey + ResetInactivityIfNeededCalled func(selfPubKey string, consensusMsgPubKey string, consensusMsgPeerID core.PeerID) + func (rhs *RedundancyHandlerStub) AdjustInactivityIfNeeded(selfPubKey string, consensusPubKeys []string, roundIndex int64) + func (rhs *RedundancyHandlerStub) IsInterfaceNil() bool + func (rhs *RedundancyHandlerStub) IsMainMachineActive() bool + func (rhs *RedundancyHandlerStub) IsRedundancyNode() bool + func (rhs *RedundancyHandlerStub) ObserverPrivateKey() crypto.PrivateKey + func (rhs *RedundancyHandlerStub) ResetInactivityIfNeeded(selfPubKey string, consensusMsgPubKey string, consensusMsgPeerID core.PeerID) + type RequestedItemsHandlerStub struct + AddCalled func(key string) error + HasCalled func(key string) bool + SweepCalled func() + func (rihs *RequestedItemsHandlerStub) Add(key string) error + func (rihs *RequestedItemsHandlerStub) Has(key string) bool + func (rihs *RequestedItemsHandlerStub) IsInterfaceNil() bool + func (rihs *RequestedItemsHandlerStub) Sweep() + type ResolversContainerStub struct + AddCalled func(key string, val dataRetriever.Resolver) error + CloseCalled func() error + GetCalled func(key string) (dataRetriever.Resolver, error) + IterateCalled func(handler func(key string, resolver dataRetriever.Resolver) bool) + LenCalled func() int + RemoveCalled func(key string) + ReplaceCalled func(key string, val dataRetriever.Resolver) error + ResolverKeysCalled func() string + func (rcs *ResolversContainerStub) Add(key string, val dataRetriever.Resolver) error + func (rcs *ResolversContainerStub) AddMultiple(_ []string, _ []dataRetriever.Resolver) error + func (rcs *ResolversContainerStub) Close() error + func (rcs *ResolversContainerStub) Get(key string) (dataRetriever.Resolver, error) + func (rcs *ResolversContainerStub) IsInterfaceNil() bool + func (rcs *ResolversContainerStub) Iterate(handler func(key string, resolver dataRetriever.Resolver) bool) + func (rcs *ResolversContainerStub) Len() int + func (rcs *ResolversContainerStub) Remove(key string) + func (rcs *ResolversContainerStub) Replace(key string, val dataRetriever.Resolver) error + func (rcs *ResolversContainerStub) ResolverKeys() string + type ResolversFinderStub struct + CrossShardResolverCalled func(baseTopic string, crossShard uint32) (dataRetriever.Resolver, error) + IntraShardResolverCalled func(baseTopic string) (dataRetriever.Resolver, error) + MetaChainResolverCalled func(baseTopic string) (dataRetriever.Resolver, error) + MetaCrossShardResolverCalled func(baseTopic string, crossShard uint32) (dataRetriever.Resolver, error) + func (rfs *ResolversFinderStub) CrossShardResolver(baseTopic string, crossShard uint32) (dataRetriever.Resolver, error) + func (rfs *ResolversFinderStub) IntraShardResolver(baseTopic string) (dataRetriever.Resolver, error) + func (rfs *ResolversFinderStub) MetaChainResolver(baseTopic string) (dataRetriever.Resolver, error) + func (rfs *ResolversFinderStub) MetaCrossShardResolver(baseTopic string, crossShard uint32) (dataRetriever.Resolver, error) + type RoundHandlerMock struct + BeforeGenesisCalled func() bool + IndexField int64 + RemainingTimeField time.Duration + TimeDurationField time.Duration + TimeStampField time.Time + func (rm *RoundHandlerMock) Index() int64 + func (rm *RoundHandlerMock) IsInterfaceNil() bool + func (rm *RoundHandlerMock) RemainingTime(_ time.Time, _ time.Duration) time.Duration + func (rm *RoundHandlerMock) TimeDuration() time.Duration + func (rm *RoundHandlerMock) TimeStamp() time.Time + func (rm *RoundHandlerMock) UpdateRound(time.Time, time.Time) + func (rndm *RoundHandlerMock) BeforeGenesis() bool + type SCToProtocolStub struct + UpdateProtocolCalled func(body *block.Body, nonce uint64) error + func (s *SCToProtocolStub) IsInterfaceNil() bool + func (s *SCToProtocolStub) UpdateProtocol(body *block.Body, nonce uint64) error + type ScQueryStub struct + ComputeScCallGasLimitCalled func(tx *transaction.Transaction) (uint64, error) + ExecuteQueryCalled func(query *process.SCQuery) (*vmcommon.VMOutput, error) + func (s *ScQueryStub) ComputeScCallGasLimit(tx *transaction.Transaction) (uint64, error) + func (s *ScQueryStub) ExecuteQuery(query *process.SCQuery) (*vmcommon.VMOutput, error) + func (s *ScQueryStub) IsInterfaceNil() bool + type ShuffledOutHandlerStub struct + CurrentShardIDCalled func() uint32 + ProcessCalled func(newShardID uint32) error + RegisterHandlerCalled func(handler func(newShardID uint32)) + func (s *ShuffledOutHandlerStub) CurrentShardID() uint32 + func (s *ShuffledOutHandlerStub) IsInterfaceNil() bool + func (s *ShuffledOutHandlerStub) Process(newShardID uint32) error + func (s *ShuffledOutHandlerStub) RegisterHandler(handler func(newShardID uint32)) + type SignerMock struct + SignStub func(private crypto.PrivateKey, msg []byte) ([]byte, error) + VerifyStub func(public crypto.PublicKey, msg []byte, sig []byte) error + func (s *SignerMock) IsInterfaceNil() bool + func (s *SignerMock) Sign(private crypto.PrivateKey, msg []byte) ([]byte, error) + func (s *SignerMock) Verify(public crypto.PublicKey, msg []byte, sig []byte) error + type SmartContractParserStub struct + GetDeployedSCAddressesCalled func(scType string) (map[string]struct{}, error) + InitialSmartContractsCalled func() []genesis.InitialSmartContractHandler + InitialSmartContractsSplitOnOwnersShardsCalled func(shardCoordinator sharding.Coordinator) (map[uint32][]genesis.InitialSmartContractHandler, error) + func (scps *SmartContractParserStub) GetDeployedSCAddresses(scType string) (map[string]struct{}, error) + func (scps *SmartContractParserStub) InitialSmartContracts() []genesis.InitialSmartContractHandler + func (scps *SmartContractParserStub) InitialSmartContractsSplitOnOwnersShards(shardCoordinator sharding.Coordinator) (map[uint32][]genesis.InitialSmartContractHandler, error) + func (scps *SmartContractParserStub) IsInterfaceNil() bool + type SoftwareVersionCheckerMock struct + func (svcm *SoftwareVersionCheckerMock) Close() error + func (svcm *SoftwareVersionCheckerMock) IsInterfaceNil() bool + func (svcm *SoftwareVersionCheckerMock) StartCheckSoftwareVersion() + type StatusComponentsStub struct + AppStatusHandler core.AppStatusHandler + Outport outport.OutportHandler + SoftwareVersionCheck statistics.SoftwareVersionChecker + func (scs *StatusComponentsStub) CheckSubcomponents() error + func (scs *StatusComponentsStub) Close() error + func (scs *StatusComponentsStub) Create() error + func (scs *StatusComponentsStub) IsInterfaceNil() bool + func (scs *StatusComponentsStub) OutportHandler() outport.OutportHandler + func (scs *StatusComponentsStub) SoftwareVersionChecker() statistics.SoftwareVersionChecker + type StorageBootstrapperMock struct + LoadFromStorageCalled func() error + func (sbm *StorageBootstrapperMock) GetHighestBlockNonce() uint64 + func (sbm *StorageBootstrapperMock) IsInterfaceNil() bool + func (sbm *StorageBootstrapperMock) LoadFromStorage() error + type StorageManagerStub struct + DatabaseCalled func() common.DBWriteCacher + EnterPruningBufferingModeCalled func() + ExitPruningBufferingModeCalled func() + GetDbThatContainsHashCalled func([]byte) common.DBWriteCacher + GetSnapshotThatContainsHashCalled func(rootHash []byte) common.SnapshotDbHandler + IsInterfaceNilCalled func() bool + IsPruningBlockedCalled func() bool + IsPruningEnabledCalled func() bool + SetCheckpointCalled func([]byte) + TakeSnapshotCalled func([]byte) + func (sms *StorageManagerStub) Close() error + func (sms *StorageManagerStub) Database() common.DBWriteCacher + func (sms *StorageManagerStub) EnterPruningBufferingMode() + func (sms *StorageManagerStub) ExitPruningBufferingMode() + func (sms *StorageManagerStub) GetSnapshotDbBatchDelay() int + func (sms *StorageManagerStub) GetSnapshotThatContainsHash(d []byte) common.SnapshotDbHandler + func (sms *StorageManagerStub) IsInterfaceNil() bool + func (sms *StorageManagerStub) IsPruningBlocked() bool + func (sms *StorageManagerStub) IsPruningEnabled() bool + func (sms *StorageManagerStub) SetCheckpoint([]byte) + func (sms *StorageManagerStub) TakeSnapshot([]byte) + type SyncTimerMock struct + ClockOffsetCalled func() time.Duration + CurrentTimeCalled func() time.Time + func (stm *SyncTimerMock) ClockOffset() time.Duration + func (stm *SyncTimerMock) Close() error + func (stm *SyncTimerMock) CurrentTime() time.Time + func (stm *SyncTimerMock) FormattedCurrentTime() string + func (stm *SyncTimerMock) IsInterfaceNil() bool + func (stm *SyncTimerMock) StartSyncingTime() + type TopicAntiFloodStub struct + IncreaseLoadCalled func(pid core.PeerID, topic string, numMessages uint32) error + func (t *TopicAntiFloodStub) IncreaseLoad(pid core.PeerID, topic string, numMessages uint32) error + func (t *TopicAntiFloodStub) IsInterfaceNil() bool + func (t *TopicAntiFloodStub) ResetForNotRegisteredTopics() + func (t *TopicAntiFloodStub) ResetForTopic(_ string) + func (t *TopicAntiFloodStub) SetMaxMessagesForTopic(_ string, _ uint32) + 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, process.TransactionType) + 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) ComputeTransactionType(tx data.TransactionHandler) (process.TransactionType, process.TransactionType) + 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 TransactionSimulatorStub struct + ProcessTxCalled func(tx *transaction.Transaction) (*txSimData.SimulationResults, error) + func (tss *TransactionSimulatorStub) IsInterfaceNil() bool + func (tss *TransactionSimulatorStub) ProcessTx(tx *transaction.Transaction) (*txSimData.SimulationResults, error) + type TriesHolderStub struct + GetAllCalled func() []common.Trie + GetCalled func([]byte) common.Trie + PutCalled func([]byte, common.Trie) + RemoveCalled func([]byte, common.Trie) + ResetCalled func() + func (ths *TriesHolderStub) Get(key []byte) common.Trie + func (ths *TriesHolderStub) GetAll() []common.Trie + func (ths *TriesHolderStub) IsInterfaceNil() bool + func (ths *TriesHolderStub) Put(key []byte, trie common.Trie) + func (ths *TriesHolderStub) Replace(key []byte, trie common.Trie) + func (ths *TriesHolderStub) Reset() + type TxForCurrentBlockStub struct + AddTxCalled func(txHash []byte, tx data.TransactionHandler) + CleanCalled func() + GetTxCalled func(txHash []byte) (data.TransactionHandler, error) + func (t *TxForCurrentBlockStub) AddTx(txHash []byte, tx data.TransactionHandler) + func (t *TxForCurrentBlockStub) Clean() + func (t *TxForCurrentBlockStub) GetTx(txHash []byte) (data.TransactionHandler, error) + func (t *TxForCurrentBlockStub) IsInterfaceNil() bool + type TxLogProcessorMock struct + func (t *TxLogProcessorMock) Clean() + func (t *TxLogProcessorMock) EnableLogToBeSavedInCache() + func (t *TxLogProcessorMock) GetLogFromCache(_ []byte) (*data.LogData, bool) + func (t *TxLogProcessorMock) IsInterfaceNil() bool + type TxLogsProcessorStub struct + GetLogCalled func(txHash []byte) (data.LogHandler, error) + SaveLogCalled func(txHash []byte, tx data.TransactionHandler, vmLogs []*vmcommon.LogEntry) error + func (txls *TxLogsProcessorStub) Clean() + func (txls *TxLogsProcessorStub) GetAllCurrentLogs() []*data.LogData + func (txls *TxLogsProcessorStub) GetLog(txHash []byte) (data.LogHandler, error) + func (txls *TxLogsProcessorStub) IsInterfaceNil() bool + func (txls *TxLogsProcessorStub) SaveLog(txHash []byte, tx data.TransactionHandler, vmLogs []*vmcommon.LogEntry) error + type Uint64ByteSliceConverterMock struct + ToByteSliceCalled func(uint64) []byte + ToUint64Called func([]byte) (uint64, error) + func (u *Uint64ByteSliceConverterMock) IsInterfaceNil() bool + func (u *Uint64ByteSliceConverterMock) ToByteSlice(p uint64) []byte + func (u *Uint64ByteSliceConverterMock) ToUint64(p []byte) (uint64, error) + type UnitOpenerStub struct + func (u *UnitOpenerStub) GetMostRecentStorageUnit(_ config.DBConfig) (storage.Storer, error) + func (u *UnitOpenerStub) IsInterfaceNil() bool + func (u *UnitOpenerStub) OpenDB(_ config.DBConfig, _ uint32, _ uint32) (storage.Storer, error) + type VMContainerMock struct + AddCalled func(key []byte, val vmcommon.VMExecutionHandler) error + AddMultipleCalled func(keys [][]byte, preprocessors []vmcommon.VMExecutionHandler) error + GetCalled func(key []byte) (vmcommon.VMExecutionHandler, error) + KeysCalled func() [][]byte + LenCalled func() int + RemoveCalled func(key []byte) + ReplaceCalled func(key []byte, val vmcommon.VMExecutionHandler) error + func (V *VMContainerMock) Close() error + func (vmc *VMContainerMock) Add(key []byte, val vmcommon.VMExecutionHandler) error + func (vmc *VMContainerMock) AddMultiple(keys [][]byte, vms []vmcommon.VMExecutionHandler) error + func (vmc *VMContainerMock) Get(key []byte) (vmcommon.VMExecutionHandler, error) + func (vmc *VMContainerMock) IsInterfaceNil() bool + func (vmc *VMContainerMock) Keys() [][]byte + func (vmc *VMContainerMock) Len() int + func (vmc *VMContainerMock) Remove(key []byte) + func (vmc *VMContainerMock) Replace(key []byte, val vmcommon.VMExecutionHandler) error + type VMExecutionHandlerStub struct + GasScheduleChangeCalled func(gasSchedule map[string]map[string]uint64) + GetVersionCalled func() string + RunSmartContractCallCalled func(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error) + RunSmartContractCreateCalled func(input *vmcommon.ContractCreateInput) (*vmcommon.VMOutput, error) + func (vm *VMExecutionHandlerStub) Close() error + func (vm *VMExecutionHandlerStub) GasScheduleChange(gasSchedule map[string]map[string]uint64) + func (vm *VMExecutionHandlerStub) GetVersion() string + func (vm *VMExecutionHandlerStub) IsInterfaceNil() bool + func (vm *VMExecutionHandlerStub) RunSmartContractCall(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error) + func (vm *VMExecutionHandlerStub) RunSmartContractCreate(input *vmcommon.ContractCreateInput) (*vmcommon.VMOutput, error) + type ValidatorInfoSyncerStub struct + func (vip *ValidatorInfoSyncerStub) IsInterfaceNil() bool + func (vip *ValidatorInfoSyncerStub) SyncMiniBlocks(*block.MetaBlock) ([][]byte, data.BodyHandler, error) + type ValidatorStatisticsProcessorStub struct + CommitCalled func() ([]byte, error) + GetPeerAccountCalled func(address []byte) (state.PeerAccountHandler, error) + GetValidatorInfoForRootHashCalled func(rootHash []byte) (map[uint32][]*state.ValidatorInfo, error) + PeerAccountToValidatorInfoCalled func(peerAccount state.PeerAccountHandler) *state.ValidatorInfo + ProcessCalled func(validatorInfo data.ShardValidatorInfoHandler) error + ProcessRatingsEndOfEpochCalled func(validatorInfos map[uint32][]*state.ValidatorInfo, epoch uint32) error + ResetValidatorStatisticsAtNewEpochCalled func(vInfos map[uint32][]*state.ValidatorInfo) error + RevertPeerStateCalled func(header data.MetaHeaderHandler) error + RootHashCalled func() ([]byte, error) + SaveNodesCoordinatorUpdatesCalled func(epoch uint32) (bool, error) + UpdatePeerStateCalled func(header data.MetaHeaderHandler) ([]byte, error) + func (vsp *ValidatorStatisticsProcessorStub) Commit() ([]byte, error) + func (vsp *ValidatorStatisticsProcessorStub) DisplayRatings(_ uint32) + func (vsp *ValidatorStatisticsProcessorStub) GetExistingPeerAccount(address []byte) (state.PeerAccountHandler, error) + func (vsp *ValidatorStatisticsProcessorStub) GetValidatorInfoForRootHash(rootHash []byte) (map[uint32][]*state.ValidatorInfo, error) + func (vsp *ValidatorStatisticsProcessorStub) IsInterfaceNil() bool + func (vsp *ValidatorStatisticsProcessorStub) LastFinalizedRootHash() []byte + func (vsp *ValidatorStatisticsProcessorStub) PeerAccountToValidatorInfo(peerAccount state.PeerAccountHandler) *state.ValidatorInfo + func (vsp *ValidatorStatisticsProcessorStub) Process(validatorInfo data.ShardValidatorInfoHandler) error + func (vsp *ValidatorStatisticsProcessorStub) ProcessRatingsEndOfEpoch(validatorInfos map[uint32][]*state.ValidatorInfo, epoch uint32) error + func (vsp *ValidatorStatisticsProcessorStub) ResetValidatorStatisticsAtNewEpoch(vInfos map[uint32][]*state.ValidatorInfo) error + func (vsp *ValidatorStatisticsProcessorStub) RevertPeerState(header data.MetaHeaderHandler) error + func (vsp *ValidatorStatisticsProcessorStub) RootHash() ([]byte, error) + func (vsp *ValidatorStatisticsProcessorStub) SaveNodesCoordinatorUpdates(epoch uint32) (bool, error) + func (vsp *ValidatorStatisticsProcessorStub) SetLastFinalizedRootHash(_ []byte) + func (vsp *ValidatorStatisticsProcessorStub) UpdatePeerState(header data.MetaHeaderHandler, _ map[string]data.HeaderHandler) ([]byte, error) + type ValidatorsProviderStub struct + GetLatestValidatorsCalled func() map[string]*state.ValidatorApiResponse + func (vp *ValidatorsProviderStub) Close() error + func (vp *ValidatorsProviderStub) GetLatestValidators() map[string]*state.ValidatorApiResponse + func (vp *ValidatorsProviderStub) IsInterfaceNil() bool + type VmMachinesContainerFactoryMock struct + func (v *VmMachinesContainerFactoryMock) BlockChainHookImpl() process.BlockChainHookHandler + func (v *VmMachinesContainerFactoryMock) Close() error + func (v *VmMachinesContainerFactoryMock) Create() (process.VirtualMachinesContainer, error) + func (v *VmMachinesContainerFactoryMock) IsInterfaceNil() bool + type WatchdogMock struct + func (w *WatchdogMock) IsInterfaceNil() bool + func (w *WatchdogMock) Reset(alarmID string) + func (w *WatchdogMock) Set(callback func(alarmID string), duration time.Duration, alarmID string) + func (w *WatchdogMock) SetDefault(duration time.Duration, alarmID string) + func (w *WatchdogMock) Stop(alarmID string)