Documentation ¶
Index ¶
- func NewCountingDB() *countingDB
- func NewMultiShardsCoordinatorMock(nrShard uint32) *multipleShardsCoordinatorMock
- func NewNetworkShardingCollectorMock() *networkShardingCollectorMock
- func NewNilOutport() *nilOutport
- func NewNodesHandlerMock(initialNodesSetup genesis.InitialNodesHandler) (*nodesHandlerMock, error)
- type AccountsDBSyncerStub
- type AccountsFactoryStub
- type AccountsParserStub
- func (aps *AccountsParserStub) GetInitialAccountsForDelegated(addressBytes []byte) []genesis.InitialAccountHandler
- func (aps *AccountsParserStub) GetTotalStakedForDelegationAddress(delegationAddress string) *big.Int
- func (aps *AccountsParserStub) InitialAccounts() []genesis.InitialAccountHandler
- func (aps *AccountsParserStub) InitialAccountsSplitOnAddressesShards(shardCoordinator sharding.Coordinator) (map[uint32][]genesis.InitialAccountHandler, error)
- func (aps *AccountsParserStub) InitialAccountsSplitOnDelegationAddressesShards(shardCoordinator sharding.Coordinator) (map[uint32][]genesis.InitialAccountHandler, error)
- func (aps *AccountsParserStub) IsInterfaceNil() bool
- type BlackListHandlerStub
- type BlockChainHookHandlerMock
- func (e *BlockChainHookHandlerMock) DeleteCompiledCode(codeHash []byte)
- func (e *BlockChainHookHandlerMock) IsInterfaceNil() bool
- func (e *BlockChainHookHandlerMock) IsPayable(address []byte) (bool, error)
- func (e *BlockChainHookHandlerMock) NewAddress(creatorAddress []byte, creatorNonce uint64, vmType []byte) ([]byte, error)
- func (e *BlockChainHookHandlerMock) ProcessBuiltInFunction(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error)
- func (e *BlockChainHookHandlerMock) SetCurrentHeader(hdr data.HeaderHandler)
- type BlockChainMock
- func (bc *BlockChainMock) CreateNewHeader() data.HeaderHandler
- func (bc *BlockChainMock) GetCurrentBlockHeader() data.HeaderHandler
- func (bc *BlockChainMock) GetCurrentBlockHeaderHash() []byte
- func (bc *BlockChainMock) GetGenesisHeader() data.HeaderHandler
- func (bc *BlockChainMock) GetGenesisHeaderHash() []byte
- func (bc *BlockChainMock) IsInterfaceNil() bool
- func (bc *BlockChainMock) SetCurrentBlockHeader(header data.HeaderHandler) error
- func (bc *BlockChainMock) SetCurrentBlockHeaderHash(hash []byte)
- func (bc *BlockChainMock) SetGenesisHeader(genesisBlock data.HeaderHandler) error
- func (bc *BlockChainMock) SetGenesisHeaderHash(hash []byte)
- type BlockProcessorMock
- func (bpm *BlockProcessorMock) AddLastNotarizedHdr(shardId uint32, processedHdr data.HeaderHandler)
- func (bpm *BlockProcessorMock) ApplyProcessedMiniBlocks(_ *processedMb.ProcessedMiniBlockTracker)
- 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
- 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) PruneStateOnRollback(currHeader data.HeaderHandler, prevHeader data.HeaderHandler)
- func (bpm *BlockProcessorMock) RestoreBlockIntoPools(header data.HeaderHandler, body data.BodyHandler) error
- func (bpm *BlockProcessorMock) RestoreLastNotarizedHrdsToGenesis()
- func (bpm *BlockProcessorMock) RevertAccountState(header data.HeaderHandler)
- func (bpm *BlockProcessorMock) RevertIndexedBlock(header data.HeaderHandler)
- func (bpm *BlockProcessorMock) RevertStateToBlock(header data.HeaderHandler) error
- func (bpm *BlockProcessorMock) SetNumProcessedObj(_ uint64)
- type BlockSizeThrottlerStub
- 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
- 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
- type BoostrapStorerMock
- 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
- type ChainStorerMock
- 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
- 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) 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() sharding.NodesShuffler
- func (ccs *CoreComponentsStub) PathHandler() storage.PathManagerHandler
- func (ccs *CoreComponentsStub) Rater() sharding.PeerAccountListAndRatingHandler
- func (ccs *CoreComponentsStub) RatingsData() process.RatingsInfoHandler
- func (ccs *CoreComponentsStub) RoundHandler() consensus.RoundHandler
- 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
- 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
- type DataComponentsStub
- 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
- 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) DoBulkRemove(index string, hashes []string) error
- func (dws *DatabaseWriterStub) DoBulkRequest(buff *bytes.Buffer, index string) error
- func (dws *DatabaseWriterStub) DoMultiGet(ids []string, index string, withSource bool, res interface{}) error
- func (dws *DatabaseWriterStub) DoRequest(req *esapi.IndexRequest) error
- func (dws *DatabaseWriterStub) IsInterfaceNil() bool
- type EpochEconomicsStub
- type EpochNotifierStub
- type EpochRewardsCreatorStub
- func (e *EpochRewardsCreatorStub) CreateMarshalizedData(body *block.Body) map[string][][]byte
- func (e *EpochRewardsCreatorStub) CreateRewardsMiniBlocks(metaBlock *block.MetaBlock, validatorsInfo map[uint32][]*state.ValidatorInfo, ...) (block.MiniBlockSlice, error)
- func (e *EpochRewardsCreatorStub) DeleteTxsFromStorage(metaBlock *block.MetaBlock, 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 *block.MetaBlock, body *block.Body)
- func (e *EpochRewardsCreatorStub) SaveTxBlockToStorage(metaBlock *block.MetaBlock, body *block.Body)
- func (e *EpochRewardsCreatorStub) VerifyRewardsMiniBlocks(metaBlock *block.MetaBlock, validatorsInfo map[uint32][]*state.ValidatorInfo, ...) error
- type EpochStartDataCreatorStub
- type EpochStartNotifierStub
- 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
- 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
- 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
- func (e *EpochValidatorInfoCreatorStub) CreateValidatorInfoMiniBlocks(validatorInfo map[uint32][]*state.ValidatorInfo) (block.MiniBlockSlice, error)
- func (e *EpochValidatorInfoCreatorStub) DeleteValidatorInfoBlocksFromStorage(metaBlock *block.MetaBlock)
- func (e *EpochValidatorInfoCreatorStub) IsInterfaceNil() bool
- func (e *EpochValidatorInfoCreatorStub) RemoveBlockDataFromPools(metaBlock *block.MetaBlock, body *block.Body)
- func (e *EpochValidatorInfoCreatorStub) SaveValidatorInfoBlocksToStorage(metaBlock *block.MetaBlock, body *block.Body)
- func (e *EpochValidatorInfoCreatorStub) VerifyValidatorInfoMiniBlocks(miniblocks []*block.MiniBlock, ...) error
- type ExportFactoryHandlerStub
- type ExportHandlerStub
- type FeeHandlerStub
- 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) 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
- 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
- func (ghm *GasHandlerMock) ComputeGasConsumedByMiniBlock(miniBlock *block.MiniBlock, mapHashTx map[string]data.TransactionHandler) (uint64, uint64, error)
- func (ghm *GasHandlerMock) ComputeGasConsumedByTx(txSenderShardId uint32, txReceiverShardId uint32, ...) (uint64, uint64, error)
- func (ghm *GasHandlerMock) GasConsumed(hash []byte) uint64
- func (ghm *GasHandlerMock) GasPenalized(hash []byte) uint64
- func (ghm *GasHandlerMock) GasRefunded(hash []byte) uint64
- func (ghm *GasHandlerMock) Init()
- func (ghm *GasHandlerMock) IsInterfaceNil() bool
- func (ghm *GasHandlerMock) RemoveGasConsumed(hashes [][]byte)
- func (ghm *GasHandlerMock) RemoveGasPenalized(hashes [][]byte)
- func (ghm *GasHandlerMock) RemoveGasRefunded(hashes [][]byte)
- func (ghm *GasHandlerMock) SetGasConsumed(gasConsumed uint64, hash []byte)
- func (ghm *GasHandlerMock) SetGasPenalized(gasPenalized uint64, hash []byte)
- func (ghm *GasHandlerMock) SetGasRefunded(gasRefunded uint64, hash []byte)
- func (ghm *GasHandlerMock) TotalGasConsumed() uint64
- func (ghm *GasHandlerMock) TotalGasPenalized() uint64
- func (ghm *GasHandlerMock) TotalGasRefunded() uint64
- type 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 HardforkTriggerStub
- func (hts *HardforkTriggerStub) AddCloser(closer update.Closer) error
- func (hts *HardforkTriggerStub) CreateData() []byte
- func (hts *HardforkTriggerStub) IsInterfaceNil() bool
- func (hts *HardforkTriggerStub) IsSelfTrigger() bool
- func (hts *HardforkTriggerStub) NotifyTriggerReceived() <-chan struct{}
- func (hts *HardforkTriggerStub) RecordedTriggerMessage() ([]byte, bool)
- func (hts *HardforkTriggerStub) Trigger(epoch uint32, withEarlyEndOfEpoch bool) error
- func (hts *HardforkTriggerStub) TriggerReceived(payload []byte, data []byte, pkBytes []byte) (bool, error)
- type HeaderIntegrityVerifierStub
- type HeaderResolverStub
- 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
- 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
- type HeadersCacherStub
- 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
- 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
- type HeartbeatMonitorStub
- 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
- type HeartbeatStorerStub
- 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
- 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
- func (ipcm *InterimProcessorContainerMock) Add(key block.Type, val process.IntermediateTransactionHandler) error
- func (ipcm *InterimProcessorContainerMock) AddMultiple(keys []block.Type, preprocessors []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(key block.Type)
- func (ipcm *InterimProcessorContainerMock) Replace(key block.Type, val process.IntermediateTransactionHandler) error
- type IntermediateTransactionHandlerMock
- 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()
- func (ith *IntermediateTransactionHandlerMock) IsInterfaceNil() bool
- func (ith *IntermediateTransactionHandlerMock) RemoveProcessedResults()
- func (ith *IntermediateTransactionHandlerMock) SaveCurrentIntermediateTxToStorage() error
- func (ith *IntermediateTransactionHandlerMock) VerifyInterMiniBlocks(body *block.Body) error
- type KeyGenMock
- 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
- func (l *LatestStorageDataProviderStub) Get() (storage.LatestDataFromStorage, error)
- func (l *LatestStorageDataProviderStub) GetParentDirAndLastEpoch() (string, uint32, error)
- func (l *LatestStorageDataProviderStub) GetShardsFromDirectory(path string) ([]string, error)
- func (l *LatestStorageDataProviderStub) IsInterfaceNil() bool
- type ListIndexUpdaterStub
- type MessageSignVerifierMock
- type MiniBlocksProviderStub
- type MiniBlocksResolverStub
- 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
- 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) Init() error
- func (s MockDB) IsInterfaceNil() bool
- func (MockDB) Put(_, _ []byte) error
- func (MockDB) RangeKeys(_ func(key []byte, val []byte) bool)
- func (MockDB) Remove(_ []byte) error
- type NetworkComponentsStub
- 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) PreferredPeersHolderHandler() factory.PreferredPeersHolderHandler
- func (ncs *NetworkComponentsStub) PubKeyCacher() process.TimeCacher
- func (ncs *NetworkComponentsStub) String() string
- type NilAntifloodHandler
- 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
- type NodeShufflerMock
- type NodesCoordinatorCacheStub
- type NodesCoordinatorMock
- func (ncm *NodesCoordinatorMock) ComputeAdditionalLeaving([]*state.ShardValidatorInfo) (map[uint32][]sharding.Validator, error)
- func (ncm *NodesCoordinatorMock) ComputeConsensusGroup(randomness []byte, round uint64, shardId uint32, epoch uint32) (validatorsGroup []sharding.Validator, err error)
- func (ncm *NodesCoordinatorMock) ConsensusGroupSize(uint32) int
- func (ncm *NodesCoordinatorMock) GetAllEligibleValidatorsPublicKeys(_ uint32) (map[uint32][][]byte, error)
- func (ncm *NodesCoordinatorMock) GetAllLeavingValidatorsPublicKeys(_ uint32) (map[uint32][][]byte, error)
- func (ncm *NodesCoordinatorMock) GetAllWaitingValidatorsPublicKeys(_ uint32) (map[uint32][][]byte, error)
- func (ncm *NodesCoordinatorMock) GetChance(uint32) uint32
- func (ncm *NodesCoordinatorMock) GetConsensusValidatorsPublicKeys(randomness []byte, round uint64, shardId uint32, epoch uint32) ([]string, error)
- func (ncm *NodesCoordinatorMock) GetConsensusWhitelistedNodes(_ uint32) (map[string]struct{}, error)
- func (ncm *NodesCoordinatorMock) GetNumTotalEligible() uint64
- func (ncm *NodesCoordinatorMock) GetOwnPublicKey() []byte
- func (ncm *NodesCoordinatorMock) GetSavedStateKey() []byte
- func (ncm *NodesCoordinatorMock) GetSelectedPublicKeys(_ []byte, _ uint32, _ uint32) ([]string, error)
- func (ncm *NodesCoordinatorMock) GetValidatorWithPublicKey(publicKey []byte) (sharding.Validator, uint32, error)
- func (ncm *NodesCoordinatorMock) GetValidatorsIndexes(_ []string, _ uint32) ([]uint64, error)
- func (ncm *NodesCoordinatorMock) IsInterfaceNil() bool
- func (ncm *NodesCoordinatorMock) LoadState(_ []byte) error
- func (ncm *NodesCoordinatorMock) SetNodesPerShards(_ map[uint32][]sharding.Validator, _ map[uint32][]sharding.Validator, _ uint32) error
- func (ncm *NodesCoordinatorMock) ShardIdForEpoch(_ uint32) (uint32, error)
- func (ncm *NodesCoordinatorMock) ShuffleOutForEpoch(_ uint32)
- func (ncm *NodesCoordinatorMock) ValidatorsWeights(validators []sharding.Validator) ([]uint32, error)
- type NodesSetupStub
- func (n *NodesSetupStub) AllInitialNodes() []sharding.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][]sharding.GenesisNodeInfoHandler, ...)
- func (n *NodesSetupStub) InitialNodesInfoForShard(shardId uint32) ([]sharding.GenesisNodeInfoHandler, []sharding.GenesisNodeInfoHandler, error)
- 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
- 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
- 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
- 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
- type PeerDenialEvaluatorStub
- type PeerHonestyHandlerStub
- type PeerShardMapperStub
- type PeerSignatureHandler
- type PeerTypeProviderStub
- type PendingMiniBlocksHandlerStub
- 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
- type ProcessComponentsStub
- 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) 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() sharding.NodesCoordinator
- func (pcs *ProcessComponentsStub) PeerShardMapper() process.NetworkShardingCollector
- func (pcs *ProcessComponentsStub) PendingMiniBlocksHandler() process.PendingMiniBlocksHandler
- 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) ShardCoordinator() sharding.Coordinator
- func (pcs *ProcessComponentsStub) String() string
- func (pcs *ProcessComponentsStub) TransactionSimulatorProcessor() factory.TransactionSimulatorProcessor
- func (pcs *ProcessComponentsStub) TxLogsProcessor() process.TransactionLogProcessorDatabase
- 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
- type RaterMock
- 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
- type RedundancyHandlerStub
- 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
- type ResolversContainerStub
- 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
- 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
- func (rndm *RoundHandlerMock) BeforeGenesis() bool
- 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)
- type SCToProtocolStub
- type ScQueryStub
- type ShuffledOutHandlerStub
- type SignerMock
- type SmartContractParserStub
- 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
- type StatusComponentsStub
- 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 StatusMetricsStub
- func (sms *StatusMetricsStub) ConfigMetrics() map[string]interface{}
- func (sms *StatusMetricsStub) EconomicsMetrics() map[string]interface{}
- func (sms *StatusMetricsStub) EnableEpochsMetrics() map[string]interface{}
- func (sms *StatusMetricsStub) IsInterfaceNil() bool
- func (sms *StatusMetricsStub) NetworkMetrics() map[string]interface{}
- func (sms *StatusMetricsStub) StatusMetricsMapWithoutP2P() map[string]interface{}
- func (sms *StatusMetricsStub) StatusMetricsWithoutP2PPrometheusString() string
- func (sms *StatusMetricsStub) StatusP2pMetricsMap() map[string]interface{}
- type StorageBootstrapperMock
- type StorageManagerStub
- 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 StorerMock
- func (sm *StorerMock) ClearCache()
- func (sm *StorerMock) Close() error
- func (sm *StorerMock) DestroyUnit() error
- func (sm *StorerMock) Get(key []byte) ([]byte, error)
- func (sm *StorerMock) GetBulkFromEpoch(keys [][]byte, _ uint32) (map[string][]byte, error)
- func (sm *StorerMock) GetFromEpoch(key []byte, _ uint32) ([]byte, error)
- func (sm *StorerMock) GetOldestEpoch() (uint32, error)
- func (sm *StorerMock) Has(_ []byte) error
- func (sm *StorerMock) IsInterfaceNil() bool
- func (sm *StorerMock) Put(key, data []byte) error
- func (sm *StorerMock) PutInEpoch(key, data []byte, _ uint32) error
- func (sm *StorerMock) RangeKeys(_ func(key []byte, val []byte) bool)
- func (sm *StorerMock) Remove(_ []byte) error
- func (sm *StorerMock) SearchFirst(_ []byte) ([]byte, error)
- type SyncTimerMock
- type TimeCacheStub
- type TopicAntiFloodStub
- 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
- 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) CreateMarshalizedReceipts() ([]byte, error)
- func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessCrossShardTransactionsDstMe(header data.HeaderHandler, processedMiniBlocksHashes map[string]struct{}, ...) (block.MiniBlockSlice, uint32, bool, error)
- func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessTransactionsFromMe(haveTime func() bool) block.MiniBlockSlice
- func (tcm *TransactionCoordinatorMock) CreatePostProcessMiniBlocks() block.MiniBlockSlice
- func (tcm *TransactionCoordinatorMock) CreateReceiptsHash() ([]byte, error)
- func (tcm *TransactionCoordinatorMock) GetAllCurrentLogs() map[string]data.LogHandler
- func (tcm *TransactionCoordinatorMock) GetAllCurrentUsedTxs(blockType block.Type) map[string]data.TransactionHandler
- func (tcm *TransactionCoordinatorMock) IsDataPreparedForProcessing(haveTime func() time.Duration) error
- func (tcm *TransactionCoordinatorMock) IsInterfaceNil() bool
- func (tcm *TransactionCoordinatorMock) ProcessBlockTransaction(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) error
- func (tcm *TransactionCoordinatorMock) VerifyCreatedBlockTransactions(hdr data.HeaderHandler, body *block.Body) error
- func (tcm *TransactionCoordinatorMock) VerifyCreatedMiniBlocks(hdr data.HeaderHandler, body *block.Body) error
- type TransactionSimulatorStub
- type TriesHolderStub
- 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
- type TxLogProcessorMock
- type TxLogsProcessorStub
- func (txls *TxLogsProcessorStub) Clean()
- func (txls *TxLogsProcessorStub) GetAllCurrentLogs() map[string]data.LogHandler
- 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
- type UnitOpenerStub
- type VMContainerMock
- func (vmc *VMContainerMock) Add(key []byte, val vmcommon.VMExecutionHandler) error
- func (vmc *VMContainerMock) AddMultiple(keys [][]byte, vms []vmcommon.VMExecutionHandler) error
- func (V *VMContainerMock) Close() 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
- 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
- type ValidatorStatisticsProcessorStub
- 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.HeaderHandler) 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.HeaderHandler, _ map[string]data.HeaderHandler) ([]byte, error)
- type ValidatorsProviderStub
- type VmMachinesContainerFactoryMock
- 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
- 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)
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
func NewCountingDB ¶
func NewCountingDB() *countingDB
NewCountingDB returns a new instance of countingDB
func NewMultiShardsCoordinatorMock ¶
func NewMultiShardsCoordinatorMock(nrShard uint32) *multipleShardsCoordinatorMock
NewMultiShardsCoordinatorMock -
func NewNetworkShardingCollectorMock ¶
func NewNetworkShardingCollectorMock() *networkShardingCollectorMock
NewNetworkShardingCollectorMock -
func NewNodesHandlerMock ¶ added in v1.0.115
func NewNodesHandlerMock( initialNodesSetup genesis.InitialNodesHandler, ) (*nodesHandlerMock, error)
NewNodesHandlerMock -
Types ¶
type AccountsDBSyncerStub ¶ added in v1.2.4
type AccountsDBSyncerStub struct { GetSyncedTriesCalled func() map[string]common.Trie SyncAccountsCalled func(rootHash []byte) error }
AccountsDBSyncerStub -
func (*AccountsDBSyncerStub) GetSyncedTries ¶ added in v1.2.4
func (a *AccountsDBSyncerStub) GetSyncedTries() map[string]common.Trie
GetSyncedTries -
func (*AccountsDBSyncerStub) IsInterfaceNil ¶ added in v1.2.4
func (a *AccountsDBSyncerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*AccountsDBSyncerStub) SyncAccounts ¶ added in v1.2.4
func (a *AccountsDBSyncerStub) SyncAccounts(rootHash []byte) error
SyncAccounts -
type AccountsFactoryStub ¶
type AccountsFactoryStub struct {
CreateAccountCalled func(address []byte) (vmcommon.AccountHandler, error)
}
AccountsFactoryStub -
func (*AccountsFactoryStub) CreateAccount ¶
func (afs *AccountsFactoryStub) CreateAccount(address []byte) (vmcommon.AccountHandler, error)
CreateAccount -
func (*AccountsFactoryStub) IsInterfaceNil ¶
func (afs *AccountsFactoryStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type AccountsParserStub ¶ added in v1.0.115
type AccountsParserStub struct { InitialAccountsSplitOnAddressesShardsCalled func(shardCoordinator sharding.Coordinator) (map[uint32][]genesis.InitialAccountHandler, error) InitialAccountsSplitOnDelegationAddressesShardsCalled func(shardCoordinator sharding.Coordinator) (map[uint32][]genesis.InitialAccountHandler, error) InitialAccountsCalled func() []genesis.InitialAccountHandler GetTotalStakedForDelegationAddressCalled func(delegationAddress string) *big.Int GetInitialAccountsForDelegatedCalled func(addressBytes []byte) []genesis.InitialAccountHandler }
AccountsParserStub -
func (*AccountsParserStub) GetInitialAccountsForDelegated ¶ added in v1.0.115
func (aps *AccountsParserStub) GetInitialAccountsForDelegated(addressBytes []byte) []genesis.InitialAccountHandler
GetInitialAccountsForDelegated -
func (*AccountsParserStub) GetTotalStakedForDelegationAddress ¶ added in v1.0.115
func (aps *AccountsParserStub) GetTotalStakedForDelegationAddress(delegationAddress string) *big.Int
GetTotalStakedForDelegationAddress -
func (*AccountsParserStub) InitialAccounts ¶ added in v1.0.115
func (aps *AccountsParserStub) InitialAccounts() []genesis.InitialAccountHandler
InitialAccounts -
func (*AccountsParserStub) InitialAccountsSplitOnAddressesShards ¶ added in v1.0.115
func (aps *AccountsParserStub) InitialAccountsSplitOnAddressesShards(shardCoordinator sharding.Coordinator) (map[uint32][]genesis.InitialAccountHandler, error)
InitialAccountsSplitOnAddressesShards -
func (*AccountsParserStub) InitialAccountsSplitOnDelegationAddressesShards ¶ added in v1.0.115
func (aps *AccountsParserStub) InitialAccountsSplitOnDelegationAddressesShards(shardCoordinator sharding.Coordinator) (map[uint32][]genesis.InitialAccountHandler, error)
InitialAccountsSplitOnDelegationAddressesShards -
func (*AccountsParserStub) IsInterfaceNil ¶ added in v1.0.115
func (aps *AccountsParserStub) IsInterfaceNil() bool
IsInterfaceNil -
type BlackListHandlerStub ¶
type BlackListHandlerStub struct { AddCalled func(key string) error AddWithSpanCalled func(key string, span time.Duration) error HasCalled func(key string) bool SweepCalled func() }
BlackListHandlerStub -
func (*BlackListHandlerStub) AddWithSpan ¶ added in v1.0.120
func (blhs *BlackListHandlerStub) AddWithSpan(key string, span time.Duration) error
AddWithSpan -
func (*BlackListHandlerStub) IsInterfaceNil ¶
func (blhs *BlackListHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
type BlockChainHookHandlerMock ¶
type BlockChainHookHandlerMock struct { SetCurrentHeaderCalled func(hdr data.HeaderHandler) NewAddressCalled func(creatorAddress []byte, creatorNonce uint64, vmType []byte) ([]byte, error) IsPayableCalled func(address []byte) (bool, error) DeleteCompiledCodeCalled func(codeHash []byte) ProcessBuiltInFunctionCalled func(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error) }
BlockChainHookHandlerMock -
func (*BlockChainHookHandlerMock) DeleteCompiledCode ¶ added in v1.1.12
func (e *BlockChainHookHandlerMock) DeleteCompiledCode(codeHash []byte)
DeleteCompiledCode -
func (*BlockChainHookHandlerMock) IsInterfaceNil ¶
func (e *BlockChainHookHandlerMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*BlockChainHookHandlerMock) IsPayable ¶ added in v1.0.147
func (e *BlockChainHookHandlerMock) IsPayable(address []byte) (bool, error)
IsPayable -
func (*BlockChainHookHandlerMock) NewAddress ¶ added in v1.0.115
func (e *BlockChainHookHandlerMock) NewAddress(creatorAddress []byte, creatorNonce uint64, vmType []byte) ([]byte, error)
NewAddress -
func (*BlockChainHookHandlerMock) ProcessBuiltInFunction ¶ added in v1.2.4
func (e *BlockChainHookHandlerMock) ProcessBuiltInFunction(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error)
ProcessBuiltInFunction -
func (*BlockChainHookHandlerMock) SetCurrentHeader ¶
func (e *BlockChainHookHandlerMock) SetCurrentHeader(hdr data.HeaderHandler)
SetCurrentHeader -
type BlockChainMock ¶
type BlockChainMock struct { GetGenesisHeaderCalled func() data.HeaderHandler SetGenesisHeaderCalled func(handler data.HeaderHandler) error GetGenesisHeaderHashCalled func() []byte SetGenesisHeaderHashCalled func([]byte) GetCurrentBlockHeaderCalled func() data.HeaderHandler SetCurrentBlockHeaderCalled func(data.HeaderHandler) error GetCurrentBlockHeaderHashCalled func() []byte SetCurrentBlockHeaderHashCalled func([]byte) GetLocalHeightCalled func() int64 SetLocalHeightCalled func(int64) GetNetworkHeightCalled func() int64 SetNetworkHeightCalled func(int64) HasBadBlockCalled func([]byte) bool PutBadBlockCalled func([]byte) CreateNewHeaderCalled func() data.HeaderHandler }
BlockChainMock is a mock implementation of the blockchain interface
func (*BlockChainMock) CreateNewHeader ¶
func (bc *BlockChainMock) CreateNewHeader() data.HeaderHandler
CreateNewHeader -
func (*BlockChainMock) GetCurrentBlockHeader ¶
func (bc *BlockChainMock) GetCurrentBlockHeader() data.HeaderHandler
GetCurrentBlockHeader returns current block header pointer
func (*BlockChainMock) GetCurrentBlockHeaderHash ¶
func (bc *BlockChainMock) GetCurrentBlockHeaderHash() []byte
GetCurrentBlockHeaderHash returns the current block header hash
func (*BlockChainMock) GetGenesisHeader ¶
func (bc *BlockChainMock) GetGenesisHeader() data.HeaderHandler
GetGenesisHeader returns the genesis block header pointer
func (*BlockChainMock) GetGenesisHeaderHash ¶
func (bc *BlockChainMock) GetGenesisHeaderHash() []byte
GetGenesisHeaderHash returns the genesis block header hash
func (*BlockChainMock) IsInterfaceNil ¶
func (bc *BlockChainMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*BlockChainMock) SetCurrentBlockHeader ¶
func (bc *BlockChainMock) SetCurrentBlockHeader(header data.HeaderHandler) error
SetCurrentBlockHeader sets current block header pointer
func (*BlockChainMock) SetCurrentBlockHeaderHash ¶
func (bc *BlockChainMock) SetCurrentBlockHeaderHash(hash []byte)
SetCurrentBlockHeaderHash returns the current block header hash
func (*BlockChainMock) SetGenesisHeader ¶
func (bc *BlockChainMock) SetGenesisHeader(genesisBlock data.HeaderHandler) error
SetGenesisHeader sets the genesis block header pointer
func (*BlockChainMock) SetGenesisHeaderHash ¶
func (bc *BlockChainMock) SetGenesisHeaderHash(hash []byte)
SetGenesisHeaderHash sets the genesis block header hash
type BlockProcessorMock ¶
type BlockProcessorMock struct { NrCommitBlockCalled uint32 Marshalizer marshal.Marshalizer ProcessBlockCalled func(header data.HeaderHandler, body data.BodyHandler, haveTime func() time.Duration) error CommitBlockCalled func(header data.HeaderHandler, body data.BodyHandler) error RevertAccountStateCalled func(header data.HeaderHandler) CreateBlockCalled func(initialHdrData data.HeaderHandler, haveTime func() bool) (data.HeaderHandler, data.BodyHandler, error) RestoreBlockIntoPoolsCalled func(header data.HeaderHandler, body data.BodyHandler) error MarshalizedDataToBroadcastCalled func(header data.HeaderHandler, body data.BodyHandler) (map[uint32][]byte, map[string][][]byte, error) DecodeBlockBodyCalled func(dta []byte) data.BodyHandler DecodeBlockHeaderCalled func(dta []byte) data.HeaderHandler AddLastNotarizedHdrCalled func(shardId uint32, processedHdr data.HeaderHandler) CreateNewHeaderCalled func(round uint64, nonce uint64) data.HeaderHandler PruneStateOnRollbackCalled func(currHeader data.HeaderHandler, prevHeader data.HeaderHandler) RestoreLastNotarizedHrdsToGenesisCalled func() RevertStateToBlockCalled func(header data.HeaderHandler) error RevertIndexedBlockCalled func(header data.HeaderHandler) }
BlockProcessorMock mocks the implementation for a blockProcessor
func (*BlockProcessorMock) AddLastNotarizedHdr ¶
func (bpm *BlockProcessorMock) AddLastNotarizedHdr(shardId uint32, processedHdr data.HeaderHandler)
AddLastNotarizedHdr -
func (*BlockProcessorMock) ApplyProcessedMiniBlocks ¶
func (bpm *BlockProcessorMock) ApplyProcessedMiniBlocks(_ *processedMb.ProcessedMiniBlockTracker)
ApplyProcessedMiniBlocks -
func (*BlockProcessorMock) Close ¶ added in v1.2.0
func (bpm *BlockProcessorMock) Close() error
Close -
func (*BlockProcessorMock) CommitBlock ¶
func (bpm *BlockProcessorMock) CommitBlock(header data.HeaderHandler, body data.BodyHandler) error
CommitBlock mocks the commit of a block
func (*BlockProcessorMock) CreateBlock ¶
func (bpm *BlockProcessorMock) CreateBlock(initialHdrData data.HeaderHandler, haveTime func() bool) (data.HeaderHandler, data.BodyHandler, error)
CreateBlock -
func (*BlockProcessorMock) CreateNewHeader ¶
func (bpm *BlockProcessorMock) CreateNewHeader(round uint64, nonce uint64) data.HeaderHandler
CreateNewHeader -
func (*BlockProcessorMock) DecodeBlockBody ¶
func (bpm *BlockProcessorMock) DecodeBlockBody(dta []byte) data.BodyHandler
DecodeBlockBody method decodes block body from a given byte array
func (*BlockProcessorMock) DecodeBlockHeader ¶
func (bpm *BlockProcessorMock) DecodeBlockHeader(dta []byte) data.HeaderHandler
DecodeBlockHeader method decodes block header from a given byte array
func (*BlockProcessorMock) IsInterfaceNil ¶
func (bpm *BlockProcessorMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*BlockProcessorMock) MarshalizedDataToBroadcast ¶
func (bpm *BlockProcessorMock) MarshalizedDataToBroadcast(header data.HeaderHandler, body data.BodyHandler) (map[uint32][]byte, map[string][][]byte, error)
MarshalizedDataToBroadcast -
func (*BlockProcessorMock) ProcessBlock ¶
func (bpm *BlockProcessorMock) ProcessBlock(header data.HeaderHandler, body data.BodyHandler, haveTime func() time.Duration) error
ProcessBlock mocks pocessing a block
func (*BlockProcessorMock) PruneStateOnRollback ¶
func (bpm *BlockProcessorMock) PruneStateOnRollback(currHeader data.HeaderHandler, prevHeader data.HeaderHandler)
PruneStateOnRollback recreates the state tries to the root hashes indicated by the provided header
func (*BlockProcessorMock) RestoreBlockIntoPools ¶
func (bpm *BlockProcessorMock) RestoreBlockIntoPools(header data.HeaderHandler, body data.BodyHandler) error
RestoreBlockIntoPools -
func (*BlockProcessorMock) RestoreLastNotarizedHrdsToGenesis ¶
func (bpm *BlockProcessorMock) RestoreLastNotarizedHrdsToGenesis()
RestoreLastNotarizedHrdsToGenesis -
func (*BlockProcessorMock) RevertAccountState ¶
func (bpm *BlockProcessorMock) RevertAccountState(header data.HeaderHandler)
RevertAccountState mocks revert of the accounts state
func (*BlockProcessorMock) RevertIndexedBlock ¶ added in v1.1.6
func (bpm *BlockProcessorMock) RevertIndexedBlock(header data.HeaderHandler)
RevertIndexedBlock -
func (*BlockProcessorMock) RevertStateToBlock ¶
func (bpm *BlockProcessorMock) RevertStateToBlock(header data.HeaderHandler) error
RevertStateToBlock recreates the state tries to the root hashes indicated by the provided header
func (*BlockProcessorMock) SetNumProcessedObj ¶
func (bpm *BlockProcessorMock) SetNumProcessedObj(_ uint64)
SetNumProcessedObj -
type BlockSizeThrottlerStub ¶
type BlockSizeThrottlerStub struct { GetCurrentMaxSizeCalled func() uint32 AddCalled func(round uint64, size uint32) SucceedCalled func(round uint64) ComputeCurrentMaxSizeCalled func() }
BlockSizeThrottlerStub -
func (*BlockSizeThrottlerStub) Add ¶
func (bsts *BlockSizeThrottlerStub) Add(round uint64, size uint32)
Add -
func (*BlockSizeThrottlerStub) ComputeCurrentMaxSize ¶
func (bsts *BlockSizeThrottlerStub) ComputeCurrentMaxSize()
ComputeCurrentMaxSize -
func (*BlockSizeThrottlerStub) GetCurrentMaxSize ¶
func (bsts *BlockSizeThrottlerStub) GetCurrentMaxSize() uint32
GetCurrentMaxSize -
func (*BlockSizeThrottlerStub) IsInterfaceNil ¶
func (bsts *BlockSizeThrottlerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*BlockSizeThrottlerStub) Succeed ¶
func (bsts *BlockSizeThrottlerStub) Succeed(round uint64)
Succeed -
type BlockTrackerStub ¶
type BlockTrackerStub struct { AddTrackedHeaderCalled func(header data.HeaderHandler, hash []byte) AddCrossNotarizedHeaderCalled func(shardID uint32, crossNotarizedHeader data.HeaderHandler, crossNotarizedHeaderHash []byte) AddSelfNotarizedHeaderCalled func(shardID uint32, selfNotarizedHeader data.HeaderHandler, selfNotarizedHeaderHash []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(handler func(shardID uint32, headers []data.HeaderHandler, headersHashes [][]byte)) RegisterSelfNotarizedFromCrossHeadersHandlerCalled func(handler func(shardID uint32, headers []data.HeaderHandler, headersHashes [][]byte)) RegisterSelfNotarizedHeadersHandlerCalled func(handler func(shardID uint32, headers []data.HeaderHandler, headersHashes [][]byte)) RegisterFinalMetachainHeadersHandlerCalled func(handler func(shardID uint32, headers []data.HeaderHandler, headersHashes [][]byte)) RemoveLastNotarizedHeadersCalled func() RestoreToGenesisCalled func() ShouldAddHeaderCalled func(headerHandler data.HeaderHandler) bool }
BlockTrackerStub -
func (*BlockTrackerStub) AddCrossNotarizedHeader ¶
func (bts *BlockTrackerStub) AddCrossNotarizedHeader(shardID uint32, crossNotarizedHeader data.HeaderHandler, crossNotarizedHeaderHash []byte)
AddCrossNotarizedHeader -
func (*BlockTrackerStub) AddSelfNotarizedHeader ¶
func (bts *BlockTrackerStub) AddSelfNotarizedHeader(shardID uint32, selfNotarizedHeader data.HeaderHandler, selfNotarizedHeaderHash []byte)
AddSelfNotarizedHeader -
func (*BlockTrackerStub) AddTrackedHeader ¶
func (bts *BlockTrackerStub) AddTrackedHeader(header data.HeaderHandler, hash []byte)
AddTrackedHeader -
func (*BlockTrackerStub) CheckBlockAgainstFinal ¶
func (bts *BlockTrackerStub) CheckBlockAgainstFinal(headerHandler data.HeaderHandler) error
CheckBlockAgainstFinal -
func (*BlockTrackerStub) CheckBlockAgainstRoundHandler ¶ added in v1.2.0
func (bts *BlockTrackerStub) CheckBlockAgainstRoundHandler(headerHandler data.HeaderHandler) error
CheckBlockAgainstRoundHandler -
func (*BlockTrackerStub) CheckBlockAgainstWhitelist ¶ added in v1.0.138
func (bts *BlockTrackerStub) CheckBlockAgainstWhitelist(interceptedData process.InterceptedData) bool
CheckBlockAgainstWhitelist -
func (*BlockTrackerStub) CleanupHeadersBehindNonce ¶
func (bts *BlockTrackerStub) CleanupHeadersBehindNonce(shardID uint32, selfNotarizedNonce uint64, crossNotarizedNonce uint64)
CleanupHeadersBehindNonce -
func (*BlockTrackerStub) CleanupInvalidCrossHeaders ¶
func (bts *BlockTrackerStub) CleanupInvalidCrossHeaders(_ uint32, _ uint64)
CleanupInvalidCrossHeaders -
func (*BlockTrackerStub) ComputeLongestChain ¶
func (bts *BlockTrackerStub) ComputeLongestChain(shardID uint32, header data.HeaderHandler) ([]data.HeaderHandler, [][]byte)
ComputeLongestChain -
func (*BlockTrackerStub) ComputeLongestMetaChainFromLastNotarized ¶
func (bts *BlockTrackerStub) ComputeLongestMetaChainFromLastNotarized() ([]data.HeaderHandler, [][]byte, error)
ComputeLongestMetaChainFromLastNotarized -
func (*BlockTrackerStub) ComputeLongestShardsChainsFromLastNotarized ¶
func (bts *BlockTrackerStub) ComputeLongestShardsChainsFromLastNotarized() ([]data.HeaderHandler, [][]byte, map[uint32][]data.HeaderHandler, error)
ComputeLongestShardsChainsFromLastNotarized -
func (*BlockTrackerStub) DisplayTrackedHeaders ¶
func (bts *BlockTrackerStub) DisplayTrackedHeaders()
DisplayTrackedHeaders -
func (*BlockTrackerStub) GetCrossNotarizedHeader ¶
func (bts *BlockTrackerStub) GetCrossNotarizedHeader(shardID uint32, offset uint64) (data.HeaderHandler, []byte, error)
GetCrossNotarizedHeader -
func (*BlockTrackerStub) GetLastCrossNotarizedHeader ¶
func (bts *BlockTrackerStub) GetLastCrossNotarizedHeader(shardID uint32) (data.HeaderHandler, []byte, error)
GetLastCrossNotarizedHeader -
func (*BlockTrackerStub) GetLastCrossNotarizedHeadersForAllShards ¶
func (bts *BlockTrackerStub) GetLastCrossNotarizedHeadersForAllShards() (map[uint32]data.HeaderHandler, error)
GetLastCrossNotarizedHeadersForAllShards -
func (*BlockTrackerStub) GetLastSelfNotarizedHeader ¶
func (bts *BlockTrackerStub) GetLastSelfNotarizedHeader(shardID uint32) (data.HeaderHandler, []byte, error)
GetLastSelfNotarizedHeader -
func (*BlockTrackerStub) GetSelfNotarizedHeader ¶ added in v1.0.104
func (bts *BlockTrackerStub) GetSelfNotarizedHeader(shardID uint32, offset uint64) (data.HeaderHandler, []byte, error)
GetSelfNotarizedHeader -
func (*BlockTrackerStub) GetTrackedHeaders ¶
func (bts *BlockTrackerStub) GetTrackedHeaders(shardID uint32) ([]data.HeaderHandler, [][]byte)
GetTrackedHeaders -
func (*BlockTrackerStub) GetTrackedHeadersForAllShards ¶
func (bts *BlockTrackerStub) GetTrackedHeadersForAllShards() map[uint32][]data.HeaderHandler
GetTrackedHeadersForAllShards -
func (*BlockTrackerStub) GetTrackedHeadersWithNonce ¶
func (bts *BlockTrackerStub) GetTrackedHeadersWithNonce(shardID uint32, nonce uint64) ([]data.HeaderHandler, [][]byte)
GetTrackedHeadersWithNonce -
func (*BlockTrackerStub) IsInterfaceNil ¶
func (bts *BlockTrackerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*BlockTrackerStub) IsShardStuck ¶
func (bts *BlockTrackerStub) IsShardStuck(shardId uint32) bool
IsShardStuck -
func (*BlockTrackerStub) RegisterCrossNotarizedHeadersHandler ¶
func (bts *BlockTrackerStub) RegisterCrossNotarizedHeadersHandler(handler func(shardID uint32, headers []data.HeaderHandler, headersHashes [][]byte))
RegisterCrossNotarizedHeadersHandler -
func (*BlockTrackerStub) RegisterFinalMetachainHeadersHandler ¶ added in v1.1.1
func (bts *BlockTrackerStub) RegisterFinalMetachainHeadersHandler(handler func(shardID uint32, headers []data.HeaderHandler, headersHashes [][]byte))
RegisterFinalMetachainHeadersHandler -
func (*BlockTrackerStub) RegisterSelfNotarizedFromCrossHeadersHandler ¶ added in v1.1.1
func (bts *BlockTrackerStub) RegisterSelfNotarizedFromCrossHeadersHandler(handler func(shardID uint32, headers []data.HeaderHandler, headersHashes [][]byte))
RegisterSelfNotarizedFromCrossHeadersHandler -
func (*BlockTrackerStub) RegisterSelfNotarizedHeadersHandler ¶
func (bts *BlockTrackerStub) RegisterSelfNotarizedHeadersHandler(handler func(shardID uint32, headers []data.HeaderHandler, headersHashes [][]byte))
RegisterSelfNotarizedHeadersHandler -
func (*BlockTrackerStub) RemoveLastNotarizedHeaders ¶
func (bts *BlockTrackerStub) RemoveLastNotarizedHeaders()
RemoveLastNotarizedHeaders -
func (*BlockTrackerStub) RestoreToGenesis ¶
func (bts *BlockTrackerStub) RestoreToGenesis()
RestoreToGenesis -
func (*BlockTrackerStub) ShouldAddHeader ¶
func (bts *BlockTrackerStub) ShouldAddHeader(headerHandler data.HeaderHandler) bool
ShouldAddHeader -
type BoostrapStorerMock ¶
type BoostrapStorerMock struct { PutCalled func(round int64, bootData bootstrapStorage.BootstrapData) error GetCalled func(round int64) (bootstrapStorage.BootstrapData, error) GetHighestRoundCalled func() int64 }
BoostrapStorerMock -
func (*BoostrapStorerMock) Get ¶
func (bsm *BoostrapStorerMock) Get(round int64) (bootstrapStorage.BootstrapData, error)
Get -
func (*BoostrapStorerMock) GetHighestRound ¶
func (bsm *BoostrapStorerMock) GetHighestRound() int64
GetHighestRound -
func (*BoostrapStorerMock) IsInterfaceNil ¶
func (bsm *BoostrapStorerMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*BoostrapStorerMock) Put ¶
func (bsm *BoostrapStorerMock) Put(round int64, bootData bootstrapStorage.BootstrapData) error
Put -
func (*BoostrapStorerMock) SaveLastRound ¶
func (bsm *BoostrapStorerMock) SaveLastRound(_ int64) error
SaveLastRound -
type BuiltInCostHandlerStub ¶ added in v1.1.46
type BuiltInCostHandlerStub struct { }
BuiltInCostHandlerStub -
func (*BuiltInCostHandlerStub) ComputeBuiltInCost ¶ added in v1.1.46
func (b *BuiltInCostHandlerStub) ComputeBuiltInCost(_ data.TransactionWithFeeHandler) uint64
ComputeBuiltInCost -
func (*BuiltInCostHandlerStub) IsBuiltInFuncCall ¶ added in v1.1.46
func (b *BuiltInCostHandlerStub) IsBuiltInFuncCall(_ data.TransactionWithFeeHandler) bool
IsBuiltInFuncCall -
func (*BuiltInCostHandlerStub) IsInterfaceNil ¶ added in v1.1.46
func (b *BuiltInCostHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
type ChainStorerMock ¶
type ChainStorerMock struct { AddStorerCalled func(key dataRetriever.UnitType, s storage.Storer) GetStorerCalled func(unitType dataRetriever.UnitType) storage.Storer HasCalled func(unitType dataRetriever.UnitType, key []byte) error GetCalled func(unitType dataRetriever.UnitType, key []byte) ([]byte, error) PutCalled func(unitType dataRetriever.UnitType, key []byte, value []byte) error GetAllCalled func(unitType dataRetriever.UnitType, keys [][]byte) (map[string][]byte, error) GetAllStorersCalled func() map[dataRetriever.UnitType]storage.Storer DestroyCalled func() error CloseAllCalled func() error }
ChainStorerMock is a mock implementation of the ChainStorer interface
func (*ChainStorerMock) AddStorer ¶
func (bc *ChainStorerMock) AddStorer(key dataRetriever.UnitType, s storage.Storer)
AddStorer will add a new storer to the chain map
func (*ChainStorerMock) Destroy ¶
func (bc *ChainStorerMock) Destroy() error
Destroy removes the underlying files/resources used by the storage service
func (*ChainStorerMock) Get ¶
func (bc *ChainStorerMock) Get(unitType dataRetriever.UnitType, key []byte) ([]byte, error)
Get returns the value for the given key if found in the selected storage unit, nil otherwise. It can return an error if the provided unit type is not supported or if the storage unit underlying implementation reports an error
func (*ChainStorerMock) GetAll ¶
func (bc *ChainStorerMock) GetAll(unitType dataRetriever.UnitType, keys [][]byte) (map[string][]byte, error)
GetAll gets all the elements with keys in the keys array, from the selected storage unit It can report an error if the provided unit type is not supported, if there is a missing key in the unit, or if the underlying implementation of the storage unit reports an error.
func (*ChainStorerMock) GetAllStorers ¶ added in v1.2.4
func (bc *ChainStorerMock) GetAllStorers() map[dataRetriever.UnitType]storage.Storer
GetAllStorers -
func (*ChainStorerMock) GetStorer ¶
func (bc *ChainStorerMock) GetStorer(unitType dataRetriever.UnitType) storage.Storer
GetStorer returns the storer from the chain map or nil if the storer was not found
func (*ChainStorerMock) Has ¶
func (bc *ChainStorerMock) Has(unitType dataRetriever.UnitType, key []byte) error
Has returns true if the key is found in the selected Unit or false otherwise It can return an error if the provided unit type is not supported or if the underlying implementation of the storage unit reports an error.
func (*ChainStorerMock) IsInterfaceNil ¶
func (bc *ChainStorerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ChainStorerMock) Put ¶
func (bc *ChainStorerMock) Put(unitType dataRetriever.UnitType, key []byte, value []byte) error
Put stores the key, value pair in the selected storage unit It can return an error if the provided unit type is not supported or if the storage unit underlying implementation reports an error
func (*ChainStorerMock) SetEpochForPutOperation ¶ added in v1.0.109
func (bc *ChainStorerMock) SetEpochForPutOperation(_ uint32)
SetEpochForPutOperation won't do anything
type CoreComponentsStub ¶ added in v1.2.0
type CoreComponentsStub struct { InternalMarshalizerField marshal.Marshalizer TxMarshalizerField marshal.Marshalizer VmMarshalizerField marshal.Marshalizer HasherField hashing.Hasher TxSignHasherField hashing.Hasher Uint64ByteSliceConverterField typeConverters.Uint64ByteSliceConverter AddressPubKeyConverterField core.PubkeyConverter ValidatorPubKeyConverterField core.PubkeyConverter PathHandlerField storage.PathManagerHandler ChainIdCalled func() string MinTransactionVersionCalled func() uint32 StatusHandlerUtilsField nodeFactory.StatusHandlersUtils StatusHandlerField core.AppStatusHandler WatchdogField core.WatchdogTimer AlarmSchedulerField core.TimersScheduler SyncTimerField ntp.SyncTimer RoundHandlerField consensus.RoundHandler EconomicsDataField process.EconomicsDataHandler RatingsDataField process.RatingsInfoHandler RaterField sharding.PeerAccountListAndRatingHandler GenesisNodesSetupField sharding.GenesisNodesSetupHandler NodesShufflerField sharding.NodesShuffler EpochNotifierField process.EpochNotifier EpochStartNotifierWithConfirmField factory.EpochStartNotifierWithConfirm ChanStopNodeProcessField chan endProcess.ArgEndProcess GenesisTimeField time.Time TxVersionCheckField process.TxVersionCheckerHandler NodeTypeProviderField core.NodeTypeProviderHandler ArwenChangeLockerInternal common.Locker }
CoreComponentsStub -
func (*CoreComponentsStub) AddressPubKeyConverter ¶ added in v1.2.0
func (ccs *CoreComponentsStub) AddressPubKeyConverter() core.PubkeyConverter
AddressPubKeyConverter -
func (*CoreComponentsStub) AlarmScheduler ¶ added in v1.2.0
func (ccs *CoreComponentsStub) AlarmScheduler() core.TimersScheduler
AlarmScheduler -
func (*CoreComponentsStub) ArwenChangeLocker ¶ added in v1.2.23
func (ccs *CoreComponentsStub) ArwenChangeLocker() common.Locker
ArwenChangeLocker -
func (*CoreComponentsStub) ChainID ¶ added in v1.2.0
func (ccs *CoreComponentsStub) ChainID() string
ChainID -
func (*CoreComponentsStub) ChanStopNodeProcess ¶ added in v1.2.0
func (ccs *CoreComponentsStub) ChanStopNodeProcess() chan endProcess.ArgEndProcess
ChanStopNodeProcess -
func (*CoreComponentsStub) CheckSubcomponents ¶ added in v1.2.0
func (ccs *CoreComponentsStub) CheckSubcomponents() error
CheckSubcomponents -
func (*CoreComponentsStub) Close ¶ added in v1.2.0
func (ccs *CoreComponentsStub) Close() error
Close -
func (*CoreComponentsStub) Create ¶ added in v1.2.0
func (ccs *CoreComponentsStub) Create() error
Create -
func (*CoreComponentsStub) EconomicsData ¶ added in v1.2.0
func (ccs *CoreComponentsStub) EconomicsData() process.EconomicsDataHandler
EconomicsData -
func (*CoreComponentsStub) EncodedAddressLen ¶ added in v1.2.0
func (ccs *CoreComponentsStub) EncodedAddressLen() uint32
EncodedAddressLen -
func (*CoreComponentsStub) EpochNotifier ¶ added in v1.2.0
func (ccs *CoreComponentsStub) EpochNotifier() process.EpochNotifier
EpochNotifier -
func (*CoreComponentsStub) EpochStartNotifierWithConfirm ¶ added in v1.2.0
func (ccs *CoreComponentsStub) EpochStartNotifierWithConfirm() factory.EpochStartNotifierWithConfirm
EpochStartNotifierWithConfirm -
func (*CoreComponentsStub) GenesisNodesSetup ¶ added in v1.2.0
func (ccs *CoreComponentsStub) GenesisNodesSetup() sharding.GenesisNodesSetupHandler
GenesisNodesSetup -
func (*CoreComponentsStub) GenesisTime ¶ added in v1.2.0
func (ccs *CoreComponentsStub) GenesisTime() time.Time
GenesisTime -
func (*CoreComponentsStub) Hasher ¶ added in v1.2.0
func (ccs *CoreComponentsStub) Hasher() hashing.Hasher
Hasher -
func (*CoreComponentsStub) InternalMarshalizer ¶ added in v1.2.0
func (ccs *CoreComponentsStub) InternalMarshalizer() marshal.Marshalizer
InternalMarshalizer -
func (*CoreComponentsStub) IsInterfaceNil ¶ added in v1.2.0
func (ccs *CoreComponentsStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*CoreComponentsStub) MinTransactionVersion ¶ added in v1.2.0
func (ccs *CoreComponentsStub) MinTransactionVersion() uint32
MinTransactionVersion -
func (*CoreComponentsStub) NodeTypeProvider ¶ added in v1.2.4
func (ccs *CoreComponentsStub) NodeTypeProvider() core.NodeTypeProviderHandler
NodeTypeProvider -
func (*CoreComponentsStub) NodesShuffler ¶ added in v1.2.0
func (ccs *CoreComponentsStub) NodesShuffler() sharding.NodesShuffler
NodesShuffler -
func (*CoreComponentsStub) PathHandler ¶ added in v1.2.0
func (ccs *CoreComponentsStub) PathHandler() storage.PathManagerHandler
PathHandler -
func (*CoreComponentsStub) Rater ¶ added in v1.2.0
func (ccs *CoreComponentsStub) Rater() sharding.PeerAccountListAndRatingHandler
Rater -
func (*CoreComponentsStub) RatingsData ¶ added in v1.2.0
func (ccs *CoreComponentsStub) RatingsData() process.RatingsInfoHandler
RatingsData -
func (*CoreComponentsStub) RoundHandler ¶ added in v1.2.0
func (ccs *CoreComponentsStub) RoundHandler() consensus.RoundHandler
RoundHandler -
func (*CoreComponentsStub) SetInternalMarshalizer ¶ added in v1.2.0
func (ccs *CoreComponentsStub) SetInternalMarshalizer(m marshal.Marshalizer) error
SetInternalMarshalizer -
func (*CoreComponentsStub) StatusHandler ¶ added in v1.2.0
func (ccs *CoreComponentsStub) StatusHandler() core.AppStatusHandler
StatusHandler -
func (*CoreComponentsStub) StatusHandlerUtils ¶ added in v1.2.0
func (ccs *CoreComponentsStub) StatusHandlerUtils() nodeFactory.StatusHandlersUtils
StatusHandlerUtils -
func (*CoreComponentsStub) String ¶ added in v1.2.12
func (ccs *CoreComponentsStub) String() string
String -
func (*CoreComponentsStub) SyncTimer ¶ added in v1.2.0
func (ccs *CoreComponentsStub) SyncTimer() ntp.SyncTimer
SyncTimer -
func (*CoreComponentsStub) TxMarshalizer ¶ added in v1.2.0
func (ccs *CoreComponentsStub) TxMarshalizer() marshal.Marshalizer
TxMarshalizer -
func (*CoreComponentsStub) TxSignHasher ¶ added in v1.2.0
func (ccs *CoreComponentsStub) TxSignHasher() hashing.Hasher
TxSignHasher -
func (*CoreComponentsStub) TxVersionChecker ¶ added in v1.2.0
func (ccs *CoreComponentsStub) TxVersionChecker() process.TxVersionCheckerHandler
TxVersionChecker -
func (*CoreComponentsStub) Uint64ByteSliceConverter ¶ added in v1.2.0
func (ccs *CoreComponentsStub) Uint64ByteSliceConverter() typeConverters.Uint64ByteSliceConverter
Uint64ByteSliceConverter -
func (*CoreComponentsStub) ValidatorPubKeyConverter ¶ added in v1.2.0
func (ccs *CoreComponentsStub) ValidatorPubKeyConverter() core.PubkeyConverter
ValidatorPubKeyConverter -
func (*CoreComponentsStub) VmMarshalizer ¶ added in v1.2.0
func (ccs *CoreComponentsStub) VmMarshalizer() marshal.Marshalizer
VmMarshalizer -
func (*CoreComponentsStub) Watchdog ¶ added in v1.2.0
func (ccs *CoreComponentsStub) Watchdog() core.WatchdogTimer
Watchdog -
type CryptoComponentsStub ¶ added in v1.2.0
type CryptoComponentsStub struct { PubKey crypto.PublicKey PrivKey crypto.PrivateKey PubKeyString string PrivKeyBytes []byte PubKeyBytes []byte BlockSig crypto.SingleSigner TxSig crypto.SingleSigner MultiSig crypto.MultiSigner PeerSignHandler crypto.PeerSignatureHandler BlKeyGen crypto.KeyGenerator TxKeyGen crypto.KeyGenerator MsgSigVerifier vm.MessageSignVerifier // contains filtered or unexported fields }
CryptoComponentsStub -
func (*CryptoComponentsStub) BlockSignKeyGen ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) BlockSignKeyGen() crypto.KeyGenerator
BlockSignKeyGen -
func (*CryptoComponentsStub) BlockSigner ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) BlockSigner() crypto.SingleSigner
BlockSigner -
func (*CryptoComponentsStub) CheckSubcomponents ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) CheckSubcomponents() error
CheckSubcomponents -
func (*CryptoComponentsStub) Clone ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) Clone() interface{}
Clone -
func (*CryptoComponentsStub) Close ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) Close() error
Close -
func (*CryptoComponentsStub) Create ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) Create() error
Create -
func (*CryptoComponentsStub) IsInterfaceNil ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*CryptoComponentsStub) MessageSignVerifier ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) MessageSignVerifier() vm.MessageSignVerifier
MessageSignVerifier -
func (*CryptoComponentsStub) MultiSigner ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) MultiSigner() crypto.MultiSigner
MultiSigner -
func (*CryptoComponentsStub) PeerSignatureHandler ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) PeerSignatureHandler() crypto.PeerSignatureHandler
PeerSignatureHandler -
func (*CryptoComponentsStub) PrivateKey ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) PrivateKey() crypto.PrivateKey
PrivateKey -
func (*CryptoComponentsStub) PrivateKeyBytes ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) PrivateKeyBytes() []byte
PrivateKeyBytes -
func (*CryptoComponentsStub) PublicKey ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) PublicKey() crypto.PublicKey
PublicKey -
func (*CryptoComponentsStub) PublicKeyBytes ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) PublicKeyBytes() []byte
PublicKeyBytes -
func (*CryptoComponentsStub) PublicKeyString ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) PublicKeyString() string
PublicKeyString -
func (*CryptoComponentsStub) SetMultiSigner ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) SetMultiSigner(ms crypto.MultiSigner) error
SetMultiSigner -
func (*CryptoComponentsStub) String ¶ added in v1.2.12
func (ccs *CryptoComponentsStub) String() string
String -
func (*CryptoComponentsStub) TxSignKeyGen ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) TxSignKeyGen() crypto.KeyGenerator
TxSignKeyGen -
func (*CryptoComponentsStub) TxSingleSigner ¶ added in v1.2.0
func (ccs *CryptoComponentsStub) TxSingleSigner() crypto.SingleSigner
TxSingleSigner -
type CurrentNetworkEpochProviderStub ¶ added in v1.2.0
type CurrentNetworkEpochProviderStub struct { SetNetworkEpochAtBootstrapCalled func(epoch uint32) EpochIsActiveInNetworkCalled func(epoch uint32) bool EpochConfirmedCalled func(epoch uint32, timestamp uint64) }
CurrentNetworkEpochProviderStub -
func (*CurrentNetworkEpochProviderStub) EpochConfirmed ¶ added in v1.2.0
func (cneps *CurrentNetworkEpochProviderStub) EpochConfirmed(epoch uint32, timestamp uint64)
EpochConfirmed -
func (*CurrentNetworkEpochProviderStub) EpochIsActiveInNetwork ¶ added in v1.2.0
func (cneps *CurrentNetworkEpochProviderStub) EpochIsActiveInNetwork(epoch uint32) bool
EpochIsActiveInNetwork -
func (*CurrentNetworkEpochProviderStub) IsInterfaceNil ¶ added in v1.2.0
func (cneps *CurrentNetworkEpochProviderStub) IsInterfaceNil() bool
IsInterfaceNil -
type DataComponentsStub ¶ added in v1.2.0
type DataComponentsStub struct { BlockChain data.ChainHandler Store dataRetriever.StorageService DataPool dataRetriever.PoolsHolder MbProvider factory.MiniBlockProvider EconomicsData factory.EconomicsHandler // contains filtered or unexported fields }
DataComponentsStub -
func (*DataComponentsStub) Blockchain ¶ added in v1.2.0
func (dcs *DataComponentsStub) Blockchain() data.ChainHandler
Blockchain -
func (*DataComponentsStub) CheckSubcomponents ¶ added in v1.2.0
func (dcs *DataComponentsStub) CheckSubcomponents() error
CheckSubcomponents -
func (*DataComponentsStub) Clone ¶ added in v1.2.0
func (dcs *DataComponentsStub) Clone() interface{}
Clone -
func (*DataComponentsStub) Close ¶ added in v1.2.0
func (dcs *DataComponentsStub) Close() error
Close -
func (*DataComponentsStub) Create ¶ added in v1.2.0
func (dcs *DataComponentsStub) Create() error
Create -
func (*DataComponentsStub) Datapool ¶ added in v1.2.0
func (dcs *DataComponentsStub) Datapool() dataRetriever.PoolsHolder
Datapool -
func (*DataComponentsStub) EconomicsHandler ¶ added in v1.2.0
func (dcs *DataComponentsStub) EconomicsHandler() factory.EconomicsHandler
EconomicsHandler -
func (*DataComponentsStub) IsInterfaceNil ¶ added in v1.2.0
func (dcs *DataComponentsStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*DataComponentsStub) MiniBlocksProvider ¶ added in v1.2.0
func (dcs *DataComponentsStub) MiniBlocksProvider() factory.MiniBlockProvider
MiniBlocksProvider -
func (*DataComponentsStub) SetBlockchain ¶ added in v1.2.0
func (dcs *DataComponentsStub) SetBlockchain(chain data.ChainHandler)
SetBlockchain -
func (*DataComponentsStub) StorageService ¶ added in v1.2.0
func (dcs *DataComponentsStub) StorageService() dataRetriever.StorageService
StorageService -
func (*DataComponentsStub) String ¶ added in v1.2.12
func (dcs *DataComponentsStub) String() string
String -
type DatabaseWriterStub ¶ added in v1.1.22
type DatabaseWriterStub struct { DoRequestCalled func(req *esapi.IndexRequest) error DoBulkRequestCalled func(buff *bytes.Buffer, index string) error DoBulkRemoveCalled func(index string, hashes []string) error DoMultiGetCalled func(ids []string, index string, withSource bool, res interface{}) error }
DatabaseWriterStub --
func (*DatabaseWriterStub) CheckAndCreateAlias ¶ added in v1.1.22
func (dws *DatabaseWriterStub) CheckAndCreateAlias(_ string, _ string) error
CheckAndCreateAlias -
func (*DatabaseWriterStub) CheckAndCreateIndex ¶ added in v1.1.22
func (dws *DatabaseWriterStub) CheckAndCreateIndex(_ string) error
CheckAndCreateIndex --
func (*DatabaseWriterStub) CheckAndCreatePolicy ¶ added in v1.1.22
func (dws *DatabaseWriterStub) CheckAndCreatePolicy(_ string, _ *bytes.Buffer) error
CheckAndCreatePolicy -
func (*DatabaseWriterStub) CheckAndCreateTemplate ¶ added in v1.1.22
func (dws *DatabaseWriterStub) CheckAndCreateTemplate(_ string, _ *bytes.Buffer) error
CheckAndCreateTemplate -
func (*DatabaseWriterStub) DoBulkRemove ¶ added in v1.1.22
func (dws *DatabaseWriterStub) DoBulkRemove(index string, hashes []string) error
DoBulkRemove -
func (*DatabaseWriterStub) DoBulkRequest ¶ added in v1.1.22
func (dws *DatabaseWriterStub) DoBulkRequest(buff *bytes.Buffer, index string) error
DoBulkRequest --
func (*DatabaseWriterStub) DoMultiGet ¶ added in v1.1.22
func (dws *DatabaseWriterStub) DoMultiGet(ids []string, index string, withSource bool, res interface{}) error
DoMultiGet --
func (*DatabaseWriterStub) DoRequest ¶ added in v1.1.22
func (dws *DatabaseWriterStub) DoRequest(req *esapi.IndexRequest) error
DoRequest --
func (*DatabaseWriterStub) IsInterfaceNil ¶ added in v1.1.22
func (dws *DatabaseWriterStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type EpochEconomicsStub ¶
type EpochEconomicsStub struct { ComputeEndOfEpochEconomicsCalled func(metaBlock *block.MetaBlock) (*block.Economics, error) VerifyRewardsPerBlockCalled func( metaBlock *block.MetaBlock, correctedProtocolSustainability *big.Int, computedEconomics *block.Economics, ) error }
EpochEconomicsStub -
func (*EpochEconomicsStub) ComputeEndOfEpochEconomics ¶
func (e *EpochEconomicsStub) ComputeEndOfEpochEconomics(metaBlock *block.MetaBlock) (*block.Economics, error)
ComputeEndOfEpochEconomics -
func (*EpochEconomicsStub) IsInterfaceNil ¶
func (e *EpochEconomicsStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EpochEconomicsStub) VerifyRewardsPerBlock ¶
func (e *EpochEconomicsStub) VerifyRewardsPerBlock( metaBlock *block.MetaBlock, correctedProtocolSustainability *big.Int, computedEconomics *block.Economics, ) error
VerifyRewardsPerBlock -
type EpochNotifierStub ¶ added in v1.1.1
type EpochNotifierStub struct { CheckEpochCalled func(header data.HeaderHandler) CurrentEpochCalled func() uint32 RegisterNotifyHandlerCalled func(handler vmcommon.EpochSubscriberHandler) }
EpochNotifierStub -
func (*EpochNotifierStub) CheckEpoch ¶ added in v1.1.1
func (ens *EpochNotifierStub) CheckEpoch(header data.HeaderHandler)
CheckEpoch -
func (*EpochNotifierStub) CurrentEpoch ¶ added in v1.1.1
func (ens *EpochNotifierStub) CurrentEpoch() uint32
CurrentEpoch -
func (*EpochNotifierStub) IsInterfaceNil ¶ added in v1.1.1
func (ens *EpochNotifierStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EpochNotifierStub) RegisterNotifyHandler ¶ added in v1.1.1
func (ens *EpochNotifierStub) RegisterNotifyHandler(handler vmcommon.EpochSubscriberHandler)
RegisterNotifyHandler -
type EpochRewardsCreatorStub ¶
type EpochRewardsCreatorStub struct { CreateRewardsMiniBlocksCalled func( metaBlock *block.MetaBlock, validatorsInfo map[uint32][]*state.ValidatorInfo, computedEconomics *block.Economics, ) (block.MiniBlockSlice, error) VerifyRewardsMiniBlocksCalled func( metaBlock *block.MetaBlock, validatorsInfo map[uint32][]*state.ValidatorInfo, computedEconomics *block.Economics, ) error CreateMarshalizedDataCalled func(body *block.Body) map[string][][]byte SaveTxBlockToStorageCalled func(metaBlock *block.MetaBlock, body *block.Body) DeleteTxsFromStorageCalled func(metaBlock *block.MetaBlock, body *block.Body) RemoveBlockDataFromPoolsCalled func(metaBlock *block.MetaBlock, body *block.Body) GetRewardsTxsCalled func(body *block.Body) map[string]data.TransactionHandler GetProtocolSustainCalled func() *big.Int GetLocalTxCacheCalled func() epochStart.TransactionCacher }
EpochRewardsCreatorStub -
func (*EpochRewardsCreatorStub) CreateMarshalizedData ¶
func (e *EpochRewardsCreatorStub) CreateMarshalizedData(body *block.Body) map[string][][]byte
CreateMarshalizedData -
func (*EpochRewardsCreatorStub) CreateRewardsMiniBlocks ¶
func (e *EpochRewardsCreatorStub) CreateRewardsMiniBlocks( metaBlock *block.MetaBlock, validatorsInfo map[uint32][]*state.ValidatorInfo, computedEconomics *block.Economics, ) (block.MiniBlockSlice, error)
CreateRewardsMiniBlocks -
func (*EpochRewardsCreatorStub) DeleteTxsFromStorage ¶
func (e *EpochRewardsCreatorStub) DeleteTxsFromStorage(metaBlock *block.MetaBlock, body *block.Body)
DeleteTxsFromStorage -
func (*EpochRewardsCreatorStub) GetLocalTxCache ¶ added in v1.1.15
func (e *EpochRewardsCreatorStub) GetLocalTxCache() epochStart.TransactionCacher
GetLocalTxCache -
func (*EpochRewardsCreatorStub) GetProtocolSustainabilityRewards ¶ added in v1.0.147
func (e *EpochRewardsCreatorStub) GetProtocolSustainabilityRewards() *big.Int
GetProtocolSustainabilityRewards -
func (*EpochRewardsCreatorStub) GetRewardsTxs ¶ added in v1.0.102
func (e *EpochRewardsCreatorStub) GetRewardsTxs(body *block.Body) map[string]data.TransactionHandler
GetRewardsTxs --
func (*EpochRewardsCreatorStub) IsInterfaceNil ¶
func (e *EpochRewardsCreatorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EpochRewardsCreatorStub) RemoveBlockDataFromPools ¶ added in v0.0.5
func (e *EpochRewardsCreatorStub) RemoveBlockDataFromPools(metaBlock *block.MetaBlock, body *block.Body)
RemoveBlockDataFromPools -
func (*EpochRewardsCreatorStub) SaveTxBlockToStorage ¶
func (e *EpochRewardsCreatorStub) SaveTxBlockToStorage(metaBlock *block.MetaBlock, body *block.Body)
SaveTxBlockToStorage -
func (*EpochRewardsCreatorStub) VerifyRewardsMiniBlocks ¶
func (e *EpochRewardsCreatorStub) VerifyRewardsMiniBlocks( metaBlock *block.MetaBlock, validatorsInfo map[uint32][]*state.ValidatorInfo, computedEconomics *block.Economics, ) error
VerifyRewardsMiniBlocks -
type EpochStartDataCreatorStub ¶
type EpochStartDataCreatorStub struct { CreateEpochStartDataCalled func() (*block.EpochStart, error) VerifyEpochStartDataForMetablockCalled func(metaBlock *block.MetaBlock) error }
EpochStartDataCreatorStub -
func (*EpochStartDataCreatorStub) CreateEpochStartData ¶
func (e *EpochStartDataCreatorStub) CreateEpochStartData() (*block.EpochStart, error)
CreateEpochStartData -
func (*EpochStartDataCreatorStub) IsInterfaceNil ¶
func (e *EpochStartDataCreatorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EpochStartDataCreatorStub) VerifyEpochStartDataForMetablock ¶
func (e *EpochStartDataCreatorStub) VerifyEpochStartDataForMetablock(metaBlock *block.MetaBlock) error
VerifyEpochStartDataForMetablock -
type EpochStartNotifierStub ¶
type EpochStartNotifierStub struct { RegisterHandlerCalled func(handler epochStart.ActionHandler) UnregisterHandlerCalled func(handler epochStart.ActionHandler) NotifyAllCalled func(hdr data.HeaderHandler) NotifyAllPrepareCalled func(hdr data.HeaderHandler, body data.BodyHandler) NotifyEpochChangeConfirmedCalled func(epoch uint32) // contains filtered or unexported fields }
EpochStartNotifierStub -
func (*EpochStartNotifierStub) IsInterfaceNil ¶
func (esnm *EpochStartNotifierStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EpochStartNotifierStub) NotifyAll ¶
func (esnm *EpochStartNotifierStub) NotifyAll(hdr data.HeaderHandler)
NotifyAll -
func (*EpochStartNotifierStub) NotifyAllPrepare ¶
func (esnm *EpochStartNotifierStub) NotifyAllPrepare(metaHdr data.HeaderHandler, body data.BodyHandler)
NotifyAllPrepare -
func (*EpochStartNotifierStub) NotifyEpochChangeConfirmed ¶ added in v1.0.120
func (esnm *EpochStartNotifierStub) NotifyEpochChangeConfirmed(epoch uint32)
NotifyEpochChangeConfirmed -
func (*EpochStartNotifierStub) RegisterHandler ¶
func (esnm *EpochStartNotifierStub) RegisterHandler(handler epochStart.ActionHandler)
RegisterHandler -
func (*EpochStartNotifierStub) UnregisterHandler ¶
func (esnm *EpochStartNotifierStub) UnregisterHandler(handler epochStart.ActionHandler)
UnregisterHandler -
type EpochStartSystemSCStub ¶ added in v1.1.1
type EpochStartSystemSCStub struct { ProcessSystemSmartContractCalled func(validatorInfos map[uint32][]*state.ValidatorInfo, nonce uint64, epoch uint32) error ProcessDelegationRewardsCalled func(miniBlocks block.MiniBlockSlice, txCache epochStart.TransactionCacher) error ToggleUnStakeUnBondCalled func(value bool) error }
EpochStartSystemSCStub -
func (*EpochStartSystemSCStub) IsInterfaceNil ¶ added in v1.1.1
func (e *EpochStartSystemSCStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EpochStartSystemSCStub) ProcessDelegationRewards ¶ added in v1.1.15
func (e *EpochStartSystemSCStub) ProcessDelegationRewards( miniBlocks block.MiniBlockSlice, txCache epochStart.TransactionCacher, ) error
ProcessDelegationRewards -
func (*EpochStartSystemSCStub) ProcessSystemSmartContract ¶ added in v1.1.1
func (e *EpochStartSystemSCStub) ProcessSystemSmartContract(validatorInfos map[uint32][]*state.ValidatorInfo, nonce uint64, epoch uint32) error
ProcessSystemSmartContract -
func (*EpochStartSystemSCStub) ToggleUnStakeUnBond ¶ added in v1.1.15
func (e *EpochStartSystemSCStub) ToggleUnStakeUnBond(value bool) error
ToggleUnStakeUnBond -
type EpochStartTriggerStub ¶
type EpochStartTriggerStub struct { ForceEpochStartCalled func(round uint64) IsEpochStartCalled func() bool EpochCalled func() uint32 MetaEpochCalled func() uint32 ReceivedHeaderCalled func(handler data.HeaderHandler) UpdateCalled func(round uint64, nonce uint64) ProcessedCalled func(header data.HeaderHandler) EpochStartRoundCalled func() uint64 }
EpochStartTriggerStub -
func (*EpochStartTriggerStub) Close ¶ added in v1.0.116
func (e *EpochStartTriggerStub) Close() error
Close -
func (*EpochStartTriggerStub) EpochFinalityAttestingRound ¶
func (e *EpochStartTriggerStub) EpochFinalityAttestingRound() uint64
EpochFinalityAttestingRound -
func (*EpochStartTriggerStub) EpochStartMetaHdrHash ¶
func (e *EpochStartTriggerStub) EpochStartMetaHdrHash() []byte
EpochStartMetaHdrHash -
func (*EpochStartTriggerStub) EpochStartRound ¶
func (e *EpochStartTriggerStub) EpochStartRound() uint64
EpochStartRound -
func (*EpochStartTriggerStub) ForceEpochStart ¶
func (e *EpochStartTriggerStub) ForceEpochStart(round uint64)
ForceEpochStart -
func (*EpochStartTriggerStub) GetRoundsPerEpoch ¶
func (e *EpochStartTriggerStub) GetRoundsPerEpoch() uint64
GetRoundsPerEpoch -
func (*EpochStartTriggerStub) GetSavedStateKey ¶
func (e *EpochStartTriggerStub) GetSavedStateKey() []byte
GetSavedStateKey -
func (*EpochStartTriggerStub) IsEpochStart ¶
func (e *EpochStartTriggerStub) IsEpochStart() bool
IsEpochStart -
func (*EpochStartTriggerStub) IsInterfaceNil ¶
func (e *EpochStartTriggerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EpochStartTriggerStub) LoadState ¶
func (e *EpochStartTriggerStub) LoadState(_ []byte) error
LoadState -
func (*EpochStartTriggerStub) MetaEpoch ¶ added in v1.0.104
func (e *EpochStartTriggerStub) MetaEpoch() uint32
MetaEpoch -
func (*EpochStartTriggerStub) NotifyAll ¶
func (e *EpochStartTriggerStub) NotifyAll(_ data.HeaderHandler)
NotifyAll -
func (*EpochStartTriggerStub) ReceivedHeader ¶
func (e *EpochStartTriggerStub) ReceivedHeader(header data.HeaderHandler)
ReceivedHeader -
func (*EpochStartTriggerStub) RequestEpochStartIfNeeded ¶
func (e *EpochStartTriggerStub) RequestEpochStartIfNeeded(_ data.HeaderHandler)
RequestEpochStartIfNeeded -
func (*EpochStartTriggerStub) Revert ¶
func (e *EpochStartTriggerStub) Revert(_ data.HeaderHandler)
Revert -
func (*EpochStartTriggerStub) RevertStateToBlock ¶
func (e *EpochStartTriggerStub) RevertStateToBlock(_ data.HeaderHandler) error
RevertStateToBlock -
func (*EpochStartTriggerStub) SetAppStatusHandler ¶ added in v0.0.5
func (e *EpochStartTriggerStub) SetAppStatusHandler(_ core.AppStatusHandler) error
SetAppStatusHandler -
func (*EpochStartTriggerStub) SetCurrentEpochStartRound ¶
func (e *EpochStartTriggerStub) SetCurrentEpochStartRound(_ uint64)
SetCurrentEpochStartRound -
func (*EpochStartTriggerStub) SetEpoch ¶ added in v1.0.138
func (e *EpochStartTriggerStub) SetEpoch(_ uint32)
SetEpoch -
func (*EpochStartTriggerStub) SetFinalityAttestingRound ¶
func (e *EpochStartTriggerStub) SetFinalityAttestingRound(_ uint64)
SetFinalityAttestingRound -
func (*EpochStartTriggerStub) SetMinRoundsBetweenEpochs ¶ added in v1.1.3
func (e *EpochStartTriggerStub) SetMinRoundsBetweenEpochs(_ uint64)
SetMinRoundsBetweenEpochs -
func (*EpochStartTriggerStub) SetProcessed ¶
func (e *EpochStartTriggerStub) SetProcessed(header data.HeaderHandler, _ data.BodyHandler)
SetProcessed -
func (*EpochStartTriggerStub) SetRoundsPerEpoch ¶
func (e *EpochStartTriggerStub) SetRoundsPerEpoch(_ uint64)
SetRoundsPerEpoch -
func (*EpochStartTriggerStub) SetTrigger ¶
func (e *EpochStartTriggerStub) SetTrigger(_ epochStart.TriggerHandler)
SetTrigger -
func (*EpochStartTriggerStub) Update ¶
func (e *EpochStartTriggerStub) Update(round uint64, nonce uint64)
Update -
type EpochValidatorInfoCreatorStub ¶
type EpochValidatorInfoCreatorStub struct { CreateValidatorInfoMiniBlocksCalled func(validatorsInfo map[uint32][]*state.ValidatorInfo) (block.MiniBlockSlice, error) VerifyValidatorInfoMiniBlocksCalled func(miniblocks []*block.MiniBlock, validatorsInfo map[uint32][]*state.ValidatorInfo) error CreateMarshalizedDataCalled func(body block.Body) map[string][][]byte SaveTxBlockToStorageCalled func(metaBlock *block.MetaBlock, body *block.Body) DeleteTxsFromStorageCalled func(metaBlock *block.MetaBlock) RemoveBlockDataFromPoolsCalled func(metaBlock *block.MetaBlock, body *block.Body) }
EpochValidatorInfoCreatorStub -
func (*EpochValidatorInfoCreatorStub) CreateValidatorInfoMiniBlocks ¶
func (e *EpochValidatorInfoCreatorStub) CreateValidatorInfoMiniBlocks(validatorInfo map[uint32][]*state.ValidatorInfo) (block.MiniBlockSlice, error)
CreateValidatorInfoMiniBlocks -
func (*EpochValidatorInfoCreatorStub) DeleteValidatorInfoBlocksFromStorage ¶
func (e *EpochValidatorInfoCreatorStub) DeleteValidatorInfoBlocksFromStorage(metaBlock *block.MetaBlock)
DeleteValidatorInfoBlocksFromStorage -
func (*EpochValidatorInfoCreatorStub) IsInterfaceNil ¶
func (e *EpochValidatorInfoCreatorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EpochValidatorInfoCreatorStub) RemoveBlockDataFromPools ¶ added in v0.0.5
func (e *EpochValidatorInfoCreatorStub) RemoveBlockDataFromPools(metaBlock *block.MetaBlock, body *block.Body)
RemoveBlockDataFromPools -
func (*EpochValidatorInfoCreatorStub) SaveValidatorInfoBlocksToStorage ¶
func (e *EpochValidatorInfoCreatorStub) SaveValidatorInfoBlocksToStorage(metaBlock *block.MetaBlock, body *block.Body)
SaveValidatorInfoBlocksToStorage -
func (*EpochValidatorInfoCreatorStub) VerifyValidatorInfoMiniBlocks ¶
func (e *EpochValidatorInfoCreatorStub) VerifyValidatorInfoMiniBlocks(miniblocks []*block.MiniBlock, validatorsInfo map[uint32][]*state.ValidatorInfo) error
VerifyValidatorInfoMiniBlocks -
type ExportFactoryHandlerStub ¶ added in v1.0.120
type ExportFactoryHandlerStub struct {
CreateCalled func() (update.ExportHandler, error)
}
ExportFactoryHandlerStub -
func (*ExportFactoryHandlerStub) Create ¶ added in v1.0.120
func (e *ExportFactoryHandlerStub) Create() (update.ExportHandler, error)
Create -
func (*ExportFactoryHandlerStub) IsInterfaceNil ¶ added in v1.0.120
func (e *ExportFactoryHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
type ExportHandlerStub ¶ added in v1.0.120
ExportHandlerStub -
func (*ExportHandlerStub) ExportAll ¶ added in v1.0.120
func (e *ExportHandlerStub) ExportAll(epoch uint32) error
ExportAll -
func (*ExportHandlerStub) IsInterfaceNil ¶ added in v1.0.120
func (e *ExportHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
type FeeHandlerStub ¶
type FeeHandlerStub struct { SetMaxGasLimitPerBlockCalled func(maxGasLimitPerBlock uint64) SetMinGasPriceCalled func(minGasPrice uint64) SetMinGasLimitCalled func(minGasLimit uint64) MaxGasLimitPerBlockCalled func() uint64 MaxGasLimitPerMiniBlockCalled func() uint64 MaxGasLimitPerBlockForSafeCrossShardCalled func() uint64 MaxGasLimitPerMiniBlockForSafeCrossShardCalled func() uint64 ComputeGasLimitCalled func(tx data.TransactionWithFeeHandler) uint64 ComputeMoveBalanceFeeCalled func(tx data.TransactionWithFeeHandler) *big.Int ComputeTxFeeCalled func(tx data.TransactionWithFeeHandler) *big.Int CheckValidityTxValuesCalled func(tx data.TransactionWithFeeHandler) error DeveloperPercentageCalled func() float64 MinGasPriceCalled func() uint64 GasPriceModifierCalled func() float64 ComputeFeeForProcessingCalled func(tx data.TransactionWithFeeHandler, gasToUse uint64) *big.Int GenesisTotalSupplyCalled func() *big.Int SplitTxGasInCategoriesCalled func(tx data.TransactionWithFeeHandler) (uint64, uint64) GasPriceForProcessingCalled func(tx data.TransactionWithFeeHandler) uint64 GasPriceForMoveCalled func(tx data.TransactionWithFeeHandler) uint64 MinGasPriceForProcessingCalled func() uint64 ComputeGasUsedAndFeeBasedOnRefundValueCalled func(tx data.TransactionWithFeeHandler, refundValue *big.Int) (uint64, *big.Int) ComputeTxFeeBasedOnGasUsedCalled func(tx data.TransactionWithFeeHandler, gasUsed uint64) *big.Int ComputeGasLimitBasedOnBalanceCalled func(tx data.TransactionWithFeeHandler, balance *big.Int) (uint64, error) }
FeeHandlerStub -
func (*FeeHandlerStub) CheckValidityTxValues ¶
func (fhs *FeeHandlerStub) CheckValidityTxValues(tx data.TransactionWithFeeHandler) error
CheckValidityTxValues -
func (*FeeHandlerStub) ComputeFeeForProcessing ¶ added in v1.1.15
func (fhs *FeeHandlerStub) ComputeFeeForProcessing(tx data.TransactionWithFeeHandler, gasToUse uint64) *big.Int
ComputeFeeForProcessing -
func (*FeeHandlerStub) ComputeGasLimit ¶
func (fhs *FeeHandlerStub) ComputeGasLimit(tx data.TransactionWithFeeHandler) uint64
ComputeGasLimit -
func (*FeeHandlerStub) ComputeGasLimitBasedOnBalance ¶ added in v1.2.4
func (fhs *FeeHandlerStub) ComputeGasLimitBasedOnBalance(tx data.TransactionWithFeeHandler, balance *big.Int) (uint64, error)
ComputeGasLimitBasedOnBalance -
func (*FeeHandlerStub) ComputeGasUsedAndFeeBasedOnRefundValue ¶ added in v1.2.0
func (fhs *FeeHandlerStub) ComputeGasUsedAndFeeBasedOnRefundValue(tx data.TransactionWithFeeHandler, refundValue *big.Int) (uint64, *big.Int)
ComputeGasUsedAndFeeBasedOnRefundValue -
func (*FeeHandlerStub) ComputeMoveBalanceFee ¶ added in v1.1.1
func (fhs *FeeHandlerStub) ComputeMoveBalanceFee(tx data.TransactionWithFeeHandler) *big.Int
ComputeMoveBalanceFee -
func (*FeeHandlerStub) ComputeTxFee ¶ added in v1.1.1
func (fhs *FeeHandlerStub) ComputeTxFee(tx data.TransactionWithFeeHandler) *big.Int
ComputeTxFee -
func (*FeeHandlerStub) ComputeTxFeeBasedOnGasUsed ¶ added in v1.2.0
func (fhs *FeeHandlerStub) ComputeTxFeeBasedOnGasUsed(tx data.TransactionWithFeeHandler, gasUsed uint64) *big.Int
ComputeTxFeeBasedOnGasUsed -
func (*FeeHandlerStub) DeveloperPercentage ¶
func (fhs *FeeHandlerStub) DeveloperPercentage() float64
DeveloperPercentage -
func (*FeeHandlerStub) GasPerDataByte ¶ added in v1.2.0
func (fhs *FeeHandlerStub) GasPerDataByte() uint64
GasPerDataByte -
func (*FeeHandlerStub) GasPriceForMove ¶ added in v1.2.0
func (fhs *FeeHandlerStub) GasPriceForMove(tx data.TransactionWithFeeHandler) uint64
GasPriceForMove -
func (*FeeHandlerStub) GasPriceForProcessing ¶ added in v1.2.0
func (fhs *FeeHandlerStub) GasPriceForProcessing(tx data.TransactionWithFeeHandler) uint64
GasPriceForProcessing -
func (*FeeHandlerStub) GasPriceModifier ¶ added in v1.1.15
func (fhs *FeeHandlerStub) GasPriceModifier() float64
GasPriceModifier -
func (*FeeHandlerStub) GenesisTotalSupply ¶ added in v1.1.22
func (fhs *FeeHandlerStub) GenesisTotalSupply() *big.Int
GenesisTotalSupply -
func (*FeeHandlerStub) IsInterfaceNil ¶
func (fhs *FeeHandlerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*FeeHandlerStub) MaxGasLimitPerBlock ¶
func (fhs *FeeHandlerStub) MaxGasLimitPerBlock(uint32) uint64
MaxGasLimitPerBlock -
func (*FeeHandlerStub) MaxGasLimitPerBlockForSafeCrossShard ¶ added in v1.2.23
func (fhs *FeeHandlerStub) MaxGasLimitPerBlockForSafeCrossShard() uint64
MaxGasLimitPerBlockForSafeCrossShard -
func (*FeeHandlerStub) MaxGasLimitPerMiniBlock ¶ added in v1.2.23
func (fhs *FeeHandlerStub) MaxGasLimitPerMiniBlock(uint32) uint64
MaxGasLimitPerMiniBlock -
func (*FeeHandlerStub) MaxGasLimitPerMiniBlockForSafeCrossShard ¶ added in v1.2.23
func (fhs *FeeHandlerStub) MaxGasLimitPerMiniBlockForSafeCrossShard() uint64
MaxGasLimitPerMiniBlockForSafeCrossShard -
func (*FeeHandlerStub) MinGasLimit ¶ added in v1.0.24
func (fhs *FeeHandlerStub) MinGasLimit() uint64
MinGasLimit will return min gas limit
func (*FeeHandlerStub) MinGasPriceForProcessing ¶ added in v1.2.0
func (fhs *FeeHandlerStub) MinGasPriceForProcessing() uint64
MinGasPriceForProcessing -
func (*FeeHandlerStub) SetMaxGasLimitPerBlock ¶
func (fhs *FeeHandlerStub) SetMaxGasLimitPerBlock(maxGasLimitPerBlock uint64)
SetMaxGasLimitPerBlock -
func (*FeeHandlerStub) SetMinGasLimit ¶
func (fhs *FeeHandlerStub) SetMinGasLimit(minGasLimit uint64)
SetMinGasLimit -
func (*FeeHandlerStub) SetMinGasPrice ¶
func (fhs *FeeHandlerStub) SetMinGasPrice(minGasPrice uint64)
SetMinGasPrice -
func (*FeeHandlerStub) SplitTxGasInCategories ¶ added in v1.2.0
func (fhs *FeeHandlerStub) SplitTxGasInCategories(tx data.TransactionWithFeeHandler) (uint64, uint64)
SplitTxGasInCategories -
type ForkDetectorStub ¶ added in v1.0.102
type ForkDetectorStub struct { AddHeaderCalled func(header data.HeaderHandler, hash []byte, state process.BlockHeaderState, selfNotarizedHeaders []data.HeaderHandler, selfNotarizedHeadersHashes [][]byte) error RemoveHeaderCalled func(nonce uint64, hash []byte) CheckForkCalled func() *process.ForkInfo GetHighestFinalBlockNonceCalled func() uint64 GetHighestFinalBlockHashCalled func() []byte ProbableHighestNonceCalled func() uint64 ResetForkCalled func() GetNotarizedHeaderHashCalled func(nonce uint64) []byte RestoreToGenesisCalled func() SetRollBackNonceCalled func(nonce uint64) ResetProbableHighestNonceCalled func() SetFinalToLastCheckpointCalled func() }
ForkDetectorStub is a mock implementation for the ForkDetector interface
func (*ForkDetectorStub) AddHeader ¶ added in v1.0.102
func (fdm *ForkDetectorStub) AddHeader( header data.HeaderHandler, hash []byte, state process.BlockHeaderState, selfNotarizedHeaders []data.HeaderHandler, selfNotarizedHeadersHashes [][]byte, ) error
AddHeader is a mock implementation for AddHeader
func (*ForkDetectorStub) CheckFork ¶ added in v1.0.102
func (fdm *ForkDetectorStub) CheckFork() *process.ForkInfo
CheckFork is a mock implementation for CheckFork
func (*ForkDetectorStub) GetHighestFinalBlockHash ¶ added in v1.0.102
func (fdm *ForkDetectorStub) GetHighestFinalBlockHash() []byte
GetHighestFinalBlockHash -
func (*ForkDetectorStub) GetHighestFinalBlockNonce ¶ added in v1.0.102
func (fdm *ForkDetectorStub) GetHighestFinalBlockNonce() uint64
GetHighestFinalBlockNonce is a mock implementation for GetHighestFinalBlockNonce
func (*ForkDetectorStub) GetNotarizedHeaderHash ¶ added in v1.0.102
func (fdm *ForkDetectorStub) GetNotarizedHeaderHash(nonce uint64) []byte
GetNotarizedHeaderHash -
func (*ForkDetectorStub) IsInterfaceNil ¶ added in v1.0.102
func (fdm *ForkDetectorStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ForkDetectorStub) ProbableHighestNonce ¶ added in v1.0.102
func (fdm *ForkDetectorStub) ProbableHighestNonce() uint64
ProbableHighestNonce is a mock implementation for ProbableHighestNonce
func (*ForkDetectorStub) RemoveHeader ¶ added in v1.0.102
func (fdm *ForkDetectorStub) RemoveHeader(nonce uint64, hash []byte)
RemoveHeader is a mock implementation for RemoveHeader
func (*ForkDetectorStub) ResetFork ¶ added in v1.0.102
func (fdm *ForkDetectorStub) ResetFork()
ResetFork -
func (*ForkDetectorStub) ResetProbableHighestNonce ¶ added in v1.0.102
func (fdm *ForkDetectorStub) ResetProbableHighestNonce()
ResetProbableHighestNonce -
func (*ForkDetectorStub) RestoreToGenesis ¶ added in v1.0.102
func (fdm *ForkDetectorStub) RestoreToGenesis()
RestoreToGenesis -
func (*ForkDetectorStub) SetFinalToLastCheckpoint ¶ added in v1.1.1
func (fdm *ForkDetectorStub) SetFinalToLastCheckpoint()
SetFinalToLastCheckpoint -
func (*ForkDetectorStub) SetRollBackNonce ¶ added in v1.0.102
func (fdm *ForkDetectorStub) SetRollBackNonce(nonce uint64)
SetRollBackNonce -
type GasHandlerMock ¶
type GasHandlerMock struct { InitCalled func() SetGasConsumedCalled func(gasConsumed uint64, hash []byte) SetGasRefundedCalled func(gasRefunded uint64, hash []byte) SetGasPenalizedCalled func(gasPenalized uint64, hash []byte) GasConsumedCalled func(hash []byte) uint64 GasRefundedCalled func(hash []byte) uint64 GasPenalizedCalled func(hash []byte) uint64 TotalGasConsumedCalled func() uint64 TotalGasRefundedCalled func() uint64 TotalGasPenalizedCalled func() uint64 RemoveGasConsumedCalled func(hashes [][]byte) RemoveGasRefundedCalled func(hashes [][]byte) RemoveGasPenalizedCalled func(hashes [][]byte) ComputeGasConsumedByMiniBlockCalled func(miniBlock *block.MiniBlock, mapHashTx map[string]data.TransactionHandler) (uint64, uint64, error) ComputeGasConsumedByTxCalled func(txSenderShardId uint32, txReceiverSharedId uint32, txHandler data.TransactionHandler) (uint64, uint64, error) }
GasHandlerMock -
func (*GasHandlerMock) ComputeGasConsumedByMiniBlock ¶
func (ghm *GasHandlerMock) ComputeGasConsumedByMiniBlock(miniBlock *block.MiniBlock, mapHashTx map[string]data.TransactionHandler) (uint64, uint64, error)
ComputeGasConsumedByMiniBlock -
func (*GasHandlerMock) ComputeGasConsumedByTx ¶
func (ghm *GasHandlerMock) ComputeGasConsumedByTx(txSenderShardId uint32, txReceiverShardId uint32, txHandler data.TransactionHandler) (uint64, uint64, error)
ComputeGasConsumedByTx -
func (*GasHandlerMock) GasConsumed ¶
func (ghm *GasHandlerMock) GasConsumed(hash []byte) uint64
GasConsumed -
func (*GasHandlerMock) GasPenalized ¶ added in v1.2.23
func (ghm *GasHandlerMock) GasPenalized(hash []byte) uint64
GasPenalized -
func (*GasHandlerMock) GasRefunded ¶
func (ghm *GasHandlerMock) GasRefunded(hash []byte) uint64
GasRefunded -
func (*GasHandlerMock) IsInterfaceNil ¶
func (ghm *GasHandlerMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*GasHandlerMock) RemoveGasConsumed ¶
func (ghm *GasHandlerMock) RemoveGasConsumed(hashes [][]byte)
RemoveGasConsumed -
func (*GasHandlerMock) RemoveGasPenalized ¶ added in v1.2.23
func (ghm *GasHandlerMock) RemoveGasPenalized(hashes [][]byte)
RemoveGasPenalized -
func (*GasHandlerMock) RemoveGasRefunded ¶
func (ghm *GasHandlerMock) RemoveGasRefunded(hashes [][]byte)
RemoveGasRefunded -
func (*GasHandlerMock) SetGasConsumed ¶
func (ghm *GasHandlerMock) SetGasConsumed(gasConsumed uint64, hash []byte)
SetGasConsumed -
func (*GasHandlerMock) SetGasPenalized ¶ added in v1.2.23
func (ghm *GasHandlerMock) SetGasPenalized(gasPenalized uint64, hash []byte)
SetGasPenalized -
func (*GasHandlerMock) SetGasRefunded ¶
func (ghm *GasHandlerMock) SetGasRefunded(gasRefunded uint64, hash []byte)
SetGasRefunded -
func (*GasHandlerMock) TotalGasConsumed ¶
func (ghm *GasHandlerMock) TotalGasConsumed() uint64
TotalGasConsumed -
func (*GasHandlerMock) TotalGasPenalized ¶ added in v1.2.23
func (ghm *GasHandlerMock) TotalGasPenalized() uint64
TotalGasPenalized -
func (*GasHandlerMock) TotalGasRefunded ¶
func (ghm *GasHandlerMock) TotalGasRefunded() uint64
TotalGasRefunded -
type GasScheduleNotifierMock ¶ added in v1.1.12
type GasScheduleNotifierMock struct { GasSchedule map[string]map[string]uint64 Handlers []core.GasScheduleSubscribeHandler }
GasScheduleNotifierMock -
func NewGasScheduleNotifierMock ¶ added in v1.1.12
func NewGasScheduleNotifierMock(gasSchedule map[string]map[string]uint64) *GasScheduleNotifierMock
NewGasScheduleNotifierMock -
func (*GasScheduleNotifierMock) ChangeGasSchedule ¶ added in v1.2.23
func (g *GasScheduleNotifierMock) ChangeGasSchedule(gasSchedule map[string]map[string]uint64)
ChangeGasSchedule -
func (*GasScheduleNotifierMock) IsInterfaceNil ¶ added in v1.1.12
func (g *GasScheduleNotifierMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*GasScheduleNotifierMock) LatestGasSchedule ¶ added in v1.1.12
func (g *GasScheduleNotifierMock) LatestGasSchedule() map[string]map[string]uint64
LatestGasSchedule -
func (*GasScheduleNotifierMock) RegisterNotifyHandler ¶ added in v1.1.12
func (g *GasScheduleNotifierMock) RegisterNotifyHandler(handler core.GasScheduleSubscribeHandler)
RegisterNotifyHandler -
func (*GasScheduleNotifierMock) UnRegisterAll ¶ added in v1.1.12
func (g *GasScheduleNotifierMock) UnRegisterAll()
UnRegisterAll -
type HardforkTriggerStub ¶ added in v1.0.102
type HardforkTriggerStub struct { TriggerCalled func(epoch uint32, withEarlyEndOfEpoch bool) error IsSelfTriggerCalled func() bool TriggerReceivedCalled func(payload []byte, data []byte, pkBytes []byte) (bool, error) RecordedTriggerMessageCalled func() ([]byte, bool) CreateDataCalled func() []byte AddCloserCalled func(closer update.Closer) error NotifyTriggerReceivedCalled func() <-chan struct{} }
HardforkTriggerStub -
func (*HardforkTriggerStub) AddCloser ¶ added in v1.0.133
func (hts *HardforkTriggerStub) AddCloser(closer update.Closer) error
AddCloser -
func (*HardforkTriggerStub) CreateData ¶ added in v1.0.115
func (hts *HardforkTriggerStub) CreateData() []byte
CreateData -
func (*HardforkTriggerStub) IsInterfaceNil ¶ added in v1.0.102
func (hts *HardforkTriggerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HardforkTriggerStub) IsSelfTrigger ¶ added in v1.0.102
func (hts *HardforkTriggerStub) IsSelfTrigger() bool
IsSelfTrigger -
func (*HardforkTriggerStub) NotifyTriggerReceived ¶ added in v1.0.133
func (hts *HardforkTriggerStub) NotifyTriggerReceived() <-chan struct{}
NotifyTriggerReceived -
func (*HardforkTriggerStub) RecordedTriggerMessage ¶ added in v1.0.102
func (hts *HardforkTriggerStub) RecordedTriggerMessage() ([]byte, bool)
RecordedTriggerMessage -
func (*HardforkTriggerStub) Trigger ¶ added in v1.0.102
func (hts *HardforkTriggerStub) Trigger(epoch uint32, withEarlyEndOfEpoch bool) error
Trigger -
func (*HardforkTriggerStub) TriggerReceived ¶ added in v1.0.102
func (hts *HardforkTriggerStub) TriggerReceived(payload []byte, data []byte, pkBytes []byte) (bool, error)
TriggerReceived -
type HeaderIntegrityVerifierStub ¶ added in v1.0.117
type HeaderIntegrityVerifierStub struct { VerifyCalled func(header data.HeaderHandler) error GetVersionCalled func(epoch uint32) string }
HeaderIntegrityVerifierStub -
func (*HeaderIntegrityVerifierStub) GetVersion ¶ added in v1.1.1
func (h *HeaderIntegrityVerifierStub) GetVersion(epoch uint32) string
GetVersion -
func (*HeaderIntegrityVerifierStub) IsInterfaceNil ¶ added in v1.0.117
func (h *HeaderIntegrityVerifierStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HeaderIntegrityVerifierStub) Verify ¶ added in v1.0.117
func (h *HeaderIntegrityVerifierStub) Verify(header data.HeaderHandler) error
Verify -
type HeaderResolverStub ¶ added in v1.2.0
type HeaderResolverStub struct { RequestDataFromHashCalled func(hash []byte, epoch uint32) error ProcessReceivedMessageCalled func(message p2p.MessageP2P) error RequestDataFromNonceCalled func(nonce uint64, epoch uint32) error RequestDataFromEpochCalled func(identifier []byte) error SetEpochHandlerCalled func(epochHandler dataRetriever.EpochHandler) error SetNumPeersToQueryCalled func(intra int, cross int) NumPeersToQueryCalled func() (int, int) SetResolverDebugHandlerCalled func(handler dataRetriever.ResolverDebugHandler) error CloseCalled func() error }
HeaderResolverStub -
func (*HeaderResolverStub) Close ¶ added in v1.2.0
func (hrs *HeaderResolverStub) Close() error
Close -
func (*HeaderResolverStub) IsInterfaceNil ¶ added in v1.2.0
func (hrs *HeaderResolverStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*HeaderResolverStub) NumPeersToQuery ¶ added in v1.2.0
func (hrs *HeaderResolverStub) NumPeersToQuery() (int, int)
NumPeersToQuery -
func (*HeaderResolverStub) ProcessReceivedMessage ¶ added in v1.2.0
func (hrs *HeaderResolverStub) ProcessReceivedMessage(message p2p.MessageP2P, _ core.PeerID) error
ProcessReceivedMessage -
func (*HeaderResolverStub) RequestDataFromEpoch ¶ added in v1.2.0
func (hrs *HeaderResolverStub) RequestDataFromEpoch(identifier []byte) error
RequestDataFromEpoch -
func (*HeaderResolverStub) RequestDataFromHash ¶ added in v1.2.0
func (hrs *HeaderResolverStub) RequestDataFromHash(hash []byte, epoch uint32) error
RequestDataFromHash -
func (*HeaderResolverStub) RequestDataFromNonce ¶ added in v1.2.0
func (hrs *HeaderResolverStub) RequestDataFromNonce(nonce uint64, epoch uint32) error
RequestDataFromNonce -
func (*HeaderResolverStub) SetEpochHandler ¶ added in v1.2.0
func (hrs *HeaderResolverStub) SetEpochHandler(epochHandler dataRetriever.EpochHandler) error
SetEpochHandler -
func (*HeaderResolverStub) SetNumPeersToQuery ¶ added in v1.2.0
func (hrs *HeaderResolverStub) SetNumPeersToQuery(intra int, cross int)
SetNumPeersToQuery -
func (*HeaderResolverStub) SetResolverDebugHandler ¶ added in v1.2.0
func (hrs *HeaderResolverStub) SetResolverDebugHandler(handler dataRetriever.ResolverDebugHandler) error
SetResolverDebugHandler -
type HeaderSigVerifierStub ¶
type HeaderSigVerifierStub struct { VerifyRandSeedAndLeaderSignatureCalled func(header data.HeaderHandler) error VerifySignatureCalled func(header data.HeaderHandler) error VerifyRandSeedCalled func(header data.HeaderHandler) error VerifyLeaderSignatureCalled func(header data.HeaderHandler) error }
HeaderSigVerifierStub -
func (*HeaderSigVerifierStub) IsInterfaceNil ¶
func (hsvm *HeaderSigVerifierStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HeaderSigVerifierStub) VerifyLeaderSignature ¶ added in v1.1.2
func (hsvm *HeaderSigVerifierStub) VerifyLeaderSignature(header data.HeaderHandler) error
VerifyLeaderSignature -
func (*HeaderSigVerifierStub) VerifyRandSeed ¶
func (hsvm *HeaderSigVerifierStub) VerifyRandSeed(header data.HeaderHandler) error
VerifyRandSeed -
func (*HeaderSigVerifierStub) VerifyRandSeedAndLeaderSignature ¶
func (hsvm *HeaderSigVerifierStub) VerifyRandSeedAndLeaderSignature(header data.HeaderHandler) error
VerifyRandSeedAndLeaderSignature -
func (*HeaderSigVerifierStub) VerifySignature ¶
func (hsvm *HeaderSigVerifierStub) VerifySignature(header data.HeaderHandler) error
VerifySignature -
type HeaderValidatorStub ¶ added in v1.2.0
type HeaderValidatorStub struct {
IsHeaderConstructionValidCalled func(currHdr, prevHdr data.HeaderHandler) error
}
HeaderValidatorStub -
func (*HeaderValidatorStub) IsHeaderConstructionValid ¶ added in v1.2.0
func (hvs *HeaderValidatorStub) IsHeaderConstructionValid(currHdr, prevHdr data.HeaderHandler) error
IsHeaderConstructionValid -
func (*HeaderValidatorStub) IsInterfaceNil ¶ added in v1.2.0
func (hvs *HeaderValidatorStub) IsInterfaceNil() bool
IsInterfaceNil returns if underlying object is true
type HeadersCacherStub ¶
type HeadersCacherStub struct { AddCalled func(headerHash []byte, header data.HeaderHandler) RemoveHeaderByHashCalled func(headerHash []byte) RemoveHeaderByNonceAndShardIdCalled func(hdrNonce uint64, shardId uint32) GetHeaderByNonceAndShardIdCalled func(hdrNonce uint64, shardId uint32) ([]data.HeaderHandler, [][]byte, error) GetHeaderByHashCalled func(hash []byte) (data.HeaderHandler, error) ClearCalled func() RegisterHandlerCalled func(handler func(key []byte, value interface{})) KeysCalled func(shardId uint32) []uint64 LenCalled func() int MaxSizeCalled func() int }
HeadersCacherStub -
func (*HeadersCacherStub) AddHeader ¶
func (hcs *HeadersCacherStub) AddHeader(headerHash []byte, header data.HeaderHandler)
AddHeader -
func (*HeadersCacherStub) GetHeaderByHash ¶
func (hcs *HeadersCacherStub) GetHeaderByHash(hash []byte) (data.HeaderHandler, error)
GetHeaderByHash -
func (*HeadersCacherStub) GetHeadersByNonceAndShardId ¶
func (hcs *HeadersCacherStub) GetHeadersByNonceAndShardId(hdrNonce uint64, shardId uint32) ([]data.HeaderHandler, [][]byte, error)
GetHeadersByNonceAndShardId -
func (*HeadersCacherStub) IsInterfaceNil ¶
func (hcs *HeadersCacherStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HeadersCacherStub) RegisterHandler ¶
func (hcs *HeadersCacherStub) RegisterHandler(handler func(key []byte, value interface{}))
RegisterHandler -
func (*HeadersCacherStub) RemoveHeaderByHash ¶
func (hcs *HeadersCacherStub) RemoveHeaderByHash(headerHash []byte)
RemoveHeaderByHash -
func (*HeadersCacherStub) RemoveHeaderByNonceAndShardId ¶
func (hcs *HeadersCacherStub) RemoveHeaderByNonceAndShardId(hdrNonce uint64, shardId uint32)
RemoveHeaderByNonceAndShardId -
type HeartbeatComponentsStub ¶ added in v1.2.0
type HeartbeatComponentsStub struct { HBMessenger heartbeat.MessageHandler HBMonitor factory.HeartbeatMonitor HBSender factory.HeartbeatSender HBStorer factory.HeartbeatStorer }
HeartbeatComponentsStub -
func (*HeartbeatComponentsStub) CheckSubcomponents ¶ added in v1.2.0
func (hbs *HeartbeatComponentsStub) CheckSubcomponents() error
CheckSubcomponents -
func (*HeartbeatComponentsStub) Close ¶ added in v1.2.0
func (hbs *HeartbeatComponentsStub) Close() error
Close -
func (*HeartbeatComponentsStub) Create ¶ added in v1.2.0
func (hbs *HeartbeatComponentsStub) Create() error
Create -
func (*HeartbeatComponentsStub) IsInterfaceNil ¶ added in v1.2.0
func (hbs *HeartbeatComponentsStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HeartbeatComponentsStub) MessageHandler ¶ added in v1.2.0
func (hbs *HeartbeatComponentsStub) MessageHandler() heartbeat.MessageHandler
MessageHandler -
func (*HeartbeatComponentsStub) Monitor ¶ added in v1.2.0
func (hbs *HeartbeatComponentsStub) Monitor() factory.HeartbeatMonitor
Monitor -
func (*HeartbeatComponentsStub) Sender ¶ added in v1.2.0
func (hbs *HeartbeatComponentsStub) Sender() factory.HeartbeatSender
Sender -
func (*HeartbeatComponentsStub) Storer ¶ added in v1.2.0
func (hbs *HeartbeatComponentsStub) Storer() factory.HeartbeatStorer
Storer -
type HeartbeatMessageHandlerStub ¶ added in v1.2.0
type HeartbeatMessageHandlerStub struct {
CreateHeartbeatFromP2PMessageCalled func(message p2p.MessageP2P) (*data.Heartbeat, error)
}
HeartbeatMessageHandlerStub -
func (*HeartbeatMessageHandlerStub) CreateHeartbeatFromP2PMessage ¶ added in v1.2.0
func (hbmh *HeartbeatMessageHandlerStub) CreateHeartbeatFromP2PMessage(message p2p.MessageP2P) (*data.Heartbeat, error)
CreateHeartbeatFromP2PMessage -
func (*HeartbeatMessageHandlerStub) IsInterfaceNil ¶ added in v1.2.0
func (hbmh *HeartbeatMessageHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
type HeartbeatMonitorStub ¶ added in v1.2.0
type HeartbeatMonitorStub struct { ProcessReceivedMessageCalled func(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error GetHeartbeatsCalled func() []heartbeatData.PubKeyHeartbeat CleanupCalled func() }
HeartbeatMonitorStub -
func (*HeartbeatMonitorStub) Cleanup ¶ added in v1.2.0
func (hbms *HeartbeatMonitorStub) Cleanup()
Cleanup -
func (*HeartbeatMonitorStub) Close ¶ added in v1.2.0
func (hbms *HeartbeatMonitorStub) Close() error
Close -
func (*HeartbeatMonitorStub) GetHeartbeats ¶ added in v1.2.0
func (hbms *HeartbeatMonitorStub) GetHeartbeats() []heartbeatData.PubKeyHeartbeat
GetHeartbeats -
func (*HeartbeatMonitorStub) IsInterfaceNil ¶ added in v1.2.0
func (hbms *HeartbeatMonitorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HeartbeatMonitorStub) ProcessReceivedMessage ¶ added in v1.2.0
func (hbms *HeartbeatMonitorStub) ProcessReceivedMessage(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error
ProcessReceivedMessage -
type HeartbeatSenderStub ¶ added in v1.2.0
type HeartbeatSenderStub struct {
SendHeartbeatCalled func() error
}
HeartbeatSenderStub -
func (*HeartbeatSenderStub) IsInterfaceNil ¶ added in v1.2.0
func (hbss *HeartbeatSenderStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HeartbeatSenderStub) SendHeartbeat ¶ added in v1.2.0
func (hbss *HeartbeatSenderStub) SendHeartbeat() error
SendHeartbeat -
type HeartbeatStorerStub ¶ added in v1.0.102
type HeartbeatStorerStub struct { LoadGenesisTimeCalled func() (time.Time, error) UpdateGenesisTimeCalled func(genesisTime time.Time) error LoadHeartBeatDTOCalled func(pubKey string) (*data.HeartbeatDTO, error) SavePubkeyDataCalled func(pubkey []byte, heartbeat *data.HeartbeatDTO) error LoadKeysCalled func() ([][]byte, error) SaveKeysCalled func(peersSlice [][]byte) error }
HeartbeatStorerStub -
func (*HeartbeatStorerStub) IsInterfaceNil ¶ added in v1.0.102
func (hss *HeartbeatStorerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HeartbeatStorerStub) LoadGenesisTime ¶ added in v1.0.102
func (hss *HeartbeatStorerStub) LoadGenesisTime() (time.Time, error)
LoadGenesisTime -
func (*HeartbeatStorerStub) LoadHeartBeatDTO ¶ added in v1.0.115
func (hss *HeartbeatStorerStub) LoadHeartBeatDTO(pubKey string) (*data.HeartbeatDTO, error)
LoadHeartBeatDTO -
func (*HeartbeatStorerStub) LoadKeys ¶ added in v1.0.102
func (hss *HeartbeatStorerStub) LoadKeys() ([][]byte, error)
LoadKeys -
func (*HeartbeatStorerStub) SaveKeys ¶ added in v1.0.102
func (hss *HeartbeatStorerStub) SaveKeys(peersSlice [][]byte) error
SaveKeys -
func (*HeartbeatStorerStub) SavePubkeyData ¶ added in v1.0.102
func (hss *HeartbeatStorerStub) SavePubkeyData(pubkey []byte, heartbeat *data.HeartbeatDTO) error
SavePubkeyData -
func (*HeartbeatStorerStub) UpdateGenesisTime ¶ added in v1.0.102
func (hss *HeartbeatStorerStub) UpdateGenesisTime(genesisTime time.Time) error
UpdateGenesisTime -
type ImportStartHandlerStub ¶ added in v1.0.133
type ImportStartHandlerStub struct { SetStartImportCalled func() error ResetStartImportCalled func() error ShouldStartImportCalled func() bool IsAfterExportBeforeImportCalled func() bool }
ImportStartHandlerStub -
func (*ImportStartHandlerStub) IsAfterExportBeforeImport ¶ added in v1.0.133
func (ish *ImportStartHandlerStub) IsAfterExportBeforeImport() bool
IsAfterExportBeforeImport -
func (*ImportStartHandlerStub) IsInterfaceNil ¶ added in v1.0.133
func (ish *ImportStartHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ImportStartHandlerStub) ResetStartImport ¶ added in v1.0.133
func (ish *ImportStartHandlerStub) ResetStartImport() error
ResetStartImport -
func (*ImportStartHandlerStub) SetStartImport ¶ added in v1.0.133
func (ish *ImportStartHandlerStub) SetStartImport() error
SetStartImport -
func (*ImportStartHandlerStub) ShouldStartImport ¶ added in v1.0.133
func (ish *ImportStartHandlerStub) ShouldStartImport() bool
ShouldStartImport -
type InterimProcessorContainerMock ¶
type InterimProcessorContainerMock struct { GetCalled func(key block.Type) (process.IntermediateTransactionHandler, error) KeysCalled func() []block.Type }
InterimProcessorContainerMock -
func (*InterimProcessorContainerMock) Add ¶
func (ipcm *InterimProcessorContainerMock) Add(key block.Type, val process.IntermediateTransactionHandler) error
Add -
func (*InterimProcessorContainerMock) AddMultiple ¶
func (ipcm *InterimProcessorContainerMock) AddMultiple(keys []block.Type, preprocessors []process.IntermediateTransactionHandler) error
AddMultiple -
func (*InterimProcessorContainerMock) Get ¶
func (ipcm *InterimProcessorContainerMock) Get(key block.Type) (process.IntermediateTransactionHandler, error)
Get -
func (*InterimProcessorContainerMock) IsInterfaceNil ¶
func (ipcm *InterimProcessorContainerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*InterimProcessorContainerMock) Keys ¶
func (ipcm *InterimProcessorContainerMock) Keys() []block.Type
Keys -
func (*InterimProcessorContainerMock) Len ¶
func (ipcm *InterimProcessorContainerMock) Len() int
Len -
func (*InterimProcessorContainerMock) Remove ¶
func (ipcm *InterimProcessorContainerMock) Remove(key block.Type)
Remove -
func (*InterimProcessorContainerMock) Replace ¶
func (ipcm *InterimProcessorContainerMock) Replace(key block.Type, val process.IntermediateTransactionHandler) error
Replace -
type IntermediateTransactionHandlerMock ¶
type IntermediateTransactionHandlerMock struct { AddIntermediateTransactionsCalled func(txs []data.TransactionHandler) error GetNumOfCrossInterMbsAndTxsCalled func() (int, int) CreateAllInterMiniBlocksCalled func() []*block.MiniBlock VerifyInterMiniBlocksCalled func(body *block.Body) error SaveCurrentIntermediateTxToStorageCalled func() error CreateBlockStartedCalled func() CreateMarshalizedDataCalled func(txHashes [][]byte) ([][]byte, error) GetAllCurrentFinishedTxsCalled func() map[string]data.TransactionHandler RemoveProcessedResultsCalled func() InitProcessedResultsCalled func() // contains filtered or unexported fields }
IntermediateTransactionHandlerMock -
func (*IntermediateTransactionHandlerMock) AddIntermediateTransactions ¶
func (ith *IntermediateTransactionHandlerMock) AddIntermediateTransactions(txs []data.TransactionHandler) error
AddIntermediateTransactions -
func (*IntermediateTransactionHandlerMock) Clean ¶ added in v1.1.15
func (ith *IntermediateTransactionHandlerMock) Clean()
Clean -
func (*IntermediateTransactionHandlerMock) CreateAllInterMiniBlocks ¶
func (ith *IntermediateTransactionHandlerMock) CreateAllInterMiniBlocks() []*block.MiniBlock
CreateAllInterMiniBlocks -
func (*IntermediateTransactionHandlerMock) CreateBlockStarted ¶
func (ith *IntermediateTransactionHandlerMock) CreateBlockStarted()
CreateBlockStarted -
func (*IntermediateTransactionHandlerMock) CreateMarshalizedData ¶
func (ith *IntermediateTransactionHandlerMock) CreateMarshalizedData(txHashes [][]byte) ([][]byte, error)
CreateMarshalizedData -
func (*IntermediateTransactionHandlerMock) GetAllCurrentFinishedTxs ¶
func (ith *IntermediateTransactionHandlerMock) GetAllCurrentFinishedTxs() map[string]data.TransactionHandler
GetAllCurrentFinishedTxs -
func (*IntermediateTransactionHandlerMock) GetCreatedInShardMiniBlock ¶
func (ith *IntermediateTransactionHandlerMock) GetCreatedInShardMiniBlock() *block.MiniBlock
GetCreatedInShardMiniBlock -
func (*IntermediateTransactionHandlerMock) GetIntermediateTransactions ¶ added in v1.0.103
func (ith *IntermediateTransactionHandlerMock) GetIntermediateTransactions() []data.TransactionHandler
GetIntermediateTransactions -
func (*IntermediateTransactionHandlerMock) GetNumOfCrossInterMbsAndTxs ¶ added in v1.1.1
func (ith *IntermediateTransactionHandlerMock) GetNumOfCrossInterMbsAndTxs() (int, int)
GetNumOfCrossInterMbsAndTxs -
func (*IntermediateTransactionHandlerMock) InitProcessedResults ¶ added in v1.2.23
func (ith *IntermediateTransactionHandlerMock) InitProcessedResults()
InitProcessedResults -
func (*IntermediateTransactionHandlerMock) IsInterfaceNil ¶
func (ith *IntermediateTransactionHandlerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*IntermediateTransactionHandlerMock) RemoveProcessedResults ¶ added in v1.2.23
func (ith *IntermediateTransactionHandlerMock) RemoveProcessedResults()
RemoveProcessedResults -
func (*IntermediateTransactionHandlerMock) SaveCurrentIntermediateTxToStorage ¶
func (ith *IntermediateTransactionHandlerMock) SaveCurrentIntermediateTxToStorage() error
SaveCurrentIntermediateTxToStorage -
func (*IntermediateTransactionHandlerMock) VerifyInterMiniBlocks ¶
func (ith *IntermediateTransactionHandlerMock) VerifyInterMiniBlocks(body *block.Body) error
VerifyInterMiniBlocks -
type KeyGenMock ¶
type KeyGenMock struct { }
KeyGenMock -
func (*KeyGenMock) CheckPublicKeyValid ¶ added in v1.0.120
func (keyGen *KeyGenMock) CheckPublicKeyValid(_ []byte) error
CheckPublicKeyValid -
func (*KeyGenMock) GeneratePair ¶
func (keyGen *KeyGenMock) GeneratePair() (crypto.PrivateKey, crypto.PublicKey)
GeneratePair -
func (*KeyGenMock) IsInterfaceNil ¶
func (keyGen *KeyGenMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*KeyGenMock) PrivateKeyFromByteArray ¶
func (keyGen *KeyGenMock) PrivateKeyFromByteArray(buff []byte) (crypto.PrivateKey, error)
PrivateKeyFromByteArray -
func (*KeyGenMock) PublicKeyFromByteArray ¶
func (keyGen *KeyGenMock) PublicKeyFromByteArray(buff []byte) (crypto.PublicKey, error)
PublicKeyFromByteArray -
type LatestStorageDataProviderStub ¶ added in v1.0.111
type LatestStorageDataProviderStub struct { GetCalled func() (storage.LatestDataFromStorage, error) GetParentDirAndLastEpochCalled func() (string, uint32, error) GetShardsFromDirectoryCalled func(path string) ([]string, error) }
LatestStorageDataProviderStub -
func (*LatestStorageDataProviderStub) Get ¶ added in v1.0.111
func (l *LatestStorageDataProviderStub) Get() (storage.LatestDataFromStorage, error)
Get -
func (*LatestStorageDataProviderStub) GetParentDirAndLastEpoch ¶ added in v1.0.111
func (l *LatestStorageDataProviderStub) GetParentDirAndLastEpoch() (string, uint32, error)
GetParentDirAndLastEpoch -
func (*LatestStorageDataProviderStub) GetShardsFromDirectory ¶ added in v1.0.111
func (l *LatestStorageDataProviderStub) GetShardsFromDirectory(path string) ([]string, error)
GetShardsFromDirectory --
func (*LatestStorageDataProviderStub) IsInterfaceNil ¶ added in v1.0.111
func (l *LatestStorageDataProviderStub) IsInterfaceNil() bool
IsInterfaceNil --
type ListIndexUpdaterStub ¶ added in v1.0.102
type ListIndexUpdaterStub struct {
UpdateListAndIndexCalled func(pubKey string, shardID uint32, list string, index uint32) error
}
ListIndexUpdaterStub -
func (*ListIndexUpdaterStub) IsInterfaceNil ¶ added in v1.0.102
func (lius *ListIndexUpdaterStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ListIndexUpdaterStub) UpdateListAndIndex ¶ added in v1.0.102
func (lius *ListIndexUpdaterStub) UpdateListAndIndex(pubKey string, shardID uint32, list string, index uint32) error
UpdateListAndIndex -
type MessageSignVerifierMock ¶ added in v1.1.34
type MessageSignVerifierMock struct { }
MessageSignVerifierMock -
func (*MessageSignVerifierMock) IsInterfaceNil ¶ added in v1.1.34
func (m *MessageSignVerifierMock) IsInterfaceNil() bool
IsInterfaceNil -
type MiniBlocksProviderStub ¶ added in v1.2.0
type MiniBlocksProviderStub struct { GetMiniBlocksCalled func(hashes [][]byte) ([]*block.MiniblockAndHash, [][]byte) GetMiniBlocksFromPoolCalled func(hashes [][]byte) ([]*block.MiniblockAndHash, [][]byte) }
MiniBlocksProviderStub -
func (*MiniBlocksProviderStub) GetMiniBlocks ¶ added in v1.2.0
func (mbps *MiniBlocksProviderStub) GetMiniBlocks(hashes [][]byte) ([]*block.MiniblockAndHash, [][]byte)
GetMiniBlocks -
func (*MiniBlocksProviderStub) GetMiniBlocksFromPool ¶ added in v1.2.0
func (mbps *MiniBlocksProviderStub) GetMiniBlocksFromPool(hashes [][]byte) ([]*block.MiniblockAndHash, [][]byte)
GetMiniBlocksFromPool -
func (*MiniBlocksProviderStub) IsInterfaceNil ¶ added in v1.2.0
func (mbps *MiniBlocksProviderStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type MiniBlocksResolverStub ¶ added in v1.2.0
type MiniBlocksResolverStub struct { RequestDataFromHashCalled func(hash []byte, epoch uint32) error RequestDataFromHashArrayCalled func(hashes [][]byte, epoch uint32) error ProcessReceivedMessageCalled func(message p2p.MessageP2P) error SetNumPeersToQueryCalled func(intra int, cross int) NumPeersToQueryCalled func() (int, int) CloseCalled func() error }
MiniBlocksResolverStub -
func (*MiniBlocksResolverStub) Close ¶ added in v1.2.0
func (mbrs *MiniBlocksResolverStub) Close() error
Close -
func (*MiniBlocksResolverStub) IsInterfaceNil ¶ added in v1.2.0
func (mbrs *MiniBlocksResolverStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*MiniBlocksResolverStub) NumPeersToQuery ¶ added in v1.2.0
func (mbrs *MiniBlocksResolverStub) NumPeersToQuery() (int, int)
NumPeersToQuery -
func (*MiniBlocksResolverStub) ProcessReceivedMessage ¶ added in v1.2.0
func (mbrs *MiniBlocksResolverStub) ProcessReceivedMessage(message p2p.MessageP2P, _ core.PeerID) error
ProcessReceivedMessage -
func (*MiniBlocksResolverStub) RequestDataFromHash ¶ added in v1.2.0
func (mbrs *MiniBlocksResolverStub) RequestDataFromHash(hash []byte, epoch uint32) error
RequestDataFromHash -
func (*MiniBlocksResolverStub) RequestDataFromHashArray ¶ added in v1.2.0
func (mbrs *MiniBlocksResolverStub) RequestDataFromHashArray(hashes [][]byte, epoch uint32) error
RequestDataFromHashArray -
func (*MiniBlocksResolverStub) SetNumPeersToQuery ¶ added in v1.2.0
func (mbrs *MiniBlocksResolverStub) SetNumPeersToQuery(intra int, cross int)
SetNumPeersToQuery -
func (*MiniBlocksResolverStub) SetResolverDebugHandler ¶ added in v1.2.0
func (mbrs *MiniBlocksResolverStub) SetResolverDebugHandler(_ dataRetriever.ResolverDebugHandler) error
SetResolverDebugHandler -
type MockDB ¶
type MockDB struct { }
MockDB -
func (MockDB) IsInterfaceNil ¶
IsInterfaceNil returns true if there is no value under the interface
type NetworkComponentsStub ¶ added in v1.2.0
type NetworkComponentsStub struct { Messenger p2p.Messenger InputAntiFlood factory.P2PAntifloodHandler OutputAntiFlood factory.P2PAntifloodHandler PeerBlackList process.PeerBlackListCacher PeerHonesty factory.PeerHonestyHandler PreferredPeersHolder factory.PreferredPeersHolderHandler }
NetworkComponentsStub -
func (*NetworkComponentsStub) CheckSubcomponents ¶ added in v1.2.0
func (ncs *NetworkComponentsStub) CheckSubcomponents() error
CheckSubcomponents -
func (*NetworkComponentsStub) Close ¶ added in v1.2.0
func (ncs *NetworkComponentsStub) Close() error
Close -
func (*NetworkComponentsStub) Create ¶ added in v1.2.0
func (ncs *NetworkComponentsStub) Create() error
Create -
func (*NetworkComponentsStub) InputAntiFloodHandler ¶ added in v1.2.0
func (ncs *NetworkComponentsStub) InputAntiFloodHandler() factory.P2PAntifloodHandler
InputAntiFloodHandler -
func (*NetworkComponentsStub) IsInterfaceNil ¶ added in v1.2.0
func (ncs *NetworkComponentsStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*NetworkComponentsStub) NetworkMessenger ¶ added in v1.2.0
func (ncs *NetworkComponentsStub) NetworkMessenger() p2p.Messenger
NetworkMessenger -
func (*NetworkComponentsStub) OutputAntiFloodHandler ¶ added in v1.2.0
func (ncs *NetworkComponentsStub) OutputAntiFloodHandler() factory.P2PAntifloodHandler
OutputAntiFloodHandler -
func (*NetworkComponentsStub) PeerBlackListHandler ¶ added in v1.2.0
func (ncs *NetworkComponentsStub) PeerBlackListHandler() process.PeerBlackListCacher
PeerBlackListHandler -
func (*NetworkComponentsStub) PeerHonestyHandler ¶ added in v1.2.0
func (ncs *NetworkComponentsStub) PeerHonestyHandler() factory.PeerHonestyHandler
PeerHonestyHandler -
func (*NetworkComponentsStub) PreferredPeersHolderHandler ¶ added in v1.2.3
func (ncs *NetworkComponentsStub) PreferredPeersHolderHandler() factory.PreferredPeersHolderHandler
PreferredPeersHolderHandler -
func (*NetworkComponentsStub) PubKeyCacher ¶ added in v1.2.0
func (ncs *NetworkComponentsStub) PubKeyCacher() process.TimeCacher
PubKeyCacher -
func (*NetworkComponentsStub) String ¶ added in v1.2.12
func (ncs *NetworkComponentsStub) String() string
String -
type NilAntifloodHandler ¶
type NilAntifloodHandler struct { }
NilAntifloodHandler is an empty implementation of P2PAntifloodHandler it does nothing
func (*NilAntifloodHandler) ApplyConsensusSize ¶ added in v1.0.123
func (nah *NilAntifloodHandler) ApplyConsensusSize(_ int)
ApplyConsensusSize does nothing
func (*NilAntifloodHandler) BlacklistPeer ¶ added in v1.0.132
BlacklistPeer does nothing
func (*NilAntifloodHandler) CanProcessMessage ¶
func (nah *NilAntifloodHandler) CanProcessMessage(_ p2p.MessageP2P, _ core.PeerID) error
CanProcessMessage will always return nil, allowing messages to go to interceptors
func (*NilAntifloodHandler) CanProcessMessagesOnTopic ¶ added in v1.0.106
func (nah *NilAntifloodHandler) CanProcessMessagesOnTopic(_ core.PeerID, _ string, _ uint32, _ uint64, _ []byte) error
CanProcessMessagesOnTopic will always return nil, allowing messages to go to interceptors
func (*NilAntifloodHandler) Close ¶ added in v1.2.0
func (nah *NilAntifloodHandler) Close() error
Close does nothing
func (*NilAntifloodHandler) IsInterfaceNil ¶
func (nah *NilAntifloodHandler) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*NilAntifloodHandler) IsOriginatorEligibleForTopic ¶ added in v1.0.133
func (nah *NilAntifloodHandler) IsOriginatorEligibleForTopic(_ core.PeerID, _ string) error
IsOriginatorEligibleForTopic returns nil
func (*NilAntifloodHandler) ResetForTopic ¶
func (nah *NilAntifloodHandler) ResetForTopic(_ string)
ResetForTopic won't do anything
func (*NilAntifloodHandler) SetDebugger ¶ added in v1.0.127
func (nah *NilAntifloodHandler) SetDebugger(_ process.AntifloodDebugger) error
SetDebugger returns nil
func (*NilAntifloodHandler) SetMaxMessagesForTopic ¶
func (nah *NilAntifloodHandler) SetMaxMessagesForTopic(_ string, _ uint32)
SetMaxMessagesForTopic won't do anything
func (*NilAntifloodHandler) SetPeerValidatorMapper ¶ added in v1.2.0
func (nah *NilAntifloodHandler) SetPeerValidatorMapper(_ process.PeerValidatorMapper) error
SetPeerValidatorMapper -
func (*NilAntifloodHandler) SetTopicsForAll ¶ added in v1.2.0
func (nah *NilAntifloodHandler) SetTopicsForAll(_ ...string)
SetTopicsForAll -
type NodeInfoMock ¶ added in v1.0.102
type NodeInfoMock struct {
// contains filtered or unexported fields
}
NodeInfoMock -
func NewNodeInfo ¶ added in v1.0.102
func NewNodeInfo(address []byte, pubKey []byte, shardId uint32, initialRating uint32) *NodeInfoMock
NewNodeInfo -
func (*NodeInfoMock) AddressBytes ¶ added in v1.0.115
func (n *NodeInfoMock) AddressBytes() []byte
AddressBytes -
func (*NodeInfoMock) AssignedShard ¶ added in v1.0.102
func (n *NodeInfoMock) AssignedShard() uint32
AssignedShard -
func (*NodeInfoMock) GetInitialRating ¶ added in v1.0.149
func (n *NodeInfoMock) GetInitialRating() uint32
GetInitialRating -
func (*NodeInfoMock) IsInterfaceNil ¶ added in v1.0.102
func (n *NodeInfoMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*NodeInfoMock) PubKeyBytes ¶ added in v1.0.115
func (n *NodeInfoMock) PubKeyBytes() []byte
PubKeyBytes -
type NodeShufflerMock ¶
type NodeShufflerMock struct { }
NodeShufflerMock -
func (*NodeShufflerMock) IsInterfaceNil ¶
func (nsm *NodeShufflerMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*NodeShufflerMock) UpdateNodeLists ¶
func (nsm *NodeShufflerMock) UpdateNodeLists(args sharding.ArgsUpdateNodes) (*sharding.ResUpdateNodes, error)
UpdateNodeLists -
func (*NodeShufflerMock) UpdateParams ¶
func (nsm *NodeShufflerMock) UpdateParams( _ uint32, _ uint32, _ float32, _ bool, )
UpdateParams -
type NodesCoordinatorCacheStub ¶
type NodesCoordinatorCacheStub struct { PutCalled func(key []byte, value interface{}) (evicted bool) GetCalled func(key []byte) (value interface{}, ok bool) }
NodesCoordinatorCacheStub -
func (*NodesCoordinatorCacheStub) Get ¶
func (rm *NodesCoordinatorCacheStub) Get(key []byte) (value interface{}, ok bool)
Get -
func (*NodesCoordinatorCacheStub) Put ¶
func (rm *NodesCoordinatorCacheStub) Put(key []byte, value interface{}) (evicted bool)
Put -
type NodesCoordinatorMock ¶
type NodesCoordinatorMock struct { ComputeValidatorsGroupCalled func(randomness []byte, round uint64, shardId uint32, epoch uint32) ([]sharding.Validator, error) GetValidatorsPublicKeysCalled func(randomness []byte, round uint64, shardId uint32, epoch uint32) ([]string, error) GetValidatorsRewardsAddressesCalled func(randomness []byte, round uint64, shardId uint32, epoch uint32) ([]string, error) GetValidatorWithPublicKeyCalled func(publicKey []byte) (validator sharding.Validator, shardId uint32, err error) GetAllValidatorsPublicKeysCalled func() (map[uint32][][]byte, error) }
NodesCoordinatorMock -
func (*NodesCoordinatorMock) ComputeAdditionalLeaving ¶ added in v1.0.115
func (ncm *NodesCoordinatorMock) ComputeAdditionalLeaving([]*state.ShardValidatorInfo) (map[uint32][]sharding.Validator, error)
ComputeAdditionalLeaving -
func (*NodesCoordinatorMock) ComputeConsensusGroup ¶
func (ncm *NodesCoordinatorMock) ComputeConsensusGroup( randomness []byte, round uint64, shardId uint32, epoch uint32, ) (validatorsGroup []sharding.Validator, err error)
ComputeConsensusGroup -
func (*NodesCoordinatorMock) ConsensusGroupSize ¶
func (ncm *NodesCoordinatorMock) ConsensusGroupSize(uint32) int
ConsensusGroupSize -
func (*NodesCoordinatorMock) GetAllEligibleValidatorsPublicKeys ¶
func (ncm *NodesCoordinatorMock) GetAllEligibleValidatorsPublicKeys(_ uint32) (map[uint32][][]byte, error)
GetAllEligibleValidatorsPublicKeys -
func (*NodesCoordinatorMock) GetAllLeavingValidatorsPublicKeys ¶ added in v1.0.102
func (ncm *NodesCoordinatorMock) GetAllLeavingValidatorsPublicKeys(_ uint32) (map[uint32][][]byte, error)
GetAllLeavingValidatorsPublicKeys -
func (*NodesCoordinatorMock) GetAllWaitingValidatorsPublicKeys ¶
func (ncm *NodesCoordinatorMock) GetAllWaitingValidatorsPublicKeys(_ uint32) (map[uint32][][]byte, error)
GetAllWaitingValidatorsPublicKeys -
func (*NodesCoordinatorMock) GetChance ¶ added in v1.0.102
func (ncm *NodesCoordinatorMock) GetChance(uint32) uint32
GetChance -
func (*NodesCoordinatorMock) GetConsensusValidatorsPublicKeys ¶
func (ncm *NodesCoordinatorMock) GetConsensusValidatorsPublicKeys( randomness []byte, round uint64, shardId uint32, epoch uint32, ) ([]string, error)
GetConsensusValidatorsPublicKeys -
func (*NodesCoordinatorMock) GetConsensusWhitelistedNodes ¶
func (ncm *NodesCoordinatorMock) GetConsensusWhitelistedNodes( _ uint32, ) (map[string]struct{}, error)
GetConsensusWhitelistedNodes return the whitelisted nodes allowed to send consensus messages, for each of the shards
func (*NodesCoordinatorMock) GetNumTotalEligible ¶
func (ncm *NodesCoordinatorMock) GetNumTotalEligible() uint64
GetNumTotalEligible -
func (*NodesCoordinatorMock) GetOwnPublicKey ¶
func (ncm *NodesCoordinatorMock) GetOwnPublicKey() []byte
GetOwnPublicKey -
func (*NodesCoordinatorMock) GetSavedStateKey ¶
func (ncm *NodesCoordinatorMock) GetSavedStateKey() []byte
GetSavedStateKey -
func (*NodesCoordinatorMock) GetSelectedPublicKeys ¶
func (ncm *NodesCoordinatorMock) GetSelectedPublicKeys(_ []byte, _ uint32, _ uint32) ([]string, error)
GetSelectedPublicKeys -
func (*NodesCoordinatorMock) GetValidatorWithPublicKey ¶
func (ncm *NodesCoordinatorMock) GetValidatorWithPublicKey(publicKey []byte) (sharding.Validator, uint32, error)
GetValidatorWithPublicKey -
func (*NodesCoordinatorMock) GetValidatorsIndexes ¶
func (ncm *NodesCoordinatorMock) GetValidatorsIndexes(_ []string, _ uint32) ([]uint64, error)
GetValidatorsIndexes -
func (*NodesCoordinatorMock) IsInterfaceNil ¶
func (ncm *NodesCoordinatorMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*NodesCoordinatorMock) LoadState ¶
func (ncm *NodesCoordinatorMock) LoadState(_ []byte) error
LoadState -
func (*NodesCoordinatorMock) SetNodesPerShards ¶
func (ncm *NodesCoordinatorMock) SetNodesPerShards(_ map[uint32][]sharding.Validator, _ map[uint32][]sharding.Validator, _ uint32) error
SetNodesPerShards -
func (*NodesCoordinatorMock) ShardIdForEpoch ¶
func (ncm *NodesCoordinatorMock) ShardIdForEpoch(_ uint32) (uint32, error)
ShardIdForEpoch returns the nodesCoordinator configured ShardId for specified epoch if epoch configuration exists, otherwise error
func (*NodesCoordinatorMock) ShuffleOutForEpoch ¶ added in v1.0.111
func (ncm *NodesCoordinatorMock) ShuffleOutForEpoch(_ uint32)
ShuffleOutForEpoch verifies if the shards changed in the new epoch and calls the shuffleOutHandler
func (*NodesCoordinatorMock) ValidatorsWeights ¶ added in v0.0.5
func (ncm *NodesCoordinatorMock) ValidatorsWeights(validators []sharding.Validator) ([]uint32, error)
ValidatorsWeights -
type NodesSetupStub ¶ added in v1.0.102
type NodesSetupStub struct { InitialNodesInfoForShardCalled func(shardId uint32) ([]sharding.GenesisNodeInfoHandler, []sharding.GenesisNodeInfoHandler, error) InitialNodesInfoCalled func() (map[uint32][]sharding.GenesisNodeInfoHandler, map[uint32][]sharding.GenesisNodeInfoHandler) GetStartTimeCalled func() int64 GetRoundDurationCalled func() uint64 GetChainIdCalled func() string GetMinTransactionVersionCalled func() uint32 GetShardConsensusGroupSizeCalled func() uint32 GetMetaConsensusGroupSizeCalled func() uint32 NumberOfShardsCalled func() uint32 MinNumberOfNodesCalled func() uint32 MinNumberOfShardNodesCalled func() uint32 MinNumberOfMetaNodesCalled func() uint32 GetHysteresisCalled func() float32 GetAdaptivityCalled func() bool AllInitialNodesCalled func() []sharding.GenesisNodeInfoHandler GetShardIDForPubKeyCalled func(pubkey []byte) (uint32, error) InitialEligibleNodesPubKeysForShardCalled func(shardId uint32) ([]string, error) InitialNodesPubKeysCalled func() map[uint32][]string MinNumberOfNodesWithHysteresisCalled func() uint32 }
NodesSetupStub -
func (*NodesSetupStub) AllInitialNodes ¶ added in v1.2.0
func (n *NodesSetupStub) AllInitialNodes() []sharding.GenesisNodeInfoHandler
AllInitialNodes -
func (*NodesSetupStub) GetAdaptivity ¶ added in v1.0.149
func (n *NodesSetupStub) GetAdaptivity() bool
GetAdaptivity -
func (*NodesSetupStub) GetChainId ¶ added in v1.0.102
func (n *NodesSetupStub) GetChainId() string
GetChainId -
func (*NodesSetupStub) GetHysteresis ¶ added in v1.0.149
func (n *NodesSetupStub) GetHysteresis() float32
GetHysteresis -
func (*NodesSetupStub) GetMetaConsensusGroupSize ¶ added in v1.0.102
func (n *NodesSetupStub) GetMetaConsensusGroupSize() uint32
GetMetaConsensusGroupSize -
func (*NodesSetupStub) GetMinTransactionVersion ¶ added in v1.0.137
func (n *NodesSetupStub) GetMinTransactionVersion() uint32
GetMinTransactionVersion -
func (*NodesSetupStub) GetRoundDuration ¶ added in v1.0.102
func (n *NodesSetupStub) GetRoundDuration() uint64
GetRoundDuration -
func (*NodesSetupStub) GetShardConsensusGroupSize ¶ added in v1.0.102
func (n *NodesSetupStub) GetShardConsensusGroupSize() uint32
GetShardConsensusGroupSize -
func (*NodesSetupStub) GetShardIDForPubKey ¶ added in v1.2.0
func (n *NodesSetupStub) GetShardIDForPubKey(pubkey []byte) (uint32, error)
GetShardIDForPubKey -
func (*NodesSetupStub) GetStartTime ¶ added in v1.0.102
func (n *NodesSetupStub) GetStartTime() int64
GetStartTime -
func (*NodesSetupStub) InitialEligibleNodesPubKeysForShard ¶ added in v1.2.0
func (n *NodesSetupStub) InitialEligibleNodesPubKeysForShard(shardId uint32) ([]string, error)
InitialEligibleNodesPubKeysForShard -
func (*NodesSetupStub) InitialNodesInfo ¶ added in v1.0.102
func (n *NodesSetupStub) InitialNodesInfo() (map[uint32][]sharding.GenesisNodeInfoHandler, map[uint32][]sharding.GenesisNodeInfoHandler)
InitialNodesInfo -
func (*NodesSetupStub) InitialNodesInfoForShard ¶ added in v1.0.102
func (n *NodesSetupStub) InitialNodesInfoForShard(shardId uint32) ([]sharding.GenesisNodeInfoHandler, []sharding.GenesisNodeInfoHandler, error)
InitialNodesInfoForShard -
func (*NodesSetupStub) InitialNodesPubKeys ¶ added in v1.2.0
func (n *NodesSetupStub) InitialNodesPubKeys() map[uint32][]string
InitialNodesPubKeys -
func (*NodesSetupStub) IsInterfaceNil ¶ added in v1.0.102
func (n *NodesSetupStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*NodesSetupStub) MinNumberOfMetaNodes ¶ added in v1.0.149
func (n *NodesSetupStub) MinNumberOfMetaNodes() uint32
MinNumberOfMetaNodes -
func (*NodesSetupStub) MinNumberOfNodes ¶ added in v1.0.110
func (n *NodesSetupStub) MinNumberOfNodes() uint32
MinNumberOfNodes -
func (*NodesSetupStub) MinNumberOfNodesWithHysteresis ¶ added in v1.1.3
func (n *NodesSetupStub) MinNumberOfNodesWithHysteresis() uint32
MinNumberOfNodesWithHysteresis -
func (*NodesSetupStub) MinNumberOfShardNodes ¶ added in v1.0.149
func (n *NodesSetupStub) MinNumberOfShardNodes() uint32
MinNumberOfShardNodes -
func (*NodesSetupStub) NumberOfShards ¶ added in v1.0.102
func (n *NodesSetupStub) NumberOfShards() uint32
NumberOfShards -
type OneSCExecutorMockVM ¶
type OneSCExecutorMockVM struct { GasForOperation uint64 // contains filtered or unexported fields }
OneSCExecutorMockVM contains one hardcoded SC with the following behaviour (written in golang): ------------------------------------- var a int
func init(initial int){ a = initial }
func Add(value int){ a += value }
func Get() int{ return a }
-------------------------------------
func NewOneSCExecutorMockVM ¶
func NewOneSCExecutorMockVM(blockchainHook vmcommon.BlockchainHook, hasher hashing.Hasher) (*OneSCExecutorMockVM, error)
NewOneSCExecutorMockVM -
func (*OneSCExecutorMockVM) GasScheduleChange ¶ added in v1.1.12
func (vm *OneSCExecutorMockVM) GasScheduleChange(_ map[string]map[string]uint64)
GasScheduleChange -
func (*OneSCExecutorMockVM) GetVersion ¶ added in v1.1.60
func (vm *OneSCExecutorMockVM) GetVersion() string
GetVersion -
func (*OneSCExecutorMockVM) IsInterfaceNil ¶ added in v1.1.12
func (vm *OneSCExecutorMockVM) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*OneSCExecutorMockVM) RunSmartContractCall ¶
func (vm *OneSCExecutorMockVM) RunSmartContractCall(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error)
RunSmartContractCall -
func (*OneSCExecutorMockVM) RunSmartContractCreate ¶
func (vm *OneSCExecutorMockVM) RunSmartContractCreate(input *vmcommon.ContractCreateInput) (*vmcommon.VMOutput, error)
RunSmartContractCreate -
type P2PAntifloodHandlerStub ¶
type P2PAntifloodHandlerStub struct { CanProcessMessageCalled func(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error CanProcessMessagesOnTopicCalled func(peer core.PeerID, topic string, numMessages uint32, totalSize uint64, sequence []byte) error ApplyConsensusSizeCalled func(size int) SetDebuggerCalled func(debugger process.AntifloodDebugger) error BlacklistPeerCalled func(peer core.PeerID, reason string, duration time.Duration) IsOriginatorEligibleForTopicCalled func(pid core.PeerID, topic string) error }
P2PAntifloodHandlerStub -
func (*P2PAntifloodHandlerStub) ApplyConsensusSize ¶ added in v1.2.0
func (p2pahs *P2PAntifloodHandlerStub) ApplyConsensusSize(size int)
ApplyConsensusSize -
func (*P2PAntifloodHandlerStub) BlacklistPeer ¶ added in v1.0.132
func (p2pahs *P2PAntifloodHandlerStub) BlacklistPeer(peer core.PeerID, reason string, duration time.Duration)
BlacklistPeer -
func (*P2PAntifloodHandlerStub) CanProcessMessage ¶
func (p2pahs *P2PAntifloodHandlerStub) CanProcessMessage(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error
CanProcessMessage -
func (*P2PAntifloodHandlerStub) CanProcessMessagesOnTopic ¶ added in v1.0.115
func (p2pahs *P2PAntifloodHandlerStub) CanProcessMessagesOnTopic(peer core.PeerID, topic string, numMessages uint32, totalSize uint64, sequence []byte) error
CanProcessMessagesOnTopic -
func (*P2PAntifloodHandlerStub) Close ¶ added in v1.2.0
func (p2pahs *P2PAntifloodHandlerStub) Close() error
Close -
func (*P2PAntifloodHandlerStub) IsInterfaceNil ¶
func (p2pahs *P2PAntifloodHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*P2PAntifloodHandlerStub) IsOriginatorEligibleForTopic ¶ added in v1.2.0
func (p2pahs *P2PAntifloodHandlerStub) IsOriginatorEligibleForTopic(pid core.PeerID, topic string) error
IsOriginatorEligibleForTopic -
func (*P2PAntifloodHandlerStub) ResetForTopic ¶ added in v1.0.115
func (p2pahs *P2PAntifloodHandlerStub) ResetForTopic(_ string)
ResetForTopic -
func (*P2PAntifloodHandlerStub) SetDebugger ¶ added in v1.2.0
func (p2pahs *P2PAntifloodHandlerStub) SetDebugger(debugger process.AntifloodDebugger) error
SetDebugger -
func (*P2PAntifloodHandlerStub) SetMaxMessagesForTopic ¶ added in v1.0.115
func (p2pahs *P2PAntifloodHandlerStub) SetMaxMessagesForTopic(_ string, _ uint32)
SetMaxMessagesForTopic -
func (*P2PAntifloodHandlerStub) SetPeerValidatorMapper ¶ added in v1.2.0
func (p2pahs *P2PAntifloodHandlerStub) SetPeerValidatorMapper(_ process.PeerValidatorMapper) error
SetPeerValidatorMapper -
func (*P2PAntifloodHandlerStub) SetTopicsForAll ¶ added in v1.2.0
func (p2pahs *P2PAntifloodHandlerStub) SetTopicsForAll(_ ...string)
SetTopicsForAll -
type PeerBlackListCacherStub ¶ added in v1.0.133
type PeerBlackListCacherStub struct { AddCalled func(pid core.PeerID) error UpsertCalled func(pid core.PeerID, span time.Duration) error HasCalled func(pid core.PeerID) bool SweepCalled func() }
PeerBlackListCacherStub -
func (*PeerBlackListCacherStub) Add ¶ added in v1.0.133
func (pblhs *PeerBlackListCacherStub) Add(pid core.PeerID) error
Add -
func (*PeerBlackListCacherStub) Has ¶ added in v1.0.133
func (pblhs *PeerBlackListCacherStub) Has(pid core.PeerID) bool
Has -
func (*PeerBlackListCacherStub) IsInterfaceNil ¶ added in v1.0.133
func (pblhs *PeerBlackListCacherStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*PeerBlackListCacherStub) Sweep ¶ added in v1.0.133
func (pblhs *PeerBlackListCacherStub) Sweep()
Sweep -
type PeerChangesHandler ¶
type PeerChangesHandler struct { PeerChangesCalled func() []block.PeerData VerifyPeerChangesCalled func(peerChanges []block.PeerData) error }
PeerChangesHandler -
func (*PeerChangesHandler) IsInterfaceNil ¶
func (p *PeerChangesHandler) IsInterfaceNil() bool
IsInterfaceNil -
func (*PeerChangesHandler) PeerChanges ¶
func (p *PeerChangesHandler) PeerChanges() []block.PeerData
PeerChanges -
func (*PeerChangesHandler) VerifyPeerChanges ¶
func (p *PeerChangesHandler) VerifyPeerChanges(peerChanges []block.PeerData) error
VerifyPeerChanges -
type PeerDenialEvaluatorStub ¶ added in v1.0.133
type PeerDenialEvaluatorStub struct { IsDeniedCalled func(pid core.PeerID) bool UpsertPeerIDClled func(pid core.PeerID, duration time.Duration) error }
PeerDenialEvaluatorStub -
func (*PeerDenialEvaluatorStub) IsDenied ¶ added in v1.0.133
func (pdes *PeerDenialEvaluatorStub) IsDenied(pid core.PeerID) bool
IsDenied -
func (*PeerDenialEvaluatorStub) IsInterfaceNil ¶ added in v1.0.133
func (pdes *PeerDenialEvaluatorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*PeerDenialEvaluatorStub) UpsertPeerID ¶ added in v1.0.133
UpsertPeerID -
type PeerHonestyHandlerStub ¶ added in v1.0.133
PeerHonestyHandlerStub -
func (*PeerHonestyHandlerStub) ChangeScore ¶ added in v1.0.133
func (phhs *PeerHonestyHandlerStub) ChangeScore(pk string, topic string, units int)
ChangeScore -
func (*PeerHonestyHandlerStub) Close ¶ added in v1.2.0
func (phhs *PeerHonestyHandlerStub) Close() error
Close -
func (*PeerHonestyHandlerStub) IsInterfaceNil ¶ added in v1.0.133
func (phhs *PeerHonestyHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
type PeerShardMapperStub ¶ added in v1.0.133
type PeerShardMapperStub struct { }
PeerShardMapperStub -
func (*PeerShardMapperStub) GetPeerInfo ¶ added in v1.0.133
func (psms *PeerShardMapperStub) GetPeerInfo(_ core.PeerID) core.P2PPeerInfo
GetPeerInfo -
func (*PeerShardMapperStub) IsInterfaceNil ¶ added in v1.0.133
func (psms *PeerShardMapperStub) IsInterfaceNil() bool
IsInterfaceNil -
type PeerSignatureHandler ¶ added in v1.2.0
type PeerSignatureHandler struct{}
PeerSignatureHandler -
func (*PeerSignatureHandler) GetPeerSignature ¶ added in v1.2.0
func (p *PeerSignatureHandler) GetPeerSignature(_ crypto.PrivateKey, _ []byte) ([]byte, error)
GetPeerSignature -
func (*PeerSignatureHandler) IsInterfaceNil ¶ added in v1.2.0
func (p *PeerSignatureHandler) IsInterfaceNil() bool
IsInterfaceNil -
func (*PeerSignatureHandler) VerifyPeerSignature ¶ added in v1.2.0
VerifyPeerSignature -
type PeerTypeProviderStub ¶ added in v1.0.102
type PeerTypeProviderStub struct {
ComputeForPubKeyCalled func(pubKey []byte) (common.PeerType, uint32, error)
}
PeerTypeProviderStub -
func (*PeerTypeProviderStub) Close ¶ added in v1.0.117
func (p *PeerTypeProviderStub) Close() error
Close -
func (*PeerTypeProviderStub) ComputeForPubKey ¶ added in v1.0.102
ComputeForPubKey -
func (*PeerTypeProviderStub) GetAllPeerTypeInfos ¶ added in v1.0.117
func (p *PeerTypeProviderStub) GetAllPeerTypeInfos() []*state.PeerTypeInfo
GetAllPeerTypeInfos -
func (*PeerTypeProviderStub) IsInterfaceNil ¶ added in v1.0.102
func (p *PeerTypeProviderStub) IsInterfaceNil() bool
IsInterfaceNil -
type PendingMiniBlocksHandlerStub ¶
type PendingMiniBlocksHandlerStub struct { AddProcessedHeaderCalled func(handler data.HeaderHandler) error RevertHeaderCalled func(handler data.HeaderHandler) error GetPendingMiniBlocksCalled func(shardID uint32) [][]byte SetPendingMiniBlocksCalled func(shardID uint32, mbHashes [][]byte) }
PendingMiniBlocksHandlerStub -
func (*PendingMiniBlocksHandlerStub) AddProcessedHeader ¶
func (p *PendingMiniBlocksHandlerStub) AddProcessedHeader(handler data.HeaderHandler) error
AddProcessedHeader -
func (*PendingMiniBlocksHandlerStub) GetPendingMiniBlocks ¶
func (p *PendingMiniBlocksHandlerStub) GetPendingMiniBlocks(shardID uint32) [][]byte
GetPendingMiniBlocks -
func (*PendingMiniBlocksHandlerStub) IsInterfaceNil ¶
func (p *PendingMiniBlocksHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*PendingMiniBlocksHandlerStub) RevertHeader ¶
func (p *PendingMiniBlocksHandlerStub) RevertHeader(handler data.HeaderHandler) error
RevertHeader -
func (*PendingMiniBlocksHandlerStub) SetPendingMiniBlocks ¶
func (p *PendingMiniBlocksHandlerStub) SetPendingMiniBlocks(shardID uint32, mbHashes [][]byte)
SetPendingMiniBlocks -
type PrivateKeyMock ¶
type PrivateKeyMock struct {
// contains filtered or unexported fields
}
PrivateKeyMock -
func (*PrivateKeyMock) GeneratePublic ¶
func (sk *PrivateKeyMock) GeneratePublic() crypto.PublicKey
GeneratePublic -
func (*PrivateKeyMock) IsInterfaceNil ¶
func (sk *PrivateKeyMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*PrivateKeyMock) ToByteArray ¶
func (sk *PrivateKeyMock) ToByteArray() ([]byte, error)
ToByteArray -
type ProcessComponentsStub ¶ added in v1.2.0
type ProcessComponentsStub struct { NodesCoord sharding.NodesCoordinator ShardCoord sharding.Coordinator IntContainer process.InterceptorsContainer ResFinder dataRetriever.ResolversFinder RoundHandlerField consensus.RoundHandler EpochTrigger epochStart.TriggerHandler EpochNotifier factory.EpochStartNotifier ForkDetect process.ForkDetector BlockProcess process.BlockProcessor BlackListHdl process.TimeCacher BootSore process.BootStorer HeaderSigVerif process.InterceptedHeaderSigVerifier HeaderIntegrVerif process.HeaderIntegrityVerifier ValidatorStatistics process.ValidatorStatisticsProcessor ValidatorProvider process.ValidatorsProvider BlockTrack process.BlockTracker PendingMiniBlocksHdl process.PendingMiniBlocksHandler ReqHandler process.RequestHandler TxLogsProcess process.TransactionLogProcessorDatabase HeaderConstructValidator process.HeaderConstructionValidator PeerMapper process.NetworkShardingCollector TxSimulatorProcessor factory.TransactionSimulatorProcessor FallbackHdrValidator process.FallbackHeaderValidator WhiteListHandlerInternal process.WhiteListHandler WhiteListerVerifiedTxsInternal process.WhiteListHandler HistoryRepositoryInternal dblookupext.HistoryRepository ImportStartHandlerInternal update.ImportStartHandler RequestedItemsHandlerInternal dataRetriever.RequestedItemsHandler NodeRedundancyHandlerInternal consensus.NodeRedundancyHandler CurrentEpochProviderInternal process.CurrentNetworkEpochProviderHandler }
ProcessComponentsStub -
func (*ProcessComponentsStub) BlackListHandler ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) BlackListHandler() process.TimeCacher
BlackListHandler -
func (*ProcessComponentsStub) BlockProcessor ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) BlockProcessor() process.BlockProcessor
BlockProcessor -
func (*ProcessComponentsStub) BlockTracker ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) BlockTracker() process.BlockTracker
BlockTracker -
func (*ProcessComponentsStub) BootStorer ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) BootStorer() process.BootStorer
BootStorer -
func (*ProcessComponentsStub) CheckSubcomponents ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) CheckSubcomponents() error
CheckSubcomponents -
func (*ProcessComponentsStub) Close ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) Close() error
Close -
func (*ProcessComponentsStub) Create ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) Create() error
Create -
func (*ProcessComponentsStub) CurrentEpochProvider ¶ added in v1.2.4
func (pcs *ProcessComponentsStub) CurrentEpochProvider() process.CurrentNetworkEpochProviderHandler
CurrentEpochProvider -
func (*ProcessComponentsStub) EpochStartNotifier ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) EpochStartNotifier() factory.EpochStartNotifier
EpochStartNotifier -
func (*ProcessComponentsStub) EpochStartTrigger ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) EpochStartTrigger() epochStart.TriggerHandler
EpochStartTrigger -
func (*ProcessComponentsStub) FallbackHeaderValidator ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) FallbackHeaderValidator() process.FallbackHeaderValidator
FallbackHeaderValidator -
func (*ProcessComponentsStub) ForkDetector ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) ForkDetector() process.ForkDetector
ForkDetector -
func (*ProcessComponentsStub) HeaderConstructionValidator ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) HeaderConstructionValidator() process.HeaderConstructionValidator
HeaderConstructionValidator -
func (*ProcessComponentsStub) HeaderIntegrityVerifier ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) HeaderIntegrityVerifier() process.HeaderIntegrityVerifier
HeaderIntegrityVerifier -
func (*ProcessComponentsStub) HeaderSigVerifier ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) HeaderSigVerifier() process.InterceptedHeaderSigVerifier
HeaderSigVerifier -
func (*ProcessComponentsStub) HistoryRepository ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) HistoryRepository() dblookupext.HistoryRepository
HistoryRepository -
func (*ProcessComponentsStub) ImportStartHandler ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) ImportStartHandler() update.ImportStartHandler
ImportStartHandler -
func (*ProcessComponentsStub) InterceptorsContainer ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) InterceptorsContainer() process.InterceptorsContainer
InterceptorsContainer -
func (*ProcessComponentsStub) IsInterfaceNil ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ProcessComponentsStub) NodeRedundancyHandler ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) NodeRedundancyHandler() consensus.NodeRedundancyHandler
NodeRedundancyHandler -
func (*ProcessComponentsStub) NodesCoordinator ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) NodesCoordinator() sharding.NodesCoordinator
NodesCoordinator -
func (*ProcessComponentsStub) PeerShardMapper ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) PeerShardMapper() process.NetworkShardingCollector
PeerShardMapper -
func (*ProcessComponentsStub) PendingMiniBlocksHandler ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) PendingMiniBlocksHandler() process.PendingMiniBlocksHandler
PendingMiniBlocksHandler -
func (*ProcessComponentsStub) RequestHandler ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) RequestHandler() process.RequestHandler
RequestHandler -
func (*ProcessComponentsStub) RequestedItemsHandler ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) RequestedItemsHandler() dataRetriever.RequestedItemsHandler
RequestedItemsHandler -
func (*ProcessComponentsStub) ResolversFinder ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) ResolversFinder() dataRetriever.ResolversFinder
ResolversFinder -
func (*ProcessComponentsStub) RoundHandler ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) RoundHandler() consensus.RoundHandler
RoundHandler -
func (*ProcessComponentsStub) ShardCoordinator ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) ShardCoordinator() sharding.Coordinator
ShardCoordinator -
func (*ProcessComponentsStub) String ¶ added in v1.2.12
func (pcs *ProcessComponentsStub) String() string
String -
func (*ProcessComponentsStub) TransactionSimulatorProcessor ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) TransactionSimulatorProcessor() factory.TransactionSimulatorProcessor
TransactionSimulatorProcessor -
func (*ProcessComponentsStub) TxLogsProcessor ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) TxLogsProcessor() process.TransactionLogProcessorDatabase
TxLogsProcessor -
func (*ProcessComponentsStub) ValidatorsProvider ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) ValidatorsProvider() process.ValidatorsProvider
ValidatorsProvider -
func (*ProcessComponentsStub) ValidatorsStatistics ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) ValidatorsStatistics() process.ValidatorStatisticsProcessor
ValidatorsStatistics -
func (*ProcessComponentsStub) WhiteListHandler ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) WhiteListHandler() process.WhiteListHandler
WhiteListHandler -
func (*ProcessComponentsStub) WhiteListerVerifiedTxs ¶ added in v1.2.0
func (pcs *ProcessComponentsStub) WhiteListerVerifiedTxs() process.WhiteListHandler
WhiteListerVerifiedTxs -
type PublicKeyMock ¶
type PublicKeyMock struct {
// contains filtered or unexported fields
}
PublicKeyMock -
func (*PublicKeyMock) IsInterfaceNil ¶
func (sspk *PublicKeyMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*PublicKeyMock) ToByteArray ¶
func (sspk *PublicKeyMock) ToByteArray() ([]byte, error)
ToByteArray -
type RaterMock ¶
type RaterMock struct { GetRatingCalled func(string) uint32 GetStartRatingCalled func() uint32 GetSignedBlocksThresholdCalled func() float32 ComputeIncreaseProposerCalled func(shardId uint32, rating uint32) uint32 ComputeDecreaseProposerCalled func(shardId uint32, rating uint32, consecutiveMissedBlocks uint32) uint32 RevertIncreaseProposerCalled func(shardId uint32, rating uint32, nrReverts uint32) uint32 ComputeIncreaseValidatorCalled func(shardId uint32, rating uint32) uint32 ComputeDecreaseValidatorCalled func(shardId uint32, rating uint32) uint32 GetChanceCalled func(rating uint32) uint32 }
RaterMock -
func (*RaterMock) ComputeDecreaseProposer ¶
func (rm *RaterMock) ComputeDecreaseProposer(shardId uint32, currentRating uint32, consecutiveMisses uint32) uint32
ComputeDecreaseProposer -
func (*RaterMock) ComputeDecreaseValidator ¶
ComputeDecreaseValidator -
func (*RaterMock) ComputeIncreaseProposer ¶
ComputeIncreaseProposer -
func (*RaterMock) ComputeIncreaseValidator ¶
ComputeIncreaseValidator -
func (*RaterMock) GetSignedBlocksThreshold ¶ added in v0.0.5
GetSignedBlocksThreshold -
type RatingReaderMock ¶
type RatingReaderMock struct { GetRatingCalled func(string) uint32 GetRatingsCalled func([]string) map[string]uint32 RatingsMap map[string]uint32 }
RatingReaderMock -
func (*RatingReaderMock) GetRating ¶
func (rrm *RatingReaderMock) GetRating(pk string) uint32
GetRating -
func (*RatingReaderMock) IsInterfaceNil ¶
func (rrm *RatingReaderMock) IsInterfaceNil() bool
IsInterfaceNil -
type RedundancyHandlerStub ¶ added in v1.1.32
type RedundancyHandlerStub struct { IsRedundancyNodeCalled func() bool IsMainMachineActiveCalled func() bool ObserverPrivateKeyCalled func() crypto.PrivateKey AdjustInactivityIfNeededCalled func(selfPubKey string, consensusPubKeys []string, roundIndex int64) ResetInactivityIfNeededCalled func(selfPubKey string, consensusMsgPubKey string, consensusMsgPeerID core.PeerID) }
RedundancyHandlerStub -
func (*RedundancyHandlerStub) AdjustInactivityIfNeeded ¶ added in v1.1.32
func (rhs *RedundancyHandlerStub) AdjustInactivityIfNeeded(selfPubKey string, consensusPubKeys []string, roundIndex int64)
AdjustInactivityIfNeeded -
func (*RedundancyHandlerStub) IsInterfaceNil ¶ added in v1.1.32
func (rhs *RedundancyHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*RedundancyHandlerStub) IsMainMachineActive ¶ added in v1.1.32
func (rhs *RedundancyHandlerStub) IsMainMachineActive() bool
IsMainMachineActive -
func (*RedundancyHandlerStub) IsRedundancyNode ¶ added in v1.1.32
func (rhs *RedundancyHandlerStub) IsRedundancyNode() bool
IsRedundancyNode -
func (*RedundancyHandlerStub) ObserverPrivateKey ¶ added in v1.1.32
func (rhs *RedundancyHandlerStub) ObserverPrivateKey() crypto.PrivateKey
ObserverPrivateKey -
func (*RedundancyHandlerStub) ResetInactivityIfNeeded ¶ added in v1.1.32
func (rhs *RedundancyHandlerStub) ResetInactivityIfNeeded(selfPubKey string, consensusMsgPubKey string, consensusMsgPeerID core.PeerID)
ResetInactivityIfNeeded -
type RequestedItemsHandlerStub ¶
type RequestedItemsHandlerStub struct { AddCalled func(key string) error HasCalled func(key string) bool SweepCalled func() }
RequestedItemsHandlerStub -
func (*RequestedItemsHandlerStub) Add ¶
func (rihs *RequestedItemsHandlerStub) Add(key string) error
Add -
func (*RequestedItemsHandlerStub) Has ¶
func (rihs *RequestedItemsHandlerStub) Has(key string) bool
Has -
func (*RequestedItemsHandlerStub) IsInterfaceNil ¶
func (rihs *RequestedItemsHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
type ResolversContainerStub ¶
type ResolversContainerStub struct { GetCalled func(key string) (dataRetriever.Resolver, error) AddCalled func(key string, val dataRetriever.Resolver) error ReplaceCalled func(key string, val dataRetriever.Resolver) error RemoveCalled func(key string) LenCalled func() int ResolverKeysCalled func() string IterateCalled func(handler func(key string, resolver dataRetriever.Resolver) bool) CloseCalled func() error }
ResolversContainerStub -
func (*ResolversContainerStub) Add ¶
func (rcs *ResolversContainerStub) Add(key string, val dataRetriever.Resolver) error
Add -
func (*ResolversContainerStub) AddMultiple ¶
func (rcs *ResolversContainerStub) AddMultiple(_ []string, _ []dataRetriever.Resolver) error
AddMultiple -
func (*ResolversContainerStub) Close ¶ added in v1.2.0
func (rcs *ResolversContainerStub) Close() error
Close -
func (*ResolversContainerStub) Get ¶
func (rcs *ResolversContainerStub) Get(key string) (dataRetriever.Resolver, error)
Get -
func (*ResolversContainerStub) IsInterfaceNil ¶
func (rcs *ResolversContainerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ResolversContainerStub) Iterate ¶ added in v1.0.110
func (rcs *ResolversContainerStub) Iterate(handler func(key string, resolver dataRetriever.Resolver) bool)
Iterate -
func (*ResolversContainerStub) Remove ¶
func (rcs *ResolversContainerStub) Remove(key string)
Remove -
func (*ResolversContainerStub) Replace ¶
func (rcs *ResolversContainerStub) Replace(key string, val dataRetriever.Resolver) error
Replace -
func (*ResolversContainerStub) ResolverKeys ¶
func (rcs *ResolversContainerStub) ResolverKeys() string
ResolverKeys -
type ResolversFinderStub ¶
type ResolversFinderStub struct { ResolversContainerStub IntraShardResolverCalled func(baseTopic string) (dataRetriever.Resolver, error) MetaChainResolverCalled func(baseTopic string) (dataRetriever.Resolver, error) CrossShardResolverCalled func(baseTopic string, crossShard uint32) (dataRetriever.Resolver, error) MetaCrossShardResolverCalled func(baseTopic string, crossShard uint32) (dataRetriever.Resolver, error) }
ResolversFinderStub -
func (*ResolversFinderStub) CrossShardResolver ¶
func (rfs *ResolversFinderStub) CrossShardResolver(baseTopic string, crossShard uint32) (dataRetriever.Resolver, error)
CrossShardResolver -
func (*ResolversFinderStub) IntraShardResolver ¶
func (rfs *ResolversFinderStub) IntraShardResolver(baseTopic string) (dataRetriever.Resolver, error)
IntraShardResolver -
func (*ResolversFinderStub) MetaChainResolver ¶
func (rfs *ResolversFinderStub) MetaChainResolver(baseTopic string) (dataRetriever.Resolver, error)
MetaChainResolver -
func (*ResolversFinderStub) MetaCrossShardResolver ¶ added in v1.0.102
func (rfs *ResolversFinderStub) MetaCrossShardResolver(baseTopic string, crossShard uint32) (dataRetriever.Resolver, error)
MetaCrossShardResolver -
type RoundHandlerMock ¶ added in v1.2.0
type RoundHandlerMock struct { IndexField int64 TimeStampField time.Time TimeDurationField time.Duration RemainingTimeField time.Duration BeforeGenesisCalled func() bool }
RoundHandlerMock -
func (*RoundHandlerMock) BeforeGenesis ¶ added in v1.2.0
func (rndm *RoundHandlerMock) BeforeGenesis() bool
BeforeGenesis -
func (*RoundHandlerMock) IsInterfaceNil ¶ added in v1.2.0
func (rm *RoundHandlerMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*RoundHandlerMock) RemainingTime ¶ added in v1.2.0
RemainingTime -
func (*RoundHandlerMock) TimeDuration ¶ added in v1.2.0
func (rm *RoundHandlerMock) TimeDuration() time.Duration
TimeDuration -
func (*RoundHandlerMock) TimeStamp ¶ added in v1.2.0
func (rm *RoundHandlerMock) TimeStamp() time.Time
TimeStamp -
func (*RoundHandlerMock) UpdateRound ¶ added in v1.2.0
func (rm *RoundHandlerMock) UpdateRound(time.Time, time.Time)
UpdateRound -
type SCToProtocolStub ¶
SCToProtocolStub -
func (*SCToProtocolStub) IsInterfaceNil ¶
func (s *SCToProtocolStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*SCToProtocolStub) UpdateProtocol ¶
func (s *SCToProtocolStub) UpdateProtocol(body *block.Body, nonce uint64) error
UpdateProtocol -
type ScQueryStub ¶
type ScQueryStub struct { ExecuteQueryCalled func(query *process.SCQuery) (*vmcommon.VMOutput, error) ComputeScCallGasLimitCalled func(tx *transaction.Transaction) (uint64, error) }
ScQueryStub -
func (*ScQueryStub) ComputeScCallGasLimit ¶
func (s *ScQueryStub) ComputeScCallGasLimit(tx *transaction.Transaction) (uint64, error)
ComputeScCallGasLimit --
func (*ScQueryStub) ExecuteQuery ¶
ExecuteQuery -
type ShuffledOutHandlerStub ¶ added in v1.0.103
type ShuffledOutHandlerStub struct { ProcessCalled func(newShardID uint32) error RegisterHandlerCalled func(handler func(newShardID uint32)) CurrentShardIDCalled func() uint32 }
ShuffledOutHandlerStub -
func (*ShuffledOutHandlerStub) CurrentShardID ¶ added in v1.0.103
func (s *ShuffledOutHandlerStub) CurrentShardID() uint32
CurrentShardID -
func (*ShuffledOutHandlerStub) IsInterfaceNil ¶ added in v1.0.103
func (s *ShuffledOutHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ShuffledOutHandlerStub) Process ¶ added in v1.0.103
func (s *ShuffledOutHandlerStub) Process(newShardID uint32) error
Process -
func (*ShuffledOutHandlerStub) RegisterHandler ¶ added in v1.0.103
func (s *ShuffledOutHandlerStub) RegisterHandler(handler func(newShardID uint32))
RegisterHandler -
type SignerMock ¶
type SignerMock struct { SignStub func(private crypto.PrivateKey, msg []byte) ([]byte, error) VerifyStub func(public crypto.PublicKey, msg []byte, sig []byte) error }
SignerMock -
func (*SignerMock) IsInterfaceNil ¶
func (s *SignerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type SmartContractParserStub ¶ added in v1.0.115
type SmartContractParserStub struct { InitialSmartContractsSplitOnOwnersShardsCalled func(shardCoordinator sharding.Coordinator) (map[uint32][]genesis.InitialSmartContractHandler, error) InitialSmartContractsCalled func() []genesis.InitialSmartContractHandler GetDeployedSCAddressesCalled func(scType string) (map[string]struct{}, error) }
SmartContractParserStub -
func (*SmartContractParserStub) GetDeployedSCAddresses ¶ added in v1.0.133
func (scps *SmartContractParserStub) GetDeployedSCAddresses(scType string) (map[string]struct{}, error)
GetDeployedSCAddresses -
func (*SmartContractParserStub) InitialSmartContracts ¶ added in v1.0.115
func (scps *SmartContractParserStub) InitialSmartContracts() []genesis.InitialSmartContractHandler
InitialSmartContracts -
func (*SmartContractParserStub) InitialSmartContractsSplitOnOwnersShards ¶ added in v1.0.115
func (scps *SmartContractParserStub) InitialSmartContractsSplitOnOwnersShards(shardCoordinator sharding.Coordinator) (map[uint32][]genesis.InitialSmartContractHandler, error)
InitialSmartContractsSplitOnOwnersShards -
func (*SmartContractParserStub) IsInterfaceNil ¶ added in v1.0.115
func (scps *SmartContractParserStub) IsInterfaceNil() bool
IsInterfaceNil -
type SoftwareVersionCheckerMock ¶ added in v1.2.0
type SoftwareVersionCheckerMock struct { }
SoftwareVersionCheckerMock -
func (*SoftwareVersionCheckerMock) Close ¶ added in v1.2.0
func (svcm *SoftwareVersionCheckerMock) Close() error
Close -
func (*SoftwareVersionCheckerMock) IsInterfaceNil ¶ added in v1.2.0
func (svcm *SoftwareVersionCheckerMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*SoftwareVersionCheckerMock) StartCheckSoftwareVersion ¶ added in v1.2.0
func (svcm *SoftwareVersionCheckerMock) StartCheckSoftwareVersion()
StartCheckSoftwareVersion -
type StatusComponentsStub ¶ added in v1.2.0
type StatusComponentsStub struct { Outport outport.OutportHandler SoftwareVersionCheck statistics.SoftwareVersionChecker AppStatusHandler core.AppStatusHandler }
StatusComponentsStub -
func (*StatusComponentsStub) CheckSubcomponents ¶ added in v1.2.0
func (scs *StatusComponentsStub) CheckSubcomponents() error
CheckSubcomponents -
func (*StatusComponentsStub) Close ¶ added in v1.2.0
func (scs *StatusComponentsStub) Close() error
Close -
func (*StatusComponentsStub) Create ¶ added in v1.2.0
func (scs *StatusComponentsStub) Create() error
Create -
func (*StatusComponentsStub) IsInterfaceNil ¶ added in v1.2.0
func (scs *StatusComponentsStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*StatusComponentsStub) OutportHandler ¶ added in v1.2.10
func (scs *StatusComponentsStub) OutportHandler() outport.OutportHandler
OutportHandler -
func (*StatusComponentsStub) SoftwareVersionChecker ¶ added in v1.2.0
func (scs *StatusComponentsStub) SoftwareVersionChecker() statistics.SoftwareVersionChecker
SoftwareVersionChecker -
type StatusMetricsStub ¶ added in v1.1.27
type StatusMetricsStub struct { StatusMetricsMapWithoutP2PCalled func() map[string]interface{} StatusP2pMetricsMapCalled func() map[string]interface{} ConfigMetricsCalled func() map[string]interface{} EnableEpochMetricsCalled func() map[string]interface{} NetworkMetricsCalled func() map[string]interface{} EconomicsMetricsCalled func() map[string]interface{} StatusMetricsWithoutP2PPrometheusStringCalled func() string }
StatusMetricsStub -
func (*StatusMetricsStub) ConfigMetrics ¶ added in v1.1.27
func (sms *StatusMetricsStub) ConfigMetrics() map[string]interface{}
ConfigMetrics -
func (*StatusMetricsStub) EconomicsMetrics ¶ added in v1.1.27
func (sms *StatusMetricsStub) EconomicsMetrics() map[string]interface{}
EconomicsMetrics -
func (*StatusMetricsStub) EnableEpochsMetrics ¶ added in v1.2.0
func (sms *StatusMetricsStub) EnableEpochsMetrics() map[string]interface{}
EnableEpochsMetrics
func (*StatusMetricsStub) IsInterfaceNil ¶ added in v1.1.27
func (sms *StatusMetricsStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*StatusMetricsStub) NetworkMetrics ¶ added in v1.1.27
func (sms *StatusMetricsStub) NetworkMetrics() map[string]interface{}
NetworkMetrics -
func (*StatusMetricsStub) StatusMetricsMapWithoutP2P ¶ added in v1.1.27
func (sms *StatusMetricsStub) StatusMetricsMapWithoutP2P() map[string]interface{}
StatusMetricsMapWithoutP2P -
func (*StatusMetricsStub) StatusMetricsWithoutP2PPrometheusString ¶ added in v1.1.27
func (sms *StatusMetricsStub) StatusMetricsWithoutP2PPrometheusString() string
StatusMetricsWithoutP2PPrometheusString -
func (*StatusMetricsStub) StatusP2pMetricsMap ¶ added in v1.1.27
func (sms *StatusMetricsStub) StatusP2pMetricsMap() map[string]interface{}
StatusP2pMetricsMap -
type StorageBootstrapperMock ¶
type StorageBootstrapperMock struct {
LoadFromStorageCalled func() error
}
StorageBootstrapperMock -
func (*StorageBootstrapperMock) GetHighestBlockNonce ¶
func (sbm *StorageBootstrapperMock) GetHighestBlockNonce() uint64
GetHighestBlockNonce -
func (*StorageBootstrapperMock) IsInterfaceNil ¶
func (sbm *StorageBootstrapperMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*StorageBootstrapperMock) LoadFromStorage ¶
func (sbm *StorageBootstrapperMock) LoadFromStorage() error
LoadFromStorage -
type StorageManagerStub ¶ added in v1.2.0
type StorageManagerStub struct { DatabaseCalled func() common.DBWriteCacher TakeSnapshotCalled func([]byte) SetCheckpointCalled func([]byte) GetDbThatContainsHashCalled func([]byte) common.DBWriteCacher GetSnapshotThatContainsHashCalled func(rootHash []byte) common.SnapshotDbHandler IsPruningEnabledCalled func() bool IsPruningBlockedCalled func() bool EnterPruningBufferingModeCalled func() ExitPruningBufferingModeCalled func() IsInterfaceNilCalled func() bool }
StorageManagerStub -
func (*StorageManagerStub) Close ¶ added in v1.2.0
func (sms *StorageManagerStub) Close() error
Close -
func (*StorageManagerStub) Database ¶ added in v1.2.0
func (sms *StorageManagerStub) Database() common.DBWriteCacher
Database -
func (*StorageManagerStub) EnterPruningBufferingMode ¶ added in v1.2.0
func (sms *StorageManagerStub) EnterPruningBufferingMode()
EnterPruningBufferingMode -
func (*StorageManagerStub) ExitPruningBufferingMode ¶ added in v1.2.0
func (sms *StorageManagerStub) ExitPruningBufferingMode()
ExitPruningBufferingMode -
func (*StorageManagerStub) GetSnapshotDbBatchDelay ¶ added in v1.2.0
func (sms *StorageManagerStub) GetSnapshotDbBatchDelay() int
GetSnapshotDbBatchDelay -
func (*StorageManagerStub) GetSnapshotThatContainsHash ¶ added in v1.2.0
func (sms *StorageManagerStub) GetSnapshotThatContainsHash(d []byte) common.SnapshotDbHandler
GetSnapshotThatContainsHash -
func (*StorageManagerStub) IsInterfaceNil ¶ added in v1.2.0
func (sms *StorageManagerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*StorageManagerStub) IsPruningBlocked ¶ added in v1.2.4
func (sms *StorageManagerStub) IsPruningBlocked() bool
IsPruningBlocked -
func (*StorageManagerStub) IsPruningEnabled ¶ added in v1.2.0
func (sms *StorageManagerStub) IsPruningEnabled() bool
IsPruningEnabled -
func (*StorageManagerStub) SetCheckpoint ¶ added in v1.2.0
func (sms *StorageManagerStub) SetCheckpoint([]byte)
SetCheckpoint -
func (*StorageManagerStub) TakeSnapshot ¶ added in v1.2.0
func (sms *StorageManagerStub) TakeSnapshot([]byte)
TakeSnapshot -
type StorerMock ¶ added in v1.0.111
type StorerMock struct {
// contains filtered or unexported fields
}
StorerMock -
func (*StorerMock) DestroyUnit ¶ added in v1.0.111
func (sm *StorerMock) DestroyUnit() error
DestroyUnit -
func (*StorerMock) Get ¶ added in v1.0.111
func (sm *StorerMock) Get(key []byte) ([]byte, error)
Get -
func (*StorerMock) GetBulkFromEpoch ¶ added in v1.0.147
GetBulkFromEpoch -
func (*StorerMock) GetFromEpoch ¶ added in v1.0.111
func (sm *StorerMock) GetFromEpoch(key []byte, _ uint32) ([]byte, error)
GetFromEpoch -
func (*StorerMock) GetOldestEpoch ¶ added in v1.2.4
func (sm *StorerMock) GetOldestEpoch() (uint32, error)
GetOldestEpoch -
func (*StorerMock) IsInterfaceNil ¶ added in v1.0.111
func (sm *StorerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*StorerMock) PutInEpoch ¶ added in v1.1.1
func (sm *StorerMock) PutInEpoch(key, data []byte, _ uint32) error
PutInEpoch -
func (*StorerMock) RangeKeys ¶ added in v1.0.138
func (sm *StorerMock) RangeKeys(_ func(key []byte, val []byte) bool)
RangeKeys -
func (*StorerMock) SearchFirst ¶ added in v1.0.111
func (sm *StorerMock) SearchFirst(_ []byte) ([]byte, error)
SearchFirst -
type SyncTimerMock ¶
type SyncTimerMock struct { ClockOffsetCalled func() time.Duration CurrentTimeCalled func() time.Time }
SyncTimerMock mocks the implementation for a SyncTimer
func (*SyncTimerMock) ClockOffset ¶
func (stm *SyncTimerMock) ClockOffset() time.Duration
ClockOffset method gets the current time offset
func (*SyncTimerMock) CurrentTime ¶
func (stm *SyncTimerMock) CurrentTime() time.Time
CurrentTime method gets the current time on which is added the current offset
func (*SyncTimerMock) FormattedCurrentTime ¶
func (stm *SyncTimerMock) FormattedCurrentTime() string
FormattedCurrentTime method gets the formatted current time on which is added a given offset
func (*SyncTimerMock) IsInterfaceNil ¶
func (stm *SyncTimerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*SyncTimerMock) StartSyncingTime ¶ added in v1.0.116
func (stm *SyncTimerMock) StartSyncingTime()
StartSyncingTime method does the time synchronization at every syncPeriod time elapsed. This should be started as a go routine
type TimeCacheStub ¶ added in v1.0.133
type TimeCacheStub struct { AddCalled func(key string) error UpsertCalled func(key string, span time.Duration) error HasCalled func(key string) bool SweepCalled func() LenCalled func() int }
TimeCacheStub -
func (*TimeCacheStub) IsInterfaceNil ¶ added in v1.0.133
func (tcs *TimeCacheStub) IsInterfaceNil() bool
IsInterfaceNil -
type TopicAntiFloodStub ¶
type TopicAntiFloodStub struct {
IncreaseLoadCalled func(pid core.PeerID, topic string, numMessages uint32) error
}
TopicAntiFloodStub -
func (*TopicAntiFloodStub) IncreaseLoad ¶ added in v1.0.106
IncreaseLoad -
func (*TopicAntiFloodStub) IsInterfaceNil ¶
func (t *TopicAntiFloodStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*TopicAntiFloodStub) ResetForNotRegisteredTopics ¶ added in v1.0.106
func (t *TopicAntiFloodStub) ResetForNotRegisteredTopics()
ResetForNotRegisteredTopics -
func (*TopicAntiFloodStub) ResetForTopic ¶
func (t *TopicAntiFloodStub) ResetForTopic(_ string)
ResetForTopic -
func (*TopicAntiFloodStub) SetMaxMessagesForTopic ¶
func (t *TopicAntiFloodStub) SetMaxMessagesForTopic(_ string, _ uint32)
SetMaxMessagesForTopic -
type TransactionCoordinatorMock ¶
type TransactionCoordinatorMock struct { ComputeTransactionTypeCalled func(tx data.TransactionHandler) (process.TransactionType, process.TransactionType) RequestMiniBlocksCalled func(header data.HeaderHandler) RequestBlockTransactionsCalled func(body *block.Body) IsDataPreparedForProcessingCalled func(haveTime func() time.Duration) error SaveTxsToStorageCalled func(body *block.Body) error RestoreBlockDataFromStorageCalled func(body *block.Body) (int, error) RemoveBlockDataFromPoolCalled func(body *block.Body) error RemoveTxsFromPoolCalled func(body *block.Body) error ProcessBlockTransactionCalled func(body *block.Body, haveTime func() time.Duration) error CreateBlockStartedCalled func() CreateMbsAndProcessCrossShardTransactionsDstMeCalled func(header data.HeaderHandler, processedMiniBlocksHashes map[string]struct{}, haveTime func() bool, ) (block.MiniBlockSlice, uint32, bool, error) CreateMbsAndProcessTransactionsFromMeCalled func(haveTime func() bool) block.MiniBlockSlice CreateMarshalizedDataCalled func(body *block.Body) map[string][][]byte GetAllCurrentUsedTxsCalled func(blockType block.Type) map[string]data.TransactionHandler VerifyCreatedBlockTransactionsCalled func(hdr data.HeaderHandler, body *block.Body) error CreatePostProcessMiniBlocksCalled func() block.MiniBlockSlice CreateMarshalizedReceiptsCalled func() ([]byte, error) VerifyCreatedMiniBlocksCalled func(hdr data.HeaderHandler, body *block.Body) error }
TransactionCoordinatorMock -
func (*TransactionCoordinatorMock) ComputeTransactionType ¶
func (tcm *TransactionCoordinatorMock) ComputeTransactionType(tx data.TransactionHandler) (process.TransactionType, process.TransactionType)
ComputeTransactionType -
func (*TransactionCoordinatorMock) CreateBlockStarted ¶
func (tcm *TransactionCoordinatorMock) CreateBlockStarted()
CreateBlockStarted -
func (*TransactionCoordinatorMock) CreateMarshalizedData ¶
func (tcm *TransactionCoordinatorMock) CreateMarshalizedData(body *block.Body) map[string][][]byte
CreateMarshalizedData -
func (*TransactionCoordinatorMock) CreateMarshalizedReceipts ¶ added in v1.1.1
func (tcm *TransactionCoordinatorMock) CreateMarshalizedReceipts() ([]byte, error)
CreateMarshalizedReceipts -
func (*TransactionCoordinatorMock) CreateMbsAndProcessCrossShardTransactionsDstMe ¶
func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessCrossShardTransactionsDstMe( header data.HeaderHandler, processedMiniBlocksHashes map[string]struct{}, haveTime func() bool, ) (block.MiniBlockSlice, uint32, bool, error)
CreateMbsAndProcessCrossShardTransactionsDstMe -
func (*TransactionCoordinatorMock) CreateMbsAndProcessTransactionsFromMe ¶
func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessTransactionsFromMe(haveTime func() bool) block.MiniBlockSlice
CreateMbsAndProcessTransactionsFromMe -
func (*TransactionCoordinatorMock) CreatePostProcessMiniBlocks ¶ added in v1.0.115
func (tcm *TransactionCoordinatorMock) CreatePostProcessMiniBlocks() block.MiniBlockSlice
CreatePostProcessMiniBlocks -
func (*TransactionCoordinatorMock) CreateReceiptsHash ¶
func (tcm *TransactionCoordinatorMock) CreateReceiptsHash() ([]byte, error)
CreateReceiptsHash -
func (*TransactionCoordinatorMock) GetAllCurrentLogs ¶ added in v1.2.3
func (tcm *TransactionCoordinatorMock) GetAllCurrentLogs() map[string]data.LogHandler
GetAllCurrentLogs -
func (*TransactionCoordinatorMock) GetAllCurrentUsedTxs ¶
func (tcm *TransactionCoordinatorMock) GetAllCurrentUsedTxs(blockType block.Type) map[string]data.TransactionHandler
GetAllCurrentUsedTxs -
func (*TransactionCoordinatorMock) IsDataPreparedForProcessing ¶
func (tcm *TransactionCoordinatorMock) IsDataPreparedForProcessing(haveTime func() time.Duration) error
IsDataPreparedForProcessing -
func (*TransactionCoordinatorMock) IsInterfaceNil ¶
func (tcm *TransactionCoordinatorMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*TransactionCoordinatorMock) ProcessBlockTransaction ¶
func (tcm *TransactionCoordinatorMock) ProcessBlockTransaction(body *block.Body, haveTime func() time.Duration) error
ProcessBlockTransaction -
func (*TransactionCoordinatorMock) RemoveBlockDataFromPool ¶
func (tcm *TransactionCoordinatorMock) RemoveBlockDataFromPool(body *block.Body) error
RemoveBlockDataFromPool -
func (*TransactionCoordinatorMock) RemoveTxsFromPool ¶ added in v1.1.7
func (tcm *TransactionCoordinatorMock) RemoveTxsFromPool(body *block.Body) error
RemoveTxsFromPool -
func (*TransactionCoordinatorMock) RequestBlockTransactions ¶
func (tcm *TransactionCoordinatorMock) RequestBlockTransactions(body *block.Body)
RequestBlockTransactions -
func (*TransactionCoordinatorMock) RequestMiniBlocks ¶
func (tcm *TransactionCoordinatorMock) RequestMiniBlocks(header data.HeaderHandler)
RequestMiniBlocks -
func (*TransactionCoordinatorMock) RestoreBlockDataFromStorage ¶
func (tcm *TransactionCoordinatorMock) RestoreBlockDataFromStorage(body *block.Body) (int, error)
RestoreBlockDataFromStorage -
func (*TransactionCoordinatorMock) SaveTxsToStorage ¶ added in v1.1.7
func (tcm *TransactionCoordinatorMock) SaveTxsToStorage(body *block.Body) error
SaveTxsToStorage -
func (*TransactionCoordinatorMock) VerifyCreatedBlockTransactions ¶
func (tcm *TransactionCoordinatorMock) VerifyCreatedBlockTransactions(hdr data.HeaderHandler, body *block.Body) error
VerifyCreatedBlockTransactions -
func (*TransactionCoordinatorMock) VerifyCreatedMiniBlocks ¶ added in v1.1.28
func (tcm *TransactionCoordinatorMock) VerifyCreatedMiniBlocks(hdr data.HeaderHandler, body *block.Body) error
VerifyCreatedMiniBlocks -
type TransactionSimulatorStub ¶ added in v1.2.4
type TransactionSimulatorStub struct {
ProcessTxCalled func(tx *transaction.Transaction) (*txSimData.SimulationResults, error)
}
TransactionSimulatorStub -
func (*TransactionSimulatorStub) IsInterfaceNil ¶ added in v1.2.4
func (tss *TransactionSimulatorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*TransactionSimulatorStub) ProcessTx ¶ added in v1.2.4
func (tss *TransactionSimulatorStub) ProcessTx(tx *transaction.Transaction) (*txSimData.SimulationResults, error)
ProcessTx -
type TriesHolderStub ¶ added in v1.2.0
type TriesHolderStub struct { PutCalled func([]byte, common.Trie) RemoveCalled func([]byte, common.Trie) GetCalled func([]byte) common.Trie GetAllCalled func() []common.Trie ResetCalled func() }
TriesHolderStub -
func (*TriesHolderStub) Get ¶ added in v1.2.0
func (ths *TriesHolderStub) Get(key []byte) common.Trie
Get -
func (*TriesHolderStub) GetAll ¶ added in v1.2.0
func (ths *TriesHolderStub) GetAll() []common.Trie
GetAll -
func (*TriesHolderStub) IsInterfaceNil ¶ added in v1.2.0
func (ths *TriesHolderStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*TriesHolderStub) Put ¶ added in v1.2.0
func (ths *TriesHolderStub) Put(key []byte, trie common.Trie)
Put -
type TxForCurrentBlockStub ¶ added in v1.1.15
type TxForCurrentBlockStub struct { CleanCalled func() GetTxCalled func(txHash []byte) (data.TransactionHandler, error) AddTxCalled func(txHash []byte, tx data.TransactionHandler) }
TxForCurrentBlockStub -
func (*TxForCurrentBlockStub) AddTx ¶ added in v1.1.15
func (t *TxForCurrentBlockStub) AddTx(txHash []byte, tx data.TransactionHandler)
AddTx -
func (*TxForCurrentBlockStub) Clean ¶ added in v1.1.15
func (t *TxForCurrentBlockStub) Clean()
Clean -
func (*TxForCurrentBlockStub) GetTx ¶ added in v1.1.15
func (t *TxForCurrentBlockStub) GetTx(txHash []byte) (data.TransactionHandler, error)
GetTx -
func (*TxForCurrentBlockStub) IsInterfaceNil ¶ added in v1.1.15
func (t *TxForCurrentBlockStub) IsInterfaceNil() bool
IsInterfaceNil -
type TxLogProcessorMock ¶ added in v1.2.0
type TxLogProcessorMock struct { }
TxLogProcessorMock -
func (*TxLogProcessorMock) EnableLogToBeSavedInCache ¶ added in v1.2.0
func (t *TxLogProcessorMock) EnableLogToBeSavedInCache()
EnableLogToBeSavedInCache -
func (*TxLogProcessorMock) GetLogFromCache ¶ added in v1.2.0
func (t *TxLogProcessorMock) GetLogFromCache(_ []byte) (data.LogHandler, bool)
GetLogFromCache -
func (*TxLogProcessorMock) IsInterfaceNil ¶ added in v1.2.0
func (t *TxLogProcessorMock) IsInterfaceNil() bool
IsInterfaceNil -
type TxLogsProcessorStub ¶ added in v1.0.104
type TxLogsProcessorStub struct { GetLogCalled func(txHash []byte) (data.LogHandler, error) SaveLogCalled func(txHash []byte, tx data.TransactionHandler, vmLogs []*vmcommon.LogEntry) error }
TxLogsProcessorStub -
func (*TxLogsProcessorStub) Clean ¶ added in v1.2.3
func (txls *TxLogsProcessorStub) Clean()
Clean -
func (*TxLogsProcessorStub) GetAllCurrentLogs ¶ added in v1.2.3
func (txls *TxLogsProcessorStub) GetAllCurrentLogs() map[string]data.LogHandler
GetAllCurrentLogs -
func (*TxLogsProcessorStub) GetLog ¶ added in v1.0.104
func (txls *TxLogsProcessorStub) GetLog(txHash []byte) (data.LogHandler, error)
GetLog -
func (*TxLogsProcessorStub) IsInterfaceNil ¶ added in v1.0.104
func (txls *TxLogsProcessorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*TxLogsProcessorStub) SaveLog ¶ added in v1.0.104
func (txls *TxLogsProcessorStub) SaveLog(txHash []byte, tx data.TransactionHandler, vmLogs []*vmcommon.LogEntry) error
SaveLog -
type Uint64ByteSliceConverterMock ¶
type Uint64ByteSliceConverterMock struct { ToByteSliceCalled func(uint64) []byte ToUint64Called func([]byte) (uint64, error) }
Uint64ByteSliceConverterMock converts byte slice to/from uint64
func (*Uint64ByteSliceConverterMock) IsInterfaceNil ¶
func (u *Uint64ByteSliceConverterMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*Uint64ByteSliceConverterMock) ToByteSlice ¶
func (u *Uint64ByteSliceConverterMock) ToByteSlice(p uint64) []byte
ToByteSlice is a mock implementation for Uint64ByteSliceConverter
type UnitOpenerStub ¶ added in v1.0.111
type UnitOpenerStub struct { }
UnitOpenerStub -
func (*UnitOpenerStub) GetMostRecentBootstrapStorageUnit ¶ added in v1.0.111
func (u *UnitOpenerStub) GetMostRecentBootstrapStorageUnit() (storage.Storer, error)
GetMostRecentBootstrapStorageUnit -
func (*UnitOpenerStub) IsInterfaceNil ¶ added in v1.0.111
func (u *UnitOpenerStub) IsInterfaceNil() bool
IsInterfaceNil -
type VMContainerMock ¶
type VMContainerMock struct { GetCalled func(key []byte) (vmcommon.VMExecutionHandler, error) AddCalled func(key []byte, val vmcommon.VMExecutionHandler) error AddMultipleCalled func(keys [][]byte, preprocessors []vmcommon.VMExecutionHandler) error ReplaceCalled func(key []byte, val vmcommon.VMExecutionHandler) error RemoveCalled func(key []byte) LenCalled func() int KeysCalled func() [][]byte }
VMContainerMock -
func (*VMContainerMock) Add ¶
func (vmc *VMContainerMock) Add(key []byte, val vmcommon.VMExecutionHandler) error
Add -
func (*VMContainerMock) AddMultiple ¶
func (vmc *VMContainerMock) AddMultiple(keys [][]byte, vms []vmcommon.VMExecutionHandler) error
AddMultiple -
func (*VMContainerMock) Get ¶
func (vmc *VMContainerMock) Get(key []byte) (vmcommon.VMExecutionHandler, error)
Get -
func (*VMContainerMock) IsInterfaceNil ¶
func (vmc *VMContainerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*VMContainerMock) Replace ¶
func (vmc *VMContainerMock) Replace(key []byte, val vmcommon.VMExecutionHandler) error
Replace -
type VMExecutionHandlerStub ¶
type VMExecutionHandlerStub struct { RunSmartContractCreateCalled func(input *vmcommon.ContractCreateInput) (*vmcommon.VMOutput, error) RunSmartContractCallCalled func(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error) GasScheduleChangeCalled func(gasSchedule map[string]map[string]uint64) GetVersionCalled func() string }
VMExecutionHandlerStub -
func (*VMExecutionHandlerStub) GasScheduleChange ¶ added in v1.1.12
func (vm *VMExecutionHandlerStub) GasScheduleChange(gasSchedule map[string]map[string]uint64)
GasScheduleChange -
func (*VMExecutionHandlerStub) GetVersion ¶ added in v1.1.60
func (vm *VMExecutionHandlerStub) GetVersion() string
GetVersion -
func (*VMExecutionHandlerStub) IsInterfaceNil ¶ added in v1.1.12
func (vm *VMExecutionHandlerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*VMExecutionHandlerStub) RunSmartContractCall ¶
func (vm *VMExecutionHandlerStub) RunSmartContractCall(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error)
RunSmartContractCall computes the result of a smart contract call and how the system must change after the execution
func (*VMExecutionHandlerStub) RunSmartContractCreate ¶
func (vm *VMExecutionHandlerStub) RunSmartContractCreate(input *vmcommon.ContractCreateInput) (*vmcommon.VMOutput, error)
RunSmartContractCreate --
type ValidatorInfoSyncerStub ¶ added in v1.0.102
type ValidatorInfoSyncerStub struct { }
ValidatorInfoSyncerStub -
func (*ValidatorInfoSyncerStub) IsInterfaceNil ¶ added in v1.0.102
func (vip *ValidatorInfoSyncerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ValidatorInfoSyncerStub) SyncMiniBlocks ¶ added in v1.0.102
func (vip *ValidatorInfoSyncerStub) SyncMiniBlocks(*block.MetaBlock) ([][]byte, data.BodyHandler, error)
SyncMiniBlocks -
type ValidatorStatisticsProcessorStub ¶
type ValidatorStatisticsProcessorStub struct { UpdatePeerStateCalled func(header data.HeaderHandler) ([]byte, error) RevertPeerStateCalled func(header data.HeaderHandler) error GetPeerAccountCalled func(address []byte) (state.PeerAccountHandler, error) RootHashCalled func() ([]byte, error) ResetValidatorStatisticsAtNewEpochCalled func(vInfos map[uint32][]*state.ValidatorInfo) error GetValidatorInfoForRootHashCalled func(rootHash []byte) (map[uint32][]*state.ValidatorInfo, error) ProcessRatingsEndOfEpochCalled func(validatorInfos map[uint32][]*state.ValidatorInfo, epoch uint32) error ProcessCalled func(validatorInfo data.ShardValidatorInfoHandler) error CommitCalled func() ([]byte, error) PeerAccountToValidatorInfoCalled func(peerAccount state.PeerAccountHandler) *state.ValidatorInfo SaveNodesCoordinatorUpdatesCalled func(epoch uint32) (bool, error) }
ValidatorStatisticsProcessorStub -
func (*ValidatorStatisticsProcessorStub) Commit ¶ added in v0.0.5
func (vsp *ValidatorStatisticsProcessorStub) Commit() ([]byte, error)
Commit -
func (*ValidatorStatisticsProcessorStub) DisplayRatings ¶ added in v1.0.111
func (vsp *ValidatorStatisticsProcessorStub) DisplayRatings(_ uint32)
DisplayRatings -
func (*ValidatorStatisticsProcessorStub) GetExistingPeerAccount ¶ added in v1.1.1
func (vsp *ValidatorStatisticsProcessorStub) GetExistingPeerAccount(address []byte) (state.PeerAccountHandler, error)
GetExistingPeerAccount -
func (*ValidatorStatisticsProcessorStub) GetValidatorInfoForRootHash ¶
func (vsp *ValidatorStatisticsProcessorStub) GetValidatorInfoForRootHash(rootHash []byte) (map[uint32][]*state.ValidatorInfo, error)
GetValidatorInfoForRootHash -
func (*ValidatorStatisticsProcessorStub) IsInterfaceNil ¶
func (vsp *ValidatorStatisticsProcessorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ValidatorStatisticsProcessorStub) LastFinalizedRootHash ¶ added in v1.0.118
func (vsp *ValidatorStatisticsProcessorStub) LastFinalizedRootHash() []byte
LastFinalizedRootHash -
func (*ValidatorStatisticsProcessorStub) PeerAccountToValidatorInfo ¶ added in v1.1.1
func (vsp *ValidatorStatisticsProcessorStub) PeerAccountToValidatorInfo(peerAccount state.PeerAccountHandler) *state.ValidatorInfo
PeerAccountToValidatorInfo -
func (*ValidatorStatisticsProcessorStub) Process ¶
func (vsp *ValidatorStatisticsProcessorStub) Process(validatorInfo data.ShardValidatorInfoHandler) error
Process -
func (*ValidatorStatisticsProcessorStub) ProcessRatingsEndOfEpoch ¶ added in v0.0.5
func (vsp *ValidatorStatisticsProcessorStub) ProcessRatingsEndOfEpoch(validatorInfos map[uint32][]*state.ValidatorInfo, epoch uint32) error
ProcessRatingsEndOfEpoch -
func (*ValidatorStatisticsProcessorStub) ResetValidatorStatisticsAtNewEpoch ¶
func (vsp *ValidatorStatisticsProcessorStub) ResetValidatorStatisticsAtNewEpoch(vInfos map[uint32][]*state.ValidatorInfo) error
ResetValidatorStatisticsAtNewEpoch -
func (*ValidatorStatisticsProcessorStub) RevertPeerState ¶
func (vsp *ValidatorStatisticsProcessorStub) RevertPeerState(header data.HeaderHandler) error
RevertPeerState -
func (*ValidatorStatisticsProcessorStub) RootHash ¶
func (vsp *ValidatorStatisticsProcessorStub) RootHash() ([]byte, error)
RootHash -
func (*ValidatorStatisticsProcessorStub) SaveNodesCoordinatorUpdates ¶ added in v1.1.15
func (vsp *ValidatorStatisticsProcessorStub) SaveNodesCoordinatorUpdates(epoch uint32) (bool, error)
SaveNodesCoordinatorUpdates -
func (*ValidatorStatisticsProcessorStub) SetLastFinalizedRootHash ¶ added in v1.0.118
func (vsp *ValidatorStatisticsProcessorStub) SetLastFinalizedRootHash(_ []byte)
SetLastFinalizedRootHash -
func (*ValidatorStatisticsProcessorStub) UpdatePeerState ¶
func (vsp *ValidatorStatisticsProcessorStub) UpdatePeerState(header data.HeaderHandler, _ map[string]data.HeaderHandler) ([]byte, error)
UpdatePeerState -
type ValidatorsProviderStub ¶ added in v1.0.117
type ValidatorsProviderStub struct {
GetLatestValidatorsCalled func() map[string]*state.ValidatorApiResponse
}
ValidatorsProviderStub -
func (*ValidatorsProviderStub) Close ¶ added in v1.2.0
func (vp *ValidatorsProviderStub) Close() error
Close -
func (*ValidatorsProviderStub) GetLatestValidators ¶ added in v1.0.117
func (vp *ValidatorsProviderStub) GetLatestValidators() map[string]*state.ValidatorApiResponse
GetLatestValidators -
func (*ValidatorsProviderStub) IsInterfaceNil ¶ added in v1.0.117
func (vp *ValidatorsProviderStub) IsInterfaceNil() bool
IsInterfaceNil -
type VmMachinesContainerFactoryMock ¶ added in v1.2.0
type VmMachinesContainerFactoryMock struct { }
VmMachinesContainerFactoryMock -
func (*VmMachinesContainerFactoryMock) BlockChainHookImpl ¶ added in v1.2.0
func (v *VmMachinesContainerFactoryMock) BlockChainHookImpl() process.BlockChainHookHandler
BlockChainHookImpl -
func (*VmMachinesContainerFactoryMock) Close ¶ added in v1.2.0
func (v *VmMachinesContainerFactoryMock) Close() error
Close -
func (*VmMachinesContainerFactoryMock) Create ¶ added in v1.2.0
func (v *VmMachinesContainerFactoryMock) Create() (process.VirtualMachinesContainer, error)
Create -
func (*VmMachinesContainerFactoryMock) IsInterfaceNil ¶ added in v1.2.0
func (v *VmMachinesContainerFactoryMock) IsInterfaceNil() bool
IsInterfaceNil -
type WatchdogMock ¶ added in v1.0.133
type WatchdogMock struct { }
WatchdogMock -
func (*WatchdogMock) IsInterfaceNil ¶ added in v1.0.133
func (w *WatchdogMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*WatchdogMock) Set ¶ added in v1.0.133
func (w *WatchdogMock) Set(callback func(alarmID string), duration time.Duration, alarmID string)
Set -
func (*WatchdogMock) SetDefault ¶ added in v1.0.133
func (w *WatchdogMock) SetDefault(duration time.Duration, alarmID string)
SetDefault -
Source Files ¶
- accountFactoryStub.go
- accountsDBSyncerStub.go
- accountsParserStub.go
- blackListHandleStub.go
- blockChainHookHandlerMock.go
- blockChainMock.go
- blockProcessorMock.go
- blockSizeThrottlerStub.go
- blockTrackerStub.go
- bootstrapStorerMock.go
- builtInCostHandlerStub.go
- chainStorerMock.go
- coreComponentsStub.go
- countingDB.go
- cryptoComponentsStub.go
- currentNetworkEpochProviderStub.go
- dataComponentsStub.go
- databaseWritterMock.go
- dbMock.go
- endOfEpochTriggerStub.go
- epochEconomicsStub.go
- epochNotifierStub.go
- epochRewardsCreatorStub.go
- epochStartDataCreatorStub.go
- epochStartNotifier.go
- epochStartSystemSCStub.go
- epochValidatorInfoCreatorStub.go
- exportFactoryHandlerStub.go
- exportHandlerStub.go
- feeHandlerStub.go
- forkDetectorStub.go
- gasHandlerMock.go
- gasScheduleNotifierMock.go
- hardforkTriggerStub.go
- headerIntegrityVerifierStub.go
- headerResolverStub.go
- headerSigVerifierStub.go
- headerValidatorStub.go
- headersCacherStub.go
- heartbeatComponentsStub.go
- heartbeatMessageHandlerStub.go
- heartbeatMonitorStub.go
- heartbeatSenderStub.go
- heartbeatStorerStub.go
- importStartHandlerStub.go
- interimProcessorContainerMock.go
- intermediateTransactionHandlerMock.go
- keyMock.go
- latestStorageDataProviderStub.go
- listIndexUpdaterStub.go
- messageSignVerifierMock.go
- miniBlocksProviderStub.go
- miniBlocksResolverStub.go
- multipleShardsCoordinatorMock.go
- networkComponentsMock.go
- networkShardingCollectorMock.go
- nilAntifloodHandler.go
- nilOutport.go
- nodeInfoMock.go
- nodesCoordinatorCacheMock.go
- nodesCoordinatorMock.go
- nodesHandlerMock.go
- nodesSetupStub.go
- oneSCExecutorMockVM.go
- p2pAntifloodHandlerStub.go
- peerBlackListCacherStub.go
- peerChangesHandler.go
- peerDenialEvaluatorStub.go
- peerHonestyHandlerStub.go
- peerShardMapperStub.go
- peerSignatureHandler.go
- peerTypeProviderStub.go
- pendingMiniBlocksHandlerStub.go
- processComponentsStub.go
- raterMock.go
- ratingReaderMock.go
- redundancyHandlerStub.go
- requestedItemsHandlerStub.go
- resolversContainerStub.go
- resolversFinderStub.go
- rounderMock.go
- scQueryStub.go
- scToProtocolHandlerMock.go
- shuffledOutHandlerStub.go
- shufflerMock.go
- signerMock.go
- smartContractParserStub.go
- softwareVersionCheckerMock.go
- statusComponentsStub.go
- statusMetricsStub.go
- storageBootstrapperMock.go
- storageManagerStub.go
- storerMock.go
- syncTimerMock.go
- timeCacherStub.go
- topicAntifloodStub.go
- transactionCoordinatorMock.go
- transactionSimulatorStub.go
- triesHolderStub.go
- txForCurrentBlockStub.go
- txLogsProcessorMock.go
- txLogsProcessorStub.go
- uint64ByteSliceConverterMock.go
- unitOpenerStub.go
- validatorInfoSyncerStub.go
- validatorStatisticsProcessorStub.go
- validatorsProviderStub.go
- vmContainerMock.go
- vmExecutionHandlerStub.go
- vmFactoryMock.go
- watchdogMock.go