Versions in this module Expand all Collapse all v1 v1.999.0 Nov 17, 2022 Changes in this version + func NewInterceptedMetaBlockMock(hdr data.HeaderHandler, hash []byte) *interceptedMetaBlockMock + func NewMultiShardsCoordinatorMock(nrShard uint32) *multipleShardsCoordinatorMock + func NewMultipleShardsCoordinatorMock() *multipleShardsCoordinatorMock + type AddressMock struct + func NewAddressMock(adr []byte) *AddressMock + func (adr *AddressMock) Bytes() []byte + func (adr *AddressMock) IsInterfaceNil() bool + type ArgumentParserMock struct + CreateDataFromStorageUpdateCalled func(storageUpdates []*vmcommon.StorageUpdate) string + GetStorageUpdatesCalled func(data string) ([]*vmcommon.StorageUpdate, error) + ParseArgumentsCalled func(data string) ([][]byte, error) + ParseCallDataCalled func(data string) (string, [][]byte, error) + ParseDeployDataCalled func(data string) (*parsers.DeployArgs, error) + func (ap *ArgumentParserMock) CreateDataFromStorageUpdate(storageUpdates []*vmcommon.StorageUpdate) string + func (ap *ArgumentParserMock) GetStorageUpdates(data string) ([]*vmcommon.StorageUpdate, error) + func (ap *ArgumentParserMock) IsInterfaceNil() bool + func (ap *ArgumentParserMock) ParseArguments(data string) ([][]byte, error) + func (ap *ArgumentParserMock) ParseCallData(data string) (string, [][]byte, error) + func (ap *ArgumentParserMock) ParseDeployData(data string) (*parsers.DeployArgs, error) + type BuiltInCostHandlerStub struct + func (b *BuiltInCostHandlerStub) ComputeBuiltInCost(_ data.TransactionWithFeeHandler) uint64 + func (b *BuiltInCostHandlerStub) IsBuiltInFuncCall(_ data.TransactionWithFeeHandler) bool + func (b *BuiltInCostHandlerStub) IsInterfaceNil() bool + type ChainStorerStub struct + AddStorerCalled func(key dataRetriever.UnitType, s storage.Storer) + CloseAllCalled func() error + DestroyCalled func() error + GetAllCalled func(unitType dataRetriever.UnitType, keys [][]byte) (map[string][]byte, error) + GetAllStorersCalled func() map[dataRetriever.UnitType]storage.Storer + GetCalled func(unitType dataRetriever.UnitType, key []byte) ([]byte, error) + GetStorerCalled func(unitType dataRetriever.UnitType) storage.Storer + HasCalled func(unitType dataRetriever.UnitType, key []byte) error + PutCalled func(unitType dataRetriever.UnitType, key []byte, value []byte) error + func (bc *ChainStorerStub) AddStorer(key dataRetriever.UnitType, s storage.Storer) + func (bc *ChainStorerStub) CloseAll() error + func (bc *ChainStorerStub) Destroy() error + func (bc *ChainStorerStub) Get(unitType dataRetriever.UnitType, key []byte) ([]byte, error) + func (bc *ChainStorerStub) GetAll(unitType dataRetriever.UnitType, keys [][]byte) (map[string][]byte, error) + func (bc *ChainStorerStub) GetAllStorers() map[dataRetriever.UnitType]storage.Storer + func (bc *ChainStorerStub) GetStorer(unitType dataRetriever.UnitType) storage.Storer + func (bc *ChainStorerStub) Has(unitType dataRetriever.UnitType, key []byte) error + func (bc *ChainStorerStub) IsInterfaceNil() bool + func (bc *ChainStorerStub) Put(unitType dataRetriever.UnitType, key []byte, value []byte) error + func (bc *ChainStorerStub) SetEpochForPutOperation(_ uint32) + type ChanceComputerStub struct + GetChanceCalled func(rating uint32) uint32 + func (c *ChanceComputerStub) GetChance(rating uint32) uint32 + func (c *ChanceComputerStub) IsInterfaceNil() bool + type CoreComponentsMock struct + AddrPubKeyConv core.PubkeyConverter + ChainIdCalled func() string + ChanStopNode chan endProcess.ArgEndProcess + EpochNotifierField process.EpochNotifier + GenesisNodesSetupCalled func() sharding.GenesisNodesSetupHandler + HardforkTriggerPubKeyField []byte + Hash hashing.Hasher + IntMarsh marshal.Marshalizer + Marsh marshal.Marshalizer + MinTransactionVersionCalled func() uint32 + NodeTypeProviderField core.NodeTypeProviderHandler + PathHdl storage.PathManagerHandler + ProcessStatusHandlerInstance common.ProcessStatusHandler + StatusHandlerCalled func() core.AppStatusHandler + TxSignHasherField hashing.Hasher + TxVersionCheckField process.TxVersionCheckerHandler + UInt64ByteSliceConv typeConverters.Uint64ByteSliceConverter + ValPubKeyConv core.PubkeyConverter + func (ccm *CoreComponentsMock) AddressPubKeyConverter() core.PubkeyConverter + func (ccm *CoreComponentsMock) ChainID() string + func (ccm *CoreComponentsMock) ChanStopNodeProcess() chan endProcess.ArgEndProcess + func (ccm *CoreComponentsMock) EpochNotifier() process.EpochNotifier + func (ccm *CoreComponentsMock) GenesisNodesSetup() sharding.GenesisNodesSetupHandler + func (ccm *CoreComponentsMock) HardforkTriggerPubKey() []byte + func (ccm *CoreComponentsMock) Hasher() hashing.Hasher + func (ccm *CoreComponentsMock) InternalMarshalizer() marshal.Marshalizer + func (ccm *CoreComponentsMock) IsInterfaceNil() bool + func (ccm *CoreComponentsMock) MinTransactionVersion() uint32 + func (ccm *CoreComponentsMock) NodeTypeProvider() core.NodeTypeProviderHandler + func (ccm *CoreComponentsMock) PathHandler() storage.PathManagerHandler + func (ccm *CoreComponentsMock) ProcessStatusHandler() common.ProcessStatusHandler + func (ccm *CoreComponentsMock) SetInternalMarshalizer(m marshal.Marshalizer) error + func (ccm *CoreComponentsMock) StatusHandler() core.AppStatusHandler + func (ccm *CoreComponentsMock) TxMarshalizer() marshal.Marshalizer + func (ccm *CoreComponentsMock) TxSignHasher() hashing.Hasher + func (ccm *CoreComponentsMock) TxVersionChecker() process.TxVersionCheckerHandler + func (ccm *CoreComponentsMock) Uint64ByteSliceConverter() typeConverters.Uint64ByteSliceConverter + func (ccm *CoreComponentsMock) ValidatorPubKeyConverter() core.PubkeyConverter + type CryptoComponentsMock struct + BlKeyGen crypto.KeyGenerator + BlockSig crypto.SingleSigner + MultiSig crypto.MultiSigner + PeerSignHandler crypto.PeerSignatureHandler + PubKey crypto.PublicKey + TxKeyGen crypto.KeyGenerator + TxSig crypto.SingleSigner + func (ccm *CryptoComponentsMock) BlockSignKeyGen() crypto.KeyGenerator + func (ccm *CryptoComponentsMock) BlockSigner() crypto.SingleSigner + func (ccm *CryptoComponentsMock) Clone() interface{} + func (ccm *CryptoComponentsMock) IsInterfaceNil() bool + func (ccm *CryptoComponentsMock) MultiSigner() crypto.MultiSigner + func (ccm *CryptoComponentsMock) PeerSignatureHandler() crypto.PeerSignatureHandler + func (ccm *CryptoComponentsMock) PublicKey() crypto.PublicKey + func (ccm *CryptoComponentsMock) SetMultiSigner(m crypto.MultiSigner) error + func (ccm *CryptoComponentsMock) TxSignKeyGen() crypto.KeyGenerator + func (ccm *CryptoComponentsMock) TxSingleSigner() crypto.SingleSigner + type DataTrieTrackerStub struct + ClearDataCachesCalled func() + DataTrieCalled func() common.Trie + DirtyDataCalled func() map[string][]byte + RetrieveValueCalled func(key []byte) ([]byte, error) + SaveKeyValueCalled func(key []byte, value []byte) error + SetDataTrieCalled func(tr common.Trie) + func (dtts *DataTrieTrackerStub) ClearDataCaches() + func (dtts *DataTrieTrackerStub) DataTrie() common.Trie + func (dtts *DataTrieTrackerStub) DirtyData() map[string][]byte + func (dtts *DataTrieTrackerStub) IsInterfaceNil() bool + func (dtts *DataTrieTrackerStub) RetrieveValue(key []byte) ([]byte, error) + func (dtts *DataTrieTrackerStub) SaveKeyValue(key []byte, value []byte) error + func (dtts *DataTrieTrackerStub) SetDataTrie(tr common.Trie) + type EconomicsHandlerStub struct + CheckValidityTxValuesCalled func(tx data.TransactionWithFeeHandler) error + ComputeFeeForProcessingCalled func(tx data.TransactionWithFeeHandler, gasToUse uint64) *big.Int + ComputeGasLimitBasedOnBalanceCalled func(tx data.TransactionWithFeeHandler, balance *big.Int) (uint64, error) + ComputeGasLimitCalled func(tx data.TransactionWithFeeHandler) uint64 + ComputeGasUsedAndFeeBasedOnRefundValueCalled func(tx data.TransactionWithFeeHandler, refundValue *big.Int) (uint64, *big.Int) + ComputeMoveBalanceFeeCalled func(tx data.TransactionWithFeeHandler) *big.Int + ComputeTxFeeBasedOnGasUsedCalled func(tx data.TransactionWithFeeHandler, gasUsed uint64) *big.Int + ComputeTxFeeCalled func(tx data.TransactionWithFeeHandler) *big.Int + DeveloperPercentageCalled func() float64 + GasPriceForMoveCalled func(tx data.TransactionWithFeeHandler) uint64 + GasPriceForProcessingCalled func(tx data.TransactionWithFeeHandler) uint64 + GasPriceModifierCalled func() float64 + LeaderPercentageCalled func() float64 + MaxGasLimitPerBlockCalled func() uint64 + MaxGasLimitPerBlockForSafeCrossShardCalled func() uint64 + MaxGasLimitPerMiniBlockCalled func() uint64 + MaxGasLimitPerMiniBlockForSafeCrossShardCalled func() uint64 + MaxGasLimitPerTxCalled func() uint64 + MaxInflationRateCalled func(year uint32) float64 + MinGasPriceCalled func() uint64 + MinGasPriceForProcessingCalled func() uint64 + MinInflationRateCalled func() float64 + ProtocolSustainabilityAddressCalled func() string + ProtocolSustainabilityPercentageCalled func() float64 + RewardsTopUpFactorCalled func() float64 + RewardsTopUpGradientPointCalled func() *big.Int + SetMinGasLimitCalled func(minGasLimit uint64) + SetMinGasPriceCalled func(minasPrice uint64) + SplitTxGasInCategoriesCalled func(tx data.TransactionWithFeeHandler) (uint64, uint64) + func (ehs *EconomicsHandlerStub) CheckValidityTxValues(tx data.TransactionWithFeeHandler) error + func (ehs *EconomicsHandlerStub) ComputeFeeForProcessing(tx data.TransactionWithFeeHandler, gasToUse uint64) *big.Int + func (ehs *EconomicsHandlerStub) ComputeGasLimit(tx data.TransactionWithFeeHandler) uint64 + func (ehs *EconomicsHandlerStub) ComputeGasLimitBasedOnBalance(tx data.TransactionWithFeeHandler, balance *big.Int) (uint64, error) + func (ehs *EconomicsHandlerStub) ComputeGasUsedAndFeeBasedOnRefundValue(tx data.TransactionWithFeeHandler, refundValue *big.Int) (uint64, *big.Int) + func (ehs *EconomicsHandlerStub) ComputeMoveBalanceFee(tx data.TransactionWithFeeHandler) *big.Int + func (ehs *EconomicsHandlerStub) ComputeTxFee(tx data.TransactionWithFeeHandler) *big.Int + func (ehs *EconomicsHandlerStub) ComputeTxFeeBasedOnGasUsed(tx data.TransactionWithFeeHandler, gasUsed uint64) *big.Int + func (ehs *EconomicsHandlerStub) DeveloperPercentage() float64 + func (ehs *EconomicsHandlerStub) GasPerDataByte() uint64 + func (ehs *EconomicsHandlerStub) GasPriceForMove(tx data.TransactionWithFeeHandler) uint64 + func (ehs *EconomicsHandlerStub) GasPriceForProcessing(tx data.TransactionWithFeeHandler) uint64 + func (ehs *EconomicsHandlerStub) GasPriceModifier() float64 + func (ehs *EconomicsHandlerStub) GenesisTotalSupply() *big.Int + func (ehs *EconomicsHandlerStub) IsInterfaceNil() bool + func (ehs *EconomicsHandlerStub) LeaderPercentage() float64 + func (ehs *EconomicsHandlerStub) MaxGasLimitPerBlock(uint32) uint64 + func (ehs *EconomicsHandlerStub) MaxGasLimitPerBlockForSafeCrossShard() uint64 + func (ehs *EconomicsHandlerStub) MaxGasLimitPerMiniBlock(uint32) uint64 + func (ehs *EconomicsHandlerStub) MaxGasLimitPerMiniBlockForSafeCrossShard() uint64 + func (ehs *EconomicsHandlerStub) MaxGasLimitPerTx() uint64 + func (ehs *EconomicsHandlerStub) MaxInflationRate(year uint32) float64 + func (ehs *EconomicsHandlerStub) MinGasLimit() uint64 + func (ehs *EconomicsHandlerStub) MinGasPrice() uint64 + func (ehs *EconomicsHandlerStub) MinGasPriceForProcessing() uint64 + func (ehs *EconomicsHandlerStub) MinInflationRate() float64 + func (ehs *EconomicsHandlerStub) ProtocolSustainabilityAddress() string + func (ehs *EconomicsHandlerStub) ProtocolSustainabilityPercentage() float64 + func (ehs *EconomicsHandlerStub) RewardsTopUpFactor() float64 + func (ehs *EconomicsHandlerStub) RewardsTopUpGradientPoint() *big.Int + func (ehs *EconomicsHandlerStub) SplitTxGasInCategories(tx data.TransactionWithFeeHandler) (uint64, uint64) + type EpochStartMetaBlockProcessorStub struct + GetEpochStartMetaBlockCalled func(ctx context.Context) (data.MetaHeaderHandler, error) + RegisterHandlerCalled func(handler func(topic string, hash []byte, data interface{})) + SaveCalled func(data process.InterceptedData, fromConnectedPeer core.PeerID, topic string) error + ValidateCalled func(data process.InterceptedData, fromConnectedPeer core.PeerID) error + func (esmbps *EpochStartMetaBlockProcessorStub) GetEpochStartMetaBlock(ctx context.Context) (data.MetaHeaderHandler, error) + func (esmbps *EpochStartMetaBlockProcessorStub) IsInterfaceNil() bool + func (esmbps *EpochStartMetaBlockProcessorStub) RegisterHandler(handler func(topic string, hash []byte, data interface{})) + func (esmbps *EpochStartMetaBlockProcessorStub) Save(data process.InterceptedData, fromConnectedPeer core.PeerID, topic string) error + func (esmbps *EpochStartMetaBlockProcessorStub) Validate(data process.InterceptedData, fromConnectedPeer core.PeerID) error + type EpochStartNotifierStub struct + NotifyAllCalled func(hdr data.HeaderHandler) + NotifyAllPrepareCalled func(hdr data.HeaderHandler, body data.BodyHandler) + NotifyEpochChangeConfirmedCalled func(epoch uint32) + 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) + type HeaderIntegrityVerifierStub struct + GetVersionCalled func(epoch uint32) string + VerifyCalled func(header data.HeaderHandler) error + func (h *HeaderIntegrityVerifierStub) GetVersion(epoch uint32) string + func (h *HeaderIntegrityVerifierStub) IsInterfaceNil() bool + func (h *HeaderIntegrityVerifierStub) Verify(header data.HeaderHandler) error + type HeaderValidatorStub struct + IsHeaderConstructionValidCalled func(currHdr, prevHdr data.HeaderHandler) error + func (hvs *HeaderValidatorStub) IsHeaderConstructionValid(currHdr, prevHdr data.HeaderHandler) error + func (hvs *HeaderValidatorStub) IsInterfaceNil() bool + type HeadersCacherStub struct + AddCalled func(headerHash []byte, header data.HeaderHandler) + ClearCalled func() + GetHeaderByHashCalled func(hash []byte) (data.HeaderHandler, error) + GetHeaderByNonceAndShardIdCalled func(hdrNonce uint64, shardId uint32) ([]data.HeaderHandler, [][]byte, error) + GetNumHeadersCalled func(shardId uint32) int + LenCalled func() int + MaxSizeCalled func() int + NoncesCalled func(shardId uint32) []uint64 + RegisterHandlerCalled func(handler func(header data.HeaderHandler, shardHeaderHash []byte)) + RemoveHeaderByHashCalled func(headerHash []byte) + RemoveHeaderByNonceAndShardIdCalled func(hdrNonce uint64, shardId uint32) + func (hcs *HeadersCacherStub) AddHeader(headerHash []byte, header data.HeaderHandler) + func (hcs *HeadersCacherStub) Clear() + func (hcs *HeadersCacherStub) GetHeaderByHash(hash []byte) (data.HeaderHandler, error) + func (hcs *HeadersCacherStub) GetHeadersByNonceAndShardId(hdrNonce uint64, shardId uint32) ([]data.HeaderHandler, [][]byte, error) + func (hcs *HeadersCacherStub) GetNumHeaders(shardId uint32) int + func (hcs *HeadersCacherStub) IsInterfaceNil() bool + func (hcs *HeadersCacherStub) Len() int + func (hcs *HeadersCacherStub) MaxSize() int + func (hcs *HeadersCacherStub) Nonces(shardId uint32) []uint64 + func (hcs *HeadersCacherStub) RegisterHandler(handler func(header data.HeaderHandler, shardHeaderHash []byte)) + func (hcs *HeadersCacherStub) RemoveHeaderByHash(headerHash []byte) + func (hcs *HeadersCacherStub) RemoveHeaderByNonceAndShardId(hdrNonce uint64, shardId uint32) + type ImportStartHandlerStub struct + IsAfterExportBeforeImportCalled func() bool + ResetStartImportCalled func() error + SetStartImportCalled func() error + ShouldStartImportCalled func() bool + func (ish *ImportStartHandlerStub) IsAfterExportBeforeImport() bool + func (ish *ImportStartHandlerStub) IsInterfaceNil() bool + func (ish *ImportStartHandlerStub) ResetStartImport() error + func (ish *ImportStartHandlerStub) SetStartImport() error + func (ish *ImportStartHandlerStub) ShouldStartImport() bool + type LatestStorageDataProviderStub struct + GetCalled func() (storage.LatestDataFromStorage, error) + GetParentDirAndLastEpochCalled func() (string, uint32, error) + GetParentDirectoryCalled func() string + GetShardsFromDirectoryCalled func(path string) ([]string, error) + func (lsdps *LatestStorageDataProviderStub) Get() (storage.LatestDataFromStorage, error) + func (lsdps *LatestStorageDataProviderStub) GetParentDirAndLastEpoch() (string, uint32, error) + func (lsdps *LatestStorageDataProviderStub) GetParentDirectory() string + func (lsdps *LatestStorageDataProviderStub) GetShardsFromDirectory(path string) ([]string, error) + func (lsdps *LatestStorageDataProviderStub) IsInterfaceNil() bool + type MarshalizerMock struct + Fail bool + func (mm *MarshalizerMock) IsInterfaceNil() bool + func (mm *MarshalizerMock) Marshal(obj interface{}) ([]byte, error) + func (mm *MarshalizerMock) Unmarshal(obj interface{}, buff []byte) error + type MessengerStub struct + ConnectedPeersCalled func() []core.PeerID + CreateTopicCalled func(topic string, identifier bool) error + IDCalled func() core.PeerID + RegisterMessageProcessorCalled func(topic string, identifier string, handler p2p.MessageProcessor) error + UnjoinAllTopicsCalled func() error + VerifyCalled func(payload []byte, pid core.PeerID, signature []byte) error + func (m *MessengerStub) ConnectedFullHistoryPeersOnTopic(_ string) []core.PeerID + func (m *MessengerStub) ConnectedPeers() []core.PeerID + func (m *MessengerStub) ConnectedPeersOnTopic(_ string) []core.PeerID + func (m *MessengerStub) CreateTopic(topic string, identifier bool) error + func (m *MessengerStub) HasTopic(_ string) bool + func (m *MessengerStub) ID() core.PeerID + func (m *MessengerStub) IsInterfaceNil() bool + func (m *MessengerStub) RegisterMessageProcessor(topic string, identifier string, handler p2p.MessageProcessor) error + func (m *MessengerStub) SendToConnectedPeer(_ string, _ []byte, _ core.PeerID) error + func (m *MessengerStub) UnjoinAllTopics() error + func (m *MessengerStub) UnregisterAllMessageProcessors() error + func (m *MessengerStub) UnregisterMessageProcessor(_ string, _ string) error + func (m *MessengerStub) Verify(payload []byte, pid core.PeerID, signature []byte) error + type MetaBlockInterceptorProcessorStub struct + GetEpochStartMetaBlockCalled func() (data.MetaHeaderHandler, error) + func (m *MetaBlockInterceptorProcessorStub) GetEpochStartMetaBlock(_ context.Context) (data.MetaHeaderHandler, error) + func (m *MetaBlockInterceptorProcessorStub) IsInterfaceNil() bool + func (m *MetaBlockInterceptorProcessorStub) RegisterHandler(_ func(topic string, hash []byte, data interface{})) + func (m *MetaBlockInterceptorProcessorStub) Save(_ process.InterceptedData, _ core.PeerID, _ string) error + func (m *MetaBlockInterceptorProcessorStub) SignalEndOfProcessing(_ []process.InterceptedData) + func (m *MetaBlockInterceptorProcessorStub) Validate(_ process.InterceptedData, _ core.PeerID) error + type NodeInfoMock struct + func NewNodeInfo(address []byte, pubKey []byte, shardId uint32, initialRating uint32) *NodeInfoMock + func (n *NodeInfoMock) AddressBytes() []byte + func (n *NodeInfoMock) AssignedShard() uint32 + func (n *NodeInfoMock) GetInitialRating() uint32 + func (n *NodeInfoMock) IsInterfaceNil() bool + func (n *NodeInfoMock) PubKeyBytes() []byte + type NodesSetupStub struct + AllInitialNodesCalled func() []nodesCoordinator.GenesisNodeInfoHandler + GetAdaptivityCalled func() bool + GetHysteresisCalled func() float32 + GetMetaConsensusGroupSizeCalled func() uint32 + GetRoundDurationCalled func() uint64 + GetShardConsensusGroupSizeCalled func() uint32 + GetShardIDForPubKeyCalled func(pubkey []byte) (uint32, error) + GetStartTimeCalled func() int64 + InitialEligibleNodesPubKeysForShardCalled func(shardId uint32) ([]string, error) + InitialNodesInfoCalled func() (map[uint32][]nodesCoordinator.GenesisNodeInfoHandler, ...) + InitialNodesInfoForShardCalled func(shardId uint32) ([]nodesCoordinator.GenesisNodeInfoHandler, ...) + InitialNodesPubKeysCalled func() map[uint32][]string + MinNumberOfMetaNodesCalled func() uint32 + MinNumberOfNodesCalled func() uint32 + MinNumberOfNodesWithHysteresisCalled func() uint32 + MinNumberOfShardNodesCalled func() uint32 + NumberOfShardsCalled func() uint32 + func (n *NodesSetupStub) AllInitialNodes() []nodesCoordinator.GenesisNodeInfoHandler + func (n *NodesSetupStub) GetAdaptivity() bool + func (n *NodesSetupStub) GetHysteresis() float32 + func (n *NodesSetupStub) GetMetaConsensusGroupSize() uint32 + func (n *NodesSetupStub) GetRoundDuration() uint64 + func (n *NodesSetupStub) GetShardConsensusGroupSize() uint32 + func (n *NodesSetupStub) GetShardIDForPubKey(pubkey []byte) (uint32, error) + func (n *NodesSetupStub) GetStartTime() int64 + func (n *NodesSetupStub) InitialEligibleNodesPubKeysForShard(shardId uint32) ([]string, error) + func (n *NodesSetupStub) InitialNodesInfo() (map[uint32][]nodesCoordinator.GenesisNodeInfoHandler, ...) + func (n *NodesSetupStub) InitialNodesInfoForShard(shardId uint32) ([]nodesCoordinator.GenesisNodeInfoHandler, ...) + func (n *NodesSetupStub) InitialNodesPubKeys() map[uint32][]string + func (n *NodesSetupStub) IsInterfaceNil() bool + func (n *NodesSetupStub) MinNumberOfMetaNodes() uint32 + func (n *NodesSetupStub) MinNumberOfNodes() uint32 + func (n *NodesSetupStub) MinNumberOfNodesWithHysteresis() uint32 + func (n *NodesSetupStub) MinNumberOfShardNodes() uint32 + func (n *NodesSetupStub) NumberOfShards() uint32 + type PubkeyConverterMock struct + func NewPubkeyConverterMock(addressLen int) *PubkeyConverterMock + func (pcm *PubkeyConverterMock) Decode(humanReadable string) ([]byte, error) + func (pcm *PubkeyConverterMock) Encode(pkBytes []byte) string + func (pcm *PubkeyConverterMock) IsInterfaceNil() bool + func (pcm *PubkeyConverterMock) Len() int + type RaterStub struct + ComputeDecreaseProposerCalled func(shardId uint32, rating uint32, consecutiveMissedBlocks uint32) uint32 + ComputeDecreaseValidatorCalled func(shardId uint32, rating uint32) uint32 + ComputeIncreaseProposerCalled func(shardId uint32, rating uint32) uint32 + ComputeIncreaseValidatorCalled func(shardId uint32, rating uint32) uint32 + GetChanceCalled func(rating uint32) uint32 + GetRatingCalled func(string) uint32 + GetSignedBlocksThresholdCalled func() float32 + GetStartRatingCalled func() uint32 + RevertIncreaseProposerCalled func(shardId uint32, rating uint32, nrReverts uint32) uint32 + func (rm *RaterStub) ComputeDecreaseProposer(shardId uint32, currentRating uint32, consecutiveMisses uint32) uint32 + func (rm *RaterStub) ComputeDecreaseValidator(shardId uint32, currentRating uint32) uint32 + func (rm *RaterStub) ComputeIncreaseProposer(shardId uint32, currentRating uint32) uint32 + func (rm *RaterStub) ComputeIncreaseValidator(shardId uint32, currentRating uint32) uint32 + func (rm *RaterStub) GetChance(rating uint32) uint32 + func (rm *RaterStub) GetRating(pk string) uint32 + func (rm *RaterStub) GetSignedBlocksThreshold() float32 + func (rm *RaterStub) GetStartRating() uint32 + func (rm *RaterStub) IsInterfaceNil() bool + func (rm *RaterStub) RevertIncreaseValidator(shardId uint32, currentRating uint32, nrReverts uint32) uint32 + type RewardsCreatorStub struct + CreateMarshalizedDataCalled func(body *block.Body) map[string][][]byte + CreateRewardsMiniBlocksCalled func(metaBlock data.MetaHeaderHandler, ...) (block.MiniBlockSlice, error) + DeleteTxsFromStorageCalled func(metaBlock data.MetaHeaderHandler, body *block.Body) + GetLocalTxCacheCalled func() epochStart.TransactionCacher + GetProtocolSustainabilityRewardsCalled func() *big.Int + GetRewardsTxsCalled func(body *block.Body) map[string]data.TransactionHandler + RemoveBlockDataFromPoolsCalled func(metaBlock data.MetaHeaderHandler, body *block.Body) + SaveTxBlockToStorageCalled func(metaBlock data.MetaHeaderHandler, body *block.Body) + VerifyRewardsMiniBlocksCalled func(metaBlock data.MetaHeaderHandler, ...) error + func (rcs *RewardsCreatorStub) CreateMarshalizedData(body *block.Body) map[string][][]byte + func (rcs *RewardsCreatorStub) CreateRewardsMiniBlocks(metaBlock data.MetaHeaderHandler, ...) (block.MiniBlockSlice, error) + func (rcs *RewardsCreatorStub) DeleteTxsFromStorage(metaBlock data.MetaHeaderHandler, body *block.Body) + func (rcs *RewardsCreatorStub) GetLocalTxCache() epochStart.TransactionCacher + func (rcs *RewardsCreatorStub) GetProtocolSustainabilityRewards() *big.Int + func (rcs *RewardsCreatorStub) GetRewardsTxs(body *block.Body) map[string]data.TransactionHandler + func (rcs *RewardsCreatorStub) IsInterfaceNil() bool + func (rcs *RewardsCreatorStub) RemoveBlockDataFromPools(metaBlock data.MetaHeaderHandler, body *block.Body) + func (rcs *RewardsCreatorStub) SaveTxBlockToStorage(metaBlock data.MetaHeaderHandler, body *block.Body) + func (rcs *RewardsCreatorStub) VerifyRewardsMiniBlocks(metaBlock data.MetaHeaderHandler, ...) error + type RewardsHandlerStub struct + LeaderPercentageCalled func() float64 + MaxInflationRateCalled func(year uint32) float64 + MinInflationRateCalled func() float64 + ProtocolSustainabilityAddressCalled func() string + ProtocolSustainabilityPercentageCalled func() float64 + RewardsTopUpFactorCalled func() float64 + RewardsTopUpGradientPointCalled func() *big.Int + func (r *RewardsHandlerStub) IsInterfaceNil() bool + func (r *RewardsHandlerStub) LeaderPercentage() float64 + func (r *RewardsHandlerStub) MaxInflationRate(year uint32) float64 + func (r *RewardsHandlerStub) MinInflationRate() float64 + func (r *RewardsHandlerStub) ProtocolSustainabilityAddress() string + func (r *RewardsHandlerStub) ProtocolSustainabilityPercentage() float64 + func (r *RewardsHandlerStub) RewardsTopUpFactor() float64 + func (r *RewardsHandlerStub) RewardsTopUpGradientPoint() *big.Int + type RoundHandlerStub struct + IndexCalled func() int64 + RemainingTimeCalled func(startTime time.Time, maxTime time.Duration) time.Duration + RoundIndex int64 + TimeDurationCalled func() time.Duration + TimeStampCalled func() time.Time + UpdateRoundCalled func(time.Time, time.Time) + func (rndm *RoundHandlerStub) Index() int64 + func (rndm *RoundHandlerStub) IsInterfaceNil() bool + func (rndm *RoundHandlerStub) RemainingTime(startTime time.Time, maxTime time.Duration) time.Duration + func (rndm *RoundHandlerStub) TimeDuration() time.Duration + func (rndm *RoundHandlerStub) TimeStamp() time.Time + func (rndm *RoundHandlerStub) UpdateRound(genesisRoundTimeStamp time.Time, timeStamp time.Time) + type RoundTimeDurationHandler struct + TimeDurationCalled func() time.Duration + func (r *RoundTimeDurationHandler) IsInterfaceNil() bool + func (r *RoundTimeDurationHandler) TimeDuration() time.Duration + type ShardCoordinatorStub struct + CommunicationIdentifierCalled func(destShardID uint32) string + ComputeIdCalled func(address []byte) uint32 + NumberOfShardsCalled func() uint32 + SameShardCalled func(firstAddress, secondAddress []byte) bool + SelfIdCalled func() uint32 + func (coordinator *ShardCoordinatorStub) CommunicationIdentifier(destShardID uint32) string + func (coordinator *ShardCoordinatorStub) ComputeId(address []byte) uint32 + func (coordinator *ShardCoordinatorStub) IsInterfaceNil() bool + func (coordinator *ShardCoordinatorStub) NumberOfShards() uint32 + func (coordinator *ShardCoordinatorStub) SameShard(firstAddress, secondAddress []byte) bool + func (coordinator *ShardCoordinatorStub) SelfId() uint32 + type ShardIdHasMapStub struct + DeleteCalled func(shardId uint32) + LoadCalled func(shardId uint32) ([]byte, bool) + RangeCalled func(f func(shardId uint32, hash []byte) bool) + StoreCalled func(shardId uint32, hash []byte) + func (sihsm *ShardIdHasMapStub) Delete(shardId uint32) + func (sihsm *ShardIdHasMapStub) IsInterfaceNil() bool + func (sihsm *ShardIdHasMapStub) Load(shardId uint32) ([]byte, bool) + func (sihsm *ShardIdHasMapStub) Range(f func(shardId uint32, hash []byte) bool) + func (sihsm *ShardIdHasMapStub) Store(shardId uint32, hash []byte) + type StakingDataProviderStub struct + CleanCalled func() + ComputeUnQualifiedNodesCalled func(validatorInfos map[uint32][]*state.ValidatorInfo) ([][]byte, map[string][][]byte, error) + FillValidatorInfoCalled func(blsKey []byte) error + GetNodeStakedTopUpCalled func(blsKey []byte) (*big.Int, error) + GetTotalStakeEligibleNodesCalled func() *big.Int + GetTotalTopUpStakeEligibleNodesCalled func() *big.Int + PrepareStakingDataCalled func(keys map[uint32][][]byte) error + func (sdps *StakingDataProviderStub) Clean() + func (sdps *StakingDataProviderStub) ComputeUnQualifiedNodes(validatorInfos map[uint32][]*state.ValidatorInfo) ([][]byte, map[string][][]byte, error) + func (sdps *StakingDataProviderStub) FillValidatorInfo(blsKey []byte) error + func (sdps *StakingDataProviderStub) GetNodeStakedTopUp(blsKey []byte) (*big.Int, error) + func (sdps *StakingDataProviderStub) GetTotalStakeEligibleNodes() *big.Int + func (sdps *StakingDataProviderStub) GetTotalTopUpStakeEligibleNodes() *big.Int + func (sdps *StakingDataProviderStub) IsInterfaceNil() bool + func (sdps *StakingDataProviderStub) PrepareStakingDataForRewards(keys map[uint32][][]byte) error + type StorageManagerStub struct + CancelPruneCalled func([]byte) + DatabaseCalled func() common.DBWriteCacher + EnterSnapshotModeCalled func() + ExitSnapshotModeCalled func() + GetDbThatContainsHashCalled func([]byte) common.DBWriteCacher + GetSnapshotThatContainsHashCalled func(rootHash []byte) common.SnapshotDbHandler + IsInterfaceNilCalled func() bool + IsPruningEnabledCalled func() bool + MarkForEvictionCalled func([]byte, common.ModifiedHashes) error + PruneCalled func([]byte) + SetCheckpointCalled func([]byte) + TakeSnapshotCalled func([]byte) + func (sms *StorageManagerStub) CancelPrune([]byte, state.TriePruningIdentifier) + func (sms *StorageManagerStub) Close() error + func (sms *StorageManagerStub) Database() common.DBWriteCacher + func (sms *StorageManagerStub) EnterSnapshotMode() + func (sms *StorageManagerStub) ExitSnapshotMode() + func (sms *StorageManagerStub) GetSnapshotDbBatchDelay() int + func (sms *StorageManagerStub) GetSnapshotThatContainsHash(d []byte) common.SnapshotDbHandler + func (sms *StorageManagerStub) IsInterfaceNil() bool + func (sms *StorageManagerStub) IsPruningEnabled() bool + func (sms *StorageManagerStub) MarkForEviction(d []byte, m common.ModifiedHashes) error + func (sms *StorageManagerStub) Prune([]byte, state.TriePruningIdentifier) + func (sms *StorageManagerStub) SetCheckpoint([]byte) + func (sms *StorageManagerStub) TakeSnapshot([]byte) + type StorerMock struct + func NewStorerMock() *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) ([]storage.KeyValuePair, 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(key []byte) error + func (sm *StorerMock) RemoveFromCurrentEpoch(key []byte) error + func (sm *StorerMock) SearchFirst(key []byte) ([]byte, error) + type SyncTimerStub struct + ClockOffsetCalled func() time.Duration + CurrentTimeCalled func() time.Time + FormattedCurrentTimeCalled func() string + StartSyncingTimeCalled func() + func (sts *SyncTimerStub) ClockOffset() time.Duration + func (sts *SyncTimerStub) Close() error + func (sts *SyncTimerStub) CurrentTime() time.Time + func (sts *SyncTimerStub) FormattedCurrentTime() string + func (sts *SyncTimerStub) IsInterfaceNil() bool + func (sts *SyncTimerStub) StartSyncingTime() + type TxForCurrentBlockStub struct + AddTxCalled func(txHash []byte, tx data.TransactionHandler) + CleanCalled func() + GetTxCalled func(txHash []byte) (data.TransactionHandler, error) + func (t *TxForCurrentBlockStub) AddTx(txHash []byte, tx data.TransactionHandler) + func (t *TxForCurrentBlockStub) Clean() + func (t *TxForCurrentBlockStub) GetTx(txHash []byte) (data.TransactionHandler, error) + func (t *TxForCurrentBlockStub) IsInterfaceNil() bool + type Uint64ByteSliceConverterMock struct + ToByteSliceCalled func(uint64) []byte + ToUint64Called func([]byte) (uint64, error) + func (u *Uint64ByteSliceConverterMock) IsInterfaceNil() bool + func (u *Uint64ByteSliceConverterMock) ToByteSlice(p uint64) []byte + func (u *Uint64ByteSliceConverterMock) ToUint64(p []byte) (uint64, error) + type Uint64SyncMapCacherStub struct + ClearCalled func() + GetCalled func(nonce uint64) (dataRetriever.ShardIdHashMap, bool) + HasCalled func(nonce uint64, shardId uint32) bool + MergeCalled func(nonce uint64, src dataRetriever.ShardIdHashMap) + RegisterHandlerCalled func(handler func(nonce uint64, shardId uint32, value []byte)) + RemoveCalled func(nonce uint64, shardId uint32) + func (usmcs *Uint64SyncMapCacherStub) Clear() + func (usmcs *Uint64SyncMapCacherStub) Get(nonce uint64) (dataRetriever.ShardIdHashMap, bool) + func (usmcs *Uint64SyncMapCacherStub) Has(nonce uint64, shardId uint32) bool + func (usmcs *Uint64SyncMapCacherStub) IsInterfaceNil() bool + func (usmcs *Uint64SyncMapCacherStub) Merge(nonce uint64, src dataRetriever.ShardIdHashMap) + func (usmcs *Uint64SyncMapCacherStub) RegisterHandler(handler func(nonce uint64, shardId uint32, value []byte)) + func (usmcs *Uint64SyncMapCacherStub) Remove(nonce uint64, shardId uint32) + type UnitOpenerStub struct + func (u *UnitOpenerStub) GetMostRecentStorageUnit(_ config.DBConfig) (storage.Storer, error) + func (u *UnitOpenerStub) IsInterfaceNil() bool + func (u *UnitOpenerStub) OpenDB(_ config.DBConfig, _ uint32, _ uint32) (storage.Storer, error) + type VMExecutionHandlerStub struct + GasScheduleChangeCalled func(gasSchedule map[string]map[string]uint64) + GetVersionCalled func() string + RunSmartContractCallCalled func(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error) + RunSmartContractCreateCalled func(input *vmcommon.ContractCreateInput) (*vmcommon.VMOutput, error) + func (vm *VMExecutionHandlerStub) Close() error + func (vm *VMExecutionHandlerStub) GasScheduleChange(gasSchedule map[string]map[string]uint64) + func (vm *VMExecutionHandlerStub) GetVersion() string + func (vm *VMExecutionHandlerStub) IsInterfaceNil() bool + func (vm *VMExecutionHandlerStub) RunSmartContractCall(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error) + func (vm *VMExecutionHandlerStub) RunSmartContractCreate(input *vmcommon.ContractCreateInput) (*vmcommon.VMOutput, error) + type ValidatorInfoSyncerStub struct + func (vip *ValidatorInfoSyncerStub) IsInterfaceNil() bool + func (vip *ValidatorInfoSyncerStub) SyncMiniBlocks(_ data.HeaderHandler) ([][]byte, data.BodyHandler, error) + type ValidatorStatisticsProcessorStub struct + CommitCalled func() ([]byte, error) + IsInterfaceNilCalled func() bool + ProcessCalled func(validatorInfo data.ShardValidatorInfoHandler) error + func (pm *ValidatorStatisticsProcessorStub) Commit() ([]byte, error) + func (pm *ValidatorStatisticsProcessorStub) IsInterfaceNil() bool + func (pm *ValidatorStatisticsProcessorStub) Process(validatorInfo data.ShardValidatorInfoHandler) error