Documentation ¶
Index ¶
- Constants
- Variables
- func AddTimestampSuffix(tag string) string
- func CreateGinContextWithRawQuery(rawQuery string) *gin.Context
- func CreateMemUnit() storage.Storer
- func GetEconomicsConfig() config.EconomicsConfig
- func GetGeneralConfig() config.Config
- func NewNonceHashConverterMock() *nonceHashConverterMock
- func NewTimeoutHandlerMock(timeout time.Duration) *timeoutHandlerMock
- type AlarmSchedulerStub
- type AlteredAccountsProviderStub
- type BalanceComputationStub
- func (bcs *BalanceComputationStub) AddBalanceToAddress(address []byte, value *big.Int) bool
- func (bcs *BalanceComputationStub) AddressHasEnoughBalance(address []byte, value *big.Int) bool
- func (bcs *BalanceComputationStub) Init()
- func (bcs *BalanceComputationStub) IsAddressSet(address []byte) bool
- func (bcs *BalanceComputationStub) IsInterfaceNil() bool
- func (bcs *BalanceComputationStub) SetBalanceToAddress(address []byte, value *big.Int)
- func (bcs *BalanceComputationStub) SubBalanceFromAddress(address []byte, value *big.Int) bool
- type BlockChainHookCounterStub
- func (stub *BlockChainHookCounterStub) GetCounterValues() map[string]uint64
- func (stub *BlockChainHookCounterStub) IsInterfaceNil() bool
- func (stub *BlockChainHookCounterStub) ProcessCrtNumberOfTrieReadsCounter() error
- func (stub *BlockChainHookCounterStub) ProcessMaxBuiltInCounters(input *vmcommon.ContractCallInput) error
- func (stub *BlockChainHookCounterStub) ResetCounters()
- func (stub *BlockChainHookCounterStub) SetMaximumValues(mapsOfValues map[string]uint64)
- type BlockChainHookStub
- func (stub *BlockChainHookStub) ApplyFiltersOnSCCodeMetadata(codeMetadata vmcommon.CodeMetadata) vmcommon.CodeMetadata
- func (stub *BlockChainHookStub) ClearCompiledCodes()
- func (stub *BlockChainHookStub) Close() error
- func (stub *BlockChainHookStub) CurrentEpoch() uint32
- func (stub *BlockChainHookStub) CurrentNonce() uint64
- func (stub *BlockChainHookStub) CurrentRandomSeed() []byte
- func (stub *BlockChainHookStub) CurrentRound() uint64
- func (stub *BlockChainHookStub) CurrentTimeStamp() uint64
- func (stub *BlockChainHookStub) DeleteCompiledCode(codeHash []byte)
- func (stub *BlockChainHookStub) FilterCodeMetadataForUpgrade(input []byte) ([]byte, error)
- func (stub *BlockChainHookStub) GetAllState(address []byte) (map[string][]byte, error)
- func (stub *BlockChainHookStub) GetBlockhash(nonce uint64) ([]byte, error)
- func (stub *BlockChainHookStub) GetBuiltinFunctionNames() vmcommon.FunctionNames
- func (stub *BlockChainHookStub) GetBuiltinFunctionsContainer() vmcommon.BuiltInFunctionContainer
- func (stub *BlockChainHookStub) GetCode(account vmcommon.UserAccountHandler) []byte
- func (stub *BlockChainHookStub) GetCompiledCode(codeHash []byte) (bool, []byte)
- func (stub *BlockChainHookStub) GetCounterValues() map[string]uint64
- func (stub *BlockChainHookStub) GetESDTToken(address []byte, tokenID []byte, nonce uint64) (*esdt.ESDigitalToken, error)
- func (stub *BlockChainHookStub) GetShardOfAddress(address []byte) uint32
- func (stub *BlockChainHookStub) GetSnapshot() int
- func (stub *BlockChainHookStub) GetStateRootHash() []byte
- func (stub *BlockChainHookStub) GetStorageData(accountAddress []byte, index []byte) ([]byte, uint32, error)
- func (stub *BlockChainHookStub) GetUserAccount(address []byte) (vmcommon.UserAccountHandler, error)
- func (stub *BlockChainHookStub) IsInterfaceNil() bool
- func (stub *BlockChainHookStub) IsLimitedTransfer(_ []byte) bool
- func (stub *BlockChainHookStub) IsPaused(_ []byte) bool
- func (stub *BlockChainHookStub) IsPayable(sndAddress []byte, recvAddress []byte) (bool, error)
- func (stub *BlockChainHookStub) IsSmartContract(address []byte) bool
- func (stub *BlockChainHookStub) LastEpoch() uint32
- func (stub *BlockChainHookStub) LastNonce() uint64
- func (stub *BlockChainHookStub) LastRandomSeed() []byte
- func (stub *BlockChainHookStub) LastRound() uint64
- func (stub *BlockChainHookStub) LastTimeStamp() uint64
- func (stub *BlockChainHookStub) NewAddress(creatorAddress []byte, creatorNonce uint64, vmType []byte) ([]byte, error)
- func (stub *BlockChainHookStub) NumberOfShards() uint32
- func (stub *BlockChainHookStub) ProcessBuiltInFunction(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error)
- func (stub *BlockChainHookStub) ResetCounters()
- func (stub *BlockChainHookStub) RevertToSnapshot(snapshot int) error
- func (stub *BlockChainHookStub) SaveCompiledCode(codeHash []byte, code []byte)
- func (stub *BlockChainHookStub) SaveNFTMetaDataToSystemAccount(tx data.TransactionHandler) error
- func (stub *BlockChainHookStub) SetCurrentHeader(hdr data.HeaderHandler)
- type BlockInfoProviderStub
- type BlockProcessorStub
- func (bps *BlockProcessorStub) Close() error
- func (bps *BlockProcessorStub) CommitBlock(header data.HeaderHandler, body data.BodyHandler) error
- func (bps *BlockProcessorStub) CreateBlock(initialHdrData data.HeaderHandler, haveTime func() bool) (data.HeaderHandler, data.BodyHandler, error)
- func (bps *BlockProcessorStub) CreateNewHeader(round uint64, nonce uint64) (data.HeaderHandler, error)
- func (bps *BlockProcessorStub) DecodeBlockBody(dta []byte) data.BodyHandler
- func (bps *BlockProcessorStub) DecodeBlockHeader(dta []byte) data.HeaderHandler
- func (bps *BlockProcessorStub) IsInterfaceNil() bool
- func (bps *BlockProcessorStub) MarshalizedDataToBroadcast(header data.HeaderHandler, body data.BodyHandler) (map[uint32][]byte, map[string][][]byte, error)
- func (bps *BlockProcessorStub) NonceOfFirstCommittedBlock() core.OptionalUint64
- func (bps *BlockProcessorStub) ProcessBlock(header data.HeaderHandler, body data.BodyHandler, ...) error
- func (bps *BlockProcessorStub) ProcessScheduledBlock(header data.HeaderHandler, body data.BodyHandler, ...) error
- func (bps *BlockProcessorStub) PruneStateOnRollback(currHeader data.HeaderHandler, currHeaderHash []byte, ...)
- func (bps *BlockProcessorStub) RestoreBlockBodyIntoPools(body data.BodyHandler) error
- func (bps *BlockProcessorStub) RestoreBlockIntoPools(header data.HeaderHandler, body data.BodyHandler) error
- func (bps *BlockProcessorStub) RevertCurrentBlock()
- func (bps *BlockProcessorStub) RevertStateToBlock(header data.HeaderHandler, rootHash []byte) error
- func (bps *BlockProcessorStub) SetNumProcessedObj(numObj uint64)
- type BlockSizeComputationStub
- func (bscs *BlockSizeComputationStub) AddNumMiniBlocks(numMiniBlocks int)
- func (bscs *BlockSizeComputationStub) AddNumTxs(numTxs int)
- func (bscs *BlockSizeComputationStub) Init()
- func (bscs *BlockSizeComputationStub) IsInterfaceNil() bool
- func (bscs *BlockSizeComputationStub) IsMaxBlockSizeReached(numNewMiniBlocks int, numNewTxs int) bool
- func (bscs *BlockSizeComputationStub) IsMaxBlockSizeWithoutThrottleReached(numNewMiniBlocks int, numNewTxs int) bool
- type BuiltInCostHandlerStub
- type CacherMock
- func (cacher *CacherMock) Clear()
- func (cacher *CacherMock) Close() error
- func (cacher *CacherMock) Get(key []byte) (value interface{}, ok bool)
- func (cacher *CacherMock) Has(key []byte) bool
- func (cacher *CacherMock) HasOrAdd(key []byte, value interface{}, _ int) (has, added bool)
- func (cacher *CacherMock) IsInterfaceNil() bool
- func (cacher *CacherMock) Keys() [][]byte
- func (cacher *CacherMock) Len() int
- func (cacher *CacherMock) MaxSize() int
- func (cacher *CacherMock) Peek(key []byte) (value interface{}, ok bool)
- func (cacher *CacherMock) Put(key []byte, value interface{}, _ int) (evicted bool)
- func (cacher *CacherMock) RegisterHandler(handler func(key []byte, value interface{}), _ string)
- func (cacher *CacherMock) Remove(key []byte)
- func (cacher *CacherMock) SizeInBytesContained() uint64
- func (cacher *CacherMock) UnRegisterHandler(string)
- type CacherStub
- func (cacher *CacherStub) Clear()
- func (cacher *CacherStub) Close() error
- func (cacher *CacherStub) Get(key []byte) (value interface{}, ok bool)
- func (cacher *CacherStub) Has(key []byte) bool
- func (cacher *CacherStub) HasOrAdd(key []byte, value interface{}, sizeInBytes int) (has, added bool)
- func (cacher *CacherStub) IsInterfaceNil() bool
- func (cacher *CacherStub) Keys() [][]byte
- func (cacher *CacherStub) Len() int
- func (cacher *CacherStub) MaxSize() int
- func (cacher *CacherStub) Peek(key []byte) (value interface{}, ok bool)
- func (cacher *CacherStub) Put(key []byte, value interface{}, sizeInBytes int) (evicted bool)
- func (cacher *CacherStub) RegisterHandler(handler func(key []byte, value interface{}), _ string)
- func (cacher *CacherStub) Remove(key []byte)
- func (cacher *CacherStub) SizeInBytesContained() uint64
- func (cacher *CacherStub) UnRegisterHandler(id string)
- type ChainHandlerMock
- func (mock *ChainHandlerMock) GetCurrentBlockHeader() data.HeaderHandler
- func (mock *ChainHandlerMock) GetCurrentBlockHeaderHash() []byte
- func (mock *ChainHandlerMock) GetCurrentBlockRootHash() []byte
- func (mock *ChainHandlerMock) GetFinalBlockInfo() (nonce uint64, blockHash []byte, rootHash []byte)
- func (mock *ChainHandlerMock) GetGenesisHeader() data.HeaderHandler
- func (mock *ChainHandlerMock) GetGenesisHeaderHash() []byte
- func (mock *ChainHandlerMock) IsInterfaceNil() bool
- func (mock *ChainHandlerMock) SetCurrentBlockHeaderAndRootHash(header data.HeaderHandler, rootHash []byte) error
- func (mock *ChainHandlerMock) SetCurrentBlockHeaderHash(hash []byte)
- func (mock *ChainHandlerMock) SetFinalBlockInfo(nonce uint64, headerHash []byte, rootHash []byte)
- func (mock *ChainHandlerMock) SetGenesisHeader(genesisBlock data.HeaderHandler) error
- func (mock *ChainHandlerMock) SetGenesisHeaderHash(hash []byte)
- type ChainHandlerStub
- func (stub *ChainHandlerStub) GetCurrentBlockHeader() data.HeaderHandler
- func (stub *ChainHandlerStub) GetCurrentBlockHeaderHash() []byte
- func (stub *ChainHandlerStub) GetCurrentBlockRootHash() []byte
- func (stub *ChainHandlerStub) GetFinalBlockInfo() (nonce uint64, blockHash []byte, rootHash []byte)
- func (stub *ChainHandlerStub) GetGenesisHeader() data.HeaderHandler
- func (stub *ChainHandlerStub) GetGenesisHeaderHash() []byte
- func (stub *ChainHandlerStub) IsInterfaceNil() bool
- func (stub *ChainHandlerStub) SetCurrentBlockHeaderAndRootHash(header data.HeaderHandler, rootHash []byte) error
- func (stub *ChainHandlerStub) SetCurrentBlockHeaderHash(hash []byte)
- func (stub *ChainHandlerStub) SetFinalBlockInfo(nonce uint64, headerHash []byte, rootHash []byte)
- func (stub *ChainHandlerStub) SetGenesisHeader(genesisBlock data.HeaderHandler) error
- func (stub *ChainHandlerStub) SetGenesisHeaderHash(hash []byte)
- type CurrentEpochProviderStub
- type CustomDatabaseRemoverStub
- type DataFieldParserStub
- type ESDTGlobalSettingsHandlerStub
- type ESDTTransferParserStub
- type EnableEpochsHandlerStub
- func (stub *EnableEpochsHandlerStub) BalanceWaitingListsEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) BlockGasAndFeesReCheckEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) CheckExecuteReadOnlyEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) CreateNFTThroughExecByCallerEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) DisableExecByCallerEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) FixFailExecutionOnErrorEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) FixOOGReturnCodeEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) IsAddFailedRelayedTxToInvalidMBsFlag() bool
- func (stub *EnableEpochsHandlerStub) IsAddTokensToDelegationFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsAheadOfTimeGasUsageFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsAlwaysSaveTokenMetaDataEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsBackwardCompSaveKeyValueFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsBalanceWaitingListsFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsBelowSignedThresholdFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsBuiltInFunctionOnMetaFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsBuiltInFunctionsFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsChangeDelegationOwnerFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsCheckCorrectTokenIDForTransferRoleFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsCheckExecuteOnReadOnlyFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsCheckFrozenCollectionFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsCheckFunctionArgumentFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsCheckTransferFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsCleanUpInformativeSCRsFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsComputeRewardCheckpointFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsCorrectFirstQueuedFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsCorrectJailedNotUnStakedEmptyQueueFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsCorrectLastUnJailedFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsCorrectLastUnJailedFlagEnabledForCurrentEpoch() bool
- func (stub *EnableEpochsHandlerStub) IsCreateNFTThroughExecByCallerFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsDelegationManagerFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsDelegationSmartContractFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsDelegationSmartContractFlagEnabledForCurrentEpoch() bool
- func (stub *EnableEpochsHandlerStub) IsDeleteDelegatorAfterClaimRewardsFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsDisableExecByCallerFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsDoNotReturnOldBlockInBlockchainHookFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsDoubleKeyProtectionFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsESDTFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsESDTFlagEnabledForCurrentEpoch() bool
- func (stub *EnableEpochsHandlerStub) IsESDTMetadataContinuousCleanupFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsESDTMultiTransferFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsESDTNFTCreateOnMultiShardFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsESDTNFTImprovementV1FlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsESDTRegisterAndSetAllRolesFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsESDTTransferRoleFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsFailExecutionOnEveryAPIErrorFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsFixAsyncCallBackArgsListFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsFixAsyncCallbackCheckFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsFixOOGReturnCodeFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsFixOldTokenLiquidityEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsFrontRunningProtectionFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsGasPriceModifierFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsGlobalMintBurnFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsGovernanceFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsGovernanceFlagEnabledForCurrentEpoch() bool
- func (stub *EnableEpochsHandlerStub) IsIncrementSCRNonceInMultiTransferFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsInterfaceNil() bool
- func (stub *EnableEpochsHandlerStub) IsManagedCryptoAPIsFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsMaxBlockchainHookCountersFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsMetaESDTSetFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsMetaProtectionFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsMiniBlockPartialExecutionFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsMultiESDTTransferFixOnCallBackFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsOptimizeGasUsedInCrossMiniBlocksFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsOptimizeNFTStoreFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsPayableBySCFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsPenalizedTooMuchGasFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsReDelegateBelowMinCheckFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsRefactorContextFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsRefactorPeersMiniBlocksFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsRelayedNonceFixEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsRelayedTransactionsFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsRelayedTransactionsV2FlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsRemoveNonUpdatedStorageFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsRepairCallbackFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsReturnDataToLastTransferFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsRuntimeCodeSizeFixEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsRuntimeMemStoreLimitEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsSCDeployFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsSCRSizeInvariantCheckFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsSCRSizeInvariantOnBuiltInResultFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsSaveJailedAlwaysFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsSaveToSystemAccountFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsScheduledMiniBlocksFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsSendAlwaysFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsSenderInOutTransferFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsSetGuardianEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsSetSenderInEeiOutputTransferFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsStakeFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsStakingV2FlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsStakingV2FlagEnabledForActivationEpochCompleted() bool
- func (stub *EnableEpochsHandlerStub) IsStakingV2OwnerFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsStopDecreasingValidatorRatingWhenStuckFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsStorageAPICostOptimizationFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsSwitchHysteresisForMinNodesFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsSwitchHysteresisForMinNodesFlagEnabledForCurrentEpoch() bool
- func (stub *EnableEpochsHandlerStub) IsSwitchJailWaitingFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsTransactionSignedWithTxHashFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsTransferToMetaFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsUnBondTokensV2FlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsValidatorToDelegationFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsValueLengthCheckFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsWaitingListFixFlagEnabled() bool
- func (stub *EnableEpochsHandlerStub) IsWipeSingleNFTLiquidityDecreaseEnabled() bool
- func (stub *EnableEpochsHandlerStub) ManagedCryptoAPIEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) MiniBlockPartialExecutionEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) MultiESDTTransferAsyncCallBackEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) RefactorContextEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) RefactorPeersMiniBlocksEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) RemoveNonUpdatedStorageEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) ResetPenalizedTooMuchGasFlag()
- func (stub *EnableEpochsHandlerStub) ScheduledMiniBlocksEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) StakingV2EnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) StorageAPICostOptimizationEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) SwitchJailWaitingEnableEpoch() uint32
- func (stub *EnableEpochsHandlerStub) WaitingListFixEnableEpoch() uint32
- type EnableRoundsHandlerStub
- 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) 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) 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) SetFinalityAttestingRound(_ uint64)
- func (e *EpochStartTriggerStub) SetProcessed(header data.HeaderHandler, _ data.BodyHandler)
- func (e *EpochStartTriggerStub) Update(round uint64, nonce uint64)
- type EsdtStorageHandlerStub
- func (e *EsdtStorageHandlerStub) AddToLiquiditySystemAcc(esdtTokenKey []byte, nonce uint64, transferValue *big.Int) error
- func (e *EsdtStorageHandlerStub) GetESDTNFTTokenOnDestination(acnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64) (*esdt.ESDigitalToken, bool, error)
- func (e *EsdtStorageHandlerStub) GetESDTNFTTokenOnDestinationWithCustomSystemAccount(accnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64, ...) (*esdt.ESDigitalToken, bool, error)
- func (e *EsdtStorageHandlerStub) GetESDTNFTTokenOnSender(acnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64) (*esdt.ESDigitalToken, error)
- func (e *EsdtStorageHandlerStub) IsInterfaceNil() bool
- func (e *EsdtStorageHandlerStub) SaveESDTNFTToken(senderAddress []byte, acnt vmcommon.UserAccountHandler, esdtTokenKey []byte, ...) ([]byte, error)
- func (e *EsdtStorageHandlerStub) SaveNFTMetaDataToSystemAccount(tx data.TransactionHandler) error
- func (e *EsdtStorageHandlerStub) WasAlreadySentToDestinationShardAndUpdateState(tickerID []byte, nonce uint64, dstAddress []byte) (bool, error)
- type FallBackHeaderValidatorStub
- type FeeComputerStub
- func (stub *FeeComputerStub) ComputeGasLimit(tx *transaction.ApiTransactionResult) uint64
- func (stub *FeeComputerStub) ComputeGasUsedAndFeeBasedOnRefundValue(tx *transaction.ApiTransactionResult, refundValue *big.Int) (uint64, *big.Int)
- func (stub *FeeComputerStub) ComputeTransactionFee(tx *transaction.ApiTransactionResult) *big.Int
- func (stub *FeeComputerStub) ComputeTxFeeBasedOnGasUsed(tx *transaction.ApiTransactionResult, gasUsed uint64) *big.Int
- func (stub *FeeComputerStub) IsInterfaceNil() bool
- type GasHandlerStub
- func (ghs *GasHandlerStub) ComputeGasProvidedByMiniBlock(miniBlock *block.MiniBlock, mapHashTx map[string]data.TransactionHandler) (uint64, uint64, error)
- func (ghs *GasHandlerStub) ComputeGasProvidedByTx(txSenderShardId uint32, txReceiverShardId uint32, ...) (uint64, uint64, error)
- func (ghs *GasHandlerStub) GasPenalized(hash []byte) uint64
- func (ghs *GasHandlerStub) GasProvided(hash []byte) uint64
- func (ghs *GasHandlerStub) GasProvidedAsScheduled(hash []byte) uint64
- func (ghs *GasHandlerStub) GasRefunded(hash []byte) uint64
- func (ghs *GasHandlerStub) Init()
- func (ghs *GasHandlerStub) IsInterfaceNil() bool
- func (ghs *GasHandlerStub) RemoveGasPenalized(hashes [][]byte)
- func (ghs *GasHandlerStub) RemoveGasProvided(hashes [][]byte)
- func (ghs *GasHandlerStub) RemoveGasProvidedAsScheduled(hashes [][]byte)
- func (ghs *GasHandlerStub) RemoveGasRefunded(hashes [][]byte)
- func (ghs *GasHandlerStub) Reset(key []byte)
- func (ghs *GasHandlerStub) RestoreGasSinceLastReset(key []byte)
- func (ghs *GasHandlerStub) SetGasPenalized(gasPenalized uint64, hash []byte)
- func (ghs *GasHandlerStub) SetGasProvided(gasProvided uint64, hash []byte)
- func (ghs *GasHandlerStub) SetGasProvidedAsScheduled(gasProvided uint64, hash []byte)
- func (ghs *GasHandlerStub) SetGasRefunded(gasRefunded uint64, hash []byte)
- func (ghs *GasHandlerStub) TotalGasPenalized() uint64
- func (ghs *GasHandlerStub) TotalGasProvided() uint64
- func (ghs *GasHandlerStub) TotalGasProvidedAsScheduled() uint64
- func (ghs *GasHandlerStub) TotalGasProvidedWithScheduled() uint64
- func (ghs *GasHandlerStub) TotalGasRefunded() uint64
- type GasScheduleNotifierMock
- func (g *GasScheduleNotifierMock) IsInterfaceNil() bool
- func (g *GasScheduleNotifierMock) LatestGasSchedule() map[string]map[string]uint64
- func (g *GasScheduleNotifierMock) LatestGasScheduleCopy() 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) NotifyTriggerReceivedV2() <-chan struct{}
- func (hts *HardforkTriggerStub) RecordedTriggerMessage() ([]byte, bool)
- func (hts *HardforkTriggerStub) SetExportFactoryHandler(exportFactoryHandler update.ExportFactoryHandler) error
- func (hts *HardforkTriggerStub) Trigger(epoch uint32, withEarlyEndOfEpoch bool) error
- func (hts *HardforkTriggerStub) TriggerReceived(payload []byte, data []byte, pkBytes []byte) (bool, error)
- type HasherStub
- type HeaderHandlerStub
- func (hhs *HeaderHandlerStub) CheckFieldsForNil() error
- func (hhs *HeaderHandlerStub) GetAccumulatedFees() *big.Int
- func (hhs *HeaderHandlerStub) GetAdditionalData() headerVersionData.HeaderAdditionalData
- func (hhs *HeaderHandlerStub) GetBlockBodyTypeInt32() int32
- func (hhs *HeaderHandlerStub) GetChainID() []byte
- func (hhs *HeaderHandlerStub) GetDevFeesInEpoch() *big.Int
- func (hhs *HeaderHandlerStub) GetDeveloperFees() *big.Int
- func (hhs *HeaderHandlerStub) GetEpoch() uint32
- func (hhs *HeaderHandlerStub) GetEpochStartHandler() data.EpochStartHandler
- func (hhs *HeaderHandlerStub) GetEpochStartMetaHash() []byte
- func (hhs *HeaderHandlerStub) GetLeaderSignature() []byte
- func (hhs *HeaderHandlerStub) GetMetaBlockHashes() [][]byte
- func (hhs *HeaderHandlerStub) GetMiniBlockHeaderHandlers() []data.MiniBlockHeaderHandler
- func (hhs *HeaderHandlerStub) GetMiniBlockHeadersHashes() [][]byte
- func (hhs *HeaderHandlerStub) GetMiniBlockHeadersWithDst(destId uint32) map[string]uint32
- func (hhs *HeaderHandlerStub) GetNonce() uint64
- func (hhs *HeaderHandlerStub) GetOrderedCrossMiniblocksWithDst(destId uint32) []*data.MiniBlockInfo
- func (hhs *HeaderHandlerStub) GetPrevHash() []byte
- func (hhs *HeaderHandlerStub) GetPrevRandSeed() []byte
- func (hhs *HeaderHandlerStub) GetPubKeysBitmap() []byte
- func (hhs *HeaderHandlerStub) GetRandSeed() []byte
- func (hhs *HeaderHandlerStub) GetReceiptsHash() []byte
- func (hhs *HeaderHandlerStub) GetReserved() []byte
- func (hhs *HeaderHandlerStub) GetRootHash() []byte
- func (hhs *HeaderHandlerStub) GetRound() uint64
- func (hhs *HeaderHandlerStub) GetShardID() uint32
- func (hhs *HeaderHandlerStub) GetShardInfoHandlers() []data.ShardDataHandler
- func (hhs *HeaderHandlerStub) GetSignature() []byte
- func (hhs *HeaderHandlerStub) GetSoftwareVersion() []byte
- func (hhs *HeaderHandlerStub) GetTimeStamp() uint64
- func (hhs *HeaderHandlerStub) GetTxCount() uint32
- func (hhs *HeaderHandlerStub) GetValidatorStatsRootHash() []byte
- func (hhs *HeaderHandlerStub) HasScheduledMiniBlocks() bool
- func (hhs *HeaderHandlerStub) HasScheduledSupport() bool
- func (hhs *HeaderHandlerStub) IsInterfaceNil() bool
- func (hhs *HeaderHandlerStub) IsStartOfEpochBlock() bool
- func (hhs *HeaderHandlerStub) MapMiniBlockHashesToShards() map[string]uint32
- func (hhs *HeaderHandlerStub) SetAccumulatedFees(_ *big.Int) error
- func (hhs *HeaderHandlerStub) SetAccumulatedFeesInEpoch(_ *big.Int) error
- func (hhs *HeaderHandlerStub) SetAdditionalData(_ headerVersionData.HeaderAdditionalData) error
- func (hhs *HeaderHandlerStub) SetChainID(_ []byte) error
- func (hhs *HeaderHandlerStub) SetDevFeesInEpoch(_ *big.Int) error
- func (hhs *HeaderHandlerStub) SetDeveloperFees(_ *big.Int) error
- func (hhs *HeaderHandlerStub) SetEpoch(_ uint32) error
- func (hhs *HeaderHandlerStub) SetEpochStartMetaHash(_ []byte) error
- func (hhs *HeaderHandlerStub) SetLeaderSignature(_ []byte) error
- func (hhs *HeaderHandlerStub) SetMetaBlockHashes(_ [][]byte) error
- func (hhs *HeaderHandlerStub) SetMiniBlockHeaderHandlers(_ []data.MiniBlockHeaderHandler) error
- func (hhs *HeaderHandlerStub) SetNonce(_ uint64) error
- func (hhs *HeaderHandlerStub) SetPrevHash(_ []byte) error
- func (hhs *HeaderHandlerStub) SetPrevRandSeed(_ []byte) error
- func (hhs *HeaderHandlerStub) SetPubKeysBitmap(_ []byte) error
- func (hhs *HeaderHandlerStub) SetRandSeed(_ []byte) error
- func (hhs *HeaderHandlerStub) SetReceiptsHash(_ []byte) error
- func (hhs *HeaderHandlerStub) SetRootHash(_ []byte) error
- func (hhs *HeaderHandlerStub) SetRound(_ uint64) error
- func (hhs *HeaderHandlerStub) SetScheduledRootHash(_ []byte) error
- func (hhs *HeaderHandlerStub) SetShardID(_ uint32) error
- func (hhs *HeaderHandlerStub) SetShardInfoHandlers(_ []data.ShardDataHandler) error
- func (hhs *HeaderHandlerStub) SetSignature(_ []byte) error
- func (hhs *HeaderHandlerStub) SetSoftwareVersion(_ []byte) error
- func (hhs *HeaderHandlerStub) SetTimeStamp(_ uint64) error
- func (hhs *HeaderHandlerStub) SetTxCount(_ uint32) error
- func (hhs *HeaderHandlerStub) SetValidatorStatsRootHash(_ []byte) error
- func (hhs *HeaderHandlerStub) ShallowClone() data.HeaderHandler
- func (hhs *HeaderHandlerStub) ValidateHeaderVersion() error
- type HeaderVersionHandlerStub
- 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 InterceptedDataStub
- func (ids *InterceptedDataStub) CheckValidity() error
- func (ids *InterceptedDataStub) Hash() []byte
- func (ids *InterceptedDataStub) Identifiers() [][]byte
- func (ids *InterceptedDataStub) IsForCurrentShard() bool
- func (ids *InterceptedDataStub) IsInterfaceNil() bool
- func (ids *InterceptedDataStub) String() string
- func (ids *InterceptedDataStub) Type() string
- type InterceptorStub
- func (is *InterceptorStub) Close() error
- func (is *InterceptorStub) IsInterfaceNil() bool
- func (is *InterceptorStub) ProcessReceivedMessage(message p2p.MessageP2P, _ core.PeerID) error
- func (is *InterceptorStub) RegisterHandler(handler func(topic string, hash []byte, data interface{}))
- func (is *InterceptorStub) SetInterceptedDebugHandler(debugger process.InterceptedDebugger) error
- type InterceptorsContainerStub
- func (ics *InterceptorsContainerStub) Add(key string, interceptor process.Interceptor) error
- func (ics *InterceptorsContainerStub) AddMultiple(keys []string, interceptors []process.Interceptor) error
- func (ics *InterceptorsContainerStub) Close() error
- func (ics *InterceptorsContainerStub) Get(topic string) (process.Interceptor, error)
- func (ics *InterceptorsContainerStub) IsInterfaceNil() bool
- func (ics *InterceptorsContainerStub) Iterate(handler func(key string, interceptor process.Interceptor) bool)
- func (ics *InterceptorsContainerStub) Len() int
- func (ics *InterceptorsContainerStub) Remove(key string)
- func (ics *InterceptorsContainerStub) Replace(key string, interceptor process.Interceptor) error
- type KeccakMock
- type LoggerStub
- func (stub *LoggerStub) Debug(message string, args ...interface{})
- func (stub *LoggerStub) Error(message string, args ...interface{})
- func (stub *LoggerStub) GetLevel() logger.LogLevel
- func (stub *LoggerStub) Info(message string, args ...interface{})
- func (stub *LoggerStub) IsInterfaceNil() bool
- func (stub *LoggerStub) Log(logLevel logger.LogLevel, message string, args ...interface{})
- func (stub *LoggerStub) LogIfError(err error, args ...interface{})
- func (stub *LoggerStub) LogLine(line *logger.LogLine)
- func (stub *LoggerStub) SetLevel(logLevel logger.LogLevel)
- func (stub *LoggerStub) Trace(message string, args ...interface{})
- func (stub *LoggerStub) Warn(message string, args ...interface{})
- type LogsFacadeStub
- type MarshalizerMock
- type MarshalizerStub
- type MemDbMock
- func (s *MemDbMock) Close() error
- func (s *MemDbMock) Destroy() error
- func (s *MemDbMock) DestroyClosed() error
- func (s *MemDbMock) Get(key []byte) ([]byte, error)
- func (s *MemDbMock) Has(key []byte) error
- func (s *MemDbMock) IsInterfaceNil() bool
- func (s *MemDbMock) Put(key, val []byte) error
- func (s *MemDbMock) RangeKeys(handler func(key []byte, value []byte) bool)
- func (s *MemDbMock) Remove(key []byte) error
- type MessageSignVerifierMock
- type NodesSetupStub
- 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 OldDataCleanerProviderStub
- type PanicDoubleTransactionsDetector
- type PathManagerStub
- type PeerAuthenticationPayloadValidatorStub
- type PeerHonestyHandlerStub
- type PreProcessorExecutionInfoHandlerMock
- type ProcessDebuggerStub
- type ProcessStatusHandlerStub
- type ProcessedMiniBlocksTrackerStub
- func (pmbts *ProcessedMiniBlocksTrackerStub) ConvertProcessedMiniBlocksMapToSlice() []bootstrapStorage.MiniBlocksInMeta
- func (pmbts *ProcessedMiniBlocksTrackerStub) ConvertSliceToProcessedMiniBlocksMap(miniBlocksInMetaBlocks []bootstrapStorage.MiniBlocksInMeta)
- func (pmbts *ProcessedMiniBlocksTrackerStub) DisplayProcessedMiniBlocks()
- func (pmbts *ProcessedMiniBlocksTrackerStub) GetProcessedMiniBlockInfo(miniBlockHash []byte) (*processedMb.ProcessedMiniBlockInfo, []byte)
- func (pmbts *ProcessedMiniBlocksTrackerStub) GetProcessedMiniBlocksInfo(metaBlockHash []byte) map[string]*processedMb.ProcessedMiniBlockInfo
- func (pmbts *ProcessedMiniBlocksTrackerStub) IsInterfaceNil() bool
- func (pmbts *ProcessedMiniBlocksTrackerStub) IsMiniBlockFullyProcessed(metaBlockHash []byte, miniBlockHash []byte) bool
- func (pmbts *ProcessedMiniBlocksTrackerStub) RemoveMetaBlockHash(metaBlockHash []byte)
- func (pmbts *ProcessedMiniBlocksTrackerStub) RemoveMiniBlockHash(miniBlockHash []byte)
- func (pmbts *ProcessedMiniBlocksTrackerStub) SetProcessedMiniBlockInfo(metaBlockHash []byte, miniBlockHash []byte, ...)
- type ProtoMarshalizerMock
- type ProtobufMarshalizerMock
- type PubkeyConverterMock
- 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 RatingsInfoMock
- func (rd *RatingsInfoMock) IsInterfaceNil() bool
- func (rd *RatingsInfoMock) MaxRating() uint32
- func (rd *RatingsInfoMock) MetaChainRatingsStepHandler() process.RatingsStepHandler
- func (rd *RatingsInfoMock) MinRating() uint32
- func (rd *RatingsInfoMock) SelectionChances() []process.SelectionChance
- func (rd *RatingsInfoMock) ShardChainRatingsStepHandler() process.RatingsStepHandler
- func (rd *RatingsInfoMock) SignedBlocksThreshold() float32
- func (rd *RatingsInfoMock) StartRating() uint32
- type ReceiptsRepositoryStub
- func (stub *ReceiptsRepositoryStub) IsInterfaceNil() bool
- func (stub *ReceiptsRepositoryStub) LoadReceipts(header data.HeaderHandler, headerHash []byte) (common.ReceiptsHolder, error)
- func (stub *ReceiptsRepositoryStub) SaveReceipts(holder common.ReceiptsHolder, header data.HeaderHandler, headerHash []byte) error
- type RequestHandlerStub
- func (rhs *RequestHandlerStub) CreateTrieNodeIdentifier(requestHash []byte, chunkIndex uint32) []byte
- func (rhs *RequestHandlerStub) GetNumPeersToQuery(key string) (int, int, error)
- func (rhs *RequestHandlerStub) IsInterfaceNil() bool
- func (rhs *RequestHandlerStub) RequestInterval() time.Duration
- func (rhs *RequestHandlerStub) RequestMetaHeader(hash []byte)
- func (rhs *RequestHandlerStub) RequestMetaHeaderByNonce(nonce uint64)
- func (rhs *RequestHandlerStub) RequestMiniBlock(destShardID uint32, miniblockHash []byte)
- func (rhs *RequestHandlerStub) RequestMiniBlocks(destShardID uint32, miniblocksHashes [][]byte)
- func (rhs *RequestHandlerStub) RequestPeerAuthenticationsByHashes(destShardID uint32, hashes [][]byte)
- func (rhs *RequestHandlerStub) RequestRewardTransactions(destShardID uint32, txHashes [][]byte)
- func (rhs *RequestHandlerStub) RequestShardHeader(shardID uint32, hash []byte)
- func (rhs *RequestHandlerStub) RequestShardHeaderByNonce(shardID uint32, nonce uint64)
- func (rhs *RequestHandlerStub) RequestStartOfEpochMetaBlock(epoch uint32)
- func (rhs *RequestHandlerStub) RequestTransaction(destShardID uint32, txHashes [][]byte)
- func (rhs *RequestHandlerStub) RequestTrieNode(requestHash []byte, topic string, chunkIndex uint32)
- func (rhs *RequestHandlerStub) RequestTrieNodes(destShardID uint32, hashes [][]byte, topic string)
- func (rhs *RequestHandlerStub) RequestUnsignedTransactions(destShardID uint32, txHashes [][]byte)
- func (rhs *RequestHandlerStub) RequestValidatorInfo(hash []byte)
- func (rhs *RequestHandlerStub) RequestValidatorsInfo(hashes [][]byte)
- func (rhs *RequestHandlerStub) SetEpoch(_ uint32)
- func (rhs *RequestHandlerStub) SetNumPeersToQuery(key string, intra int, cross int) error
- type RequestedItemsHandlerStub
- type RewardTxProcessorMock
- type RoundHandlerMock
- func (rndm *RoundHandlerMock) BeforeGenesis() bool
- func (rndm *RoundHandlerMock) Index() int64
- func (rndm *RoundHandlerMock) IsInterfaceNil() bool
- func (rndm *RoundHandlerMock) RemainingTime(startTime time.Time, maxTime time.Duration) time.Duration
- func (rndm *RoundHandlerMock) TimeDuration() time.Duration
- func (rndm *RoundHandlerMock) TimeStamp() time.Time
- func (rndm *RoundHandlerMock) UpdateRound(genesisRoundTimeStamp time.Time, timeStamp time.Time)
- type SCProcessorMock
- func (sc *SCProcessorMock) CheckBuiltinFunctionIsExecutable(expectedBuiltinFunction string, tx data.TransactionHandler) error
- func (sc *SCProcessorMock) ComputeTransactionType(tx data.TransactionHandler) (process.TransactionType, process.TransactionType)
- func (sc *SCProcessorMock) DeploySmartContract(tx data.TransactionHandler, acntSrc state.UserAccountHandler) (vmcommon.ReturnCode, error)
- func (sc *SCProcessorMock) ExecuteBuiltInFunction(tx data.TransactionHandler, acntSrc, acntDst state.UserAccountHandler) (vmcommon.ReturnCode, error)
- func (sc *SCProcessorMock) ExecuteSmartContractTransaction(tx data.TransactionHandler, acntSrc, acntDst state.UserAccountHandler) (vmcommon.ReturnCode, error)
- func (sc *SCProcessorMock) IsInterfaceNil() bool
- func (sc *SCProcessorMock) IsPayable(sndAddress []byte, recvAddress []byte) (bool, error)
- func (sc *SCProcessorMock) ProcessIfError(acntSnd state.UserAccountHandler, txHash []byte, tx data.TransactionHandler, ...) error
- func (sc *SCProcessorMock) ProcessSmartContractResult(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)
- type ScheduledTxsExecutionStub
- func (stes *ScheduledTxsExecutionStub) AddScheduledMiniBlocks(miniBlocks block.MiniBlockSlice)
- func (stes *ScheduledTxsExecutionStub) AddScheduledTx(txHash []byte, tx data.TransactionHandler) bool
- func (stes *ScheduledTxsExecutionStub) Execute(txHash []byte) error
- func (stes *ScheduledTxsExecutionStub) ExecuteAll(haveTime func() time.Duration) error
- func (stes *ScheduledTxsExecutionStub) GetScheduledGasAndFees() scheduled.GasAndFees
- func (stes *ScheduledTxsExecutionStub) GetScheduledIntermediateTxs() map[block.Type][]data.TransactionHandler
- func (stes *ScheduledTxsExecutionStub) GetScheduledMiniBlocks() block.MiniBlockSlice
- func (stes *ScheduledTxsExecutionStub) GetScheduledRootHash() []byte
- func (stes *ScheduledTxsExecutionStub) GetScheduledRootHashForHeader(headerHash []byte) ([]byte, error)
- func (stes *ScheduledTxsExecutionStub) GetScheduledRootHashForHeaderWithEpoch(headerHash []byte, epoch uint32) ([]byte, error)
- func (stes *ScheduledTxsExecutionStub) Init()
- func (stes *ScheduledTxsExecutionStub) IsInterfaceNil() bool
- func (stes *ScheduledTxsExecutionStub) IsMiniBlockExecuted(mbHash []byte) bool
- func (stes *ScheduledTxsExecutionStub) IsScheduledTx(txHash []byte) bool
- func (stes *ScheduledTxsExecutionStub) RollBackToBlock(headerHash []byte) error
- func (stes *ScheduledTxsExecutionStub) SaveState(headerHash []byte, scheduledInfo *process.ScheduledInfo)
- func (stes *ScheduledTxsExecutionStub) SaveStateIfNeeded(headerHash []byte)
- func (stes *ScheduledTxsExecutionStub) SetScheduledGasAndFees(gasAndFees scheduled.GasAndFees)
- func (stes *ScheduledTxsExecutionStub) SetScheduledInfo(scheduledInfo *process.ScheduledInfo)
- func (stes *ScheduledTxsExecutionStub) SetScheduledRootHash(rootHash []byte)
- func (stes *ScheduledTxsExecutionStub) SetTransactionCoordinator(txCoordinator process.TransactionCoordinator)
- func (stes *ScheduledTxsExecutionStub) SetTransactionProcessor(txProcessor process.TransactionProcessor)
- type ShardedDataCacheNotifierMock
- func (mock *ShardedDataCacheNotifierMock) AddData(key []byte, data interface{}, sizeInBytes int, cacheId string)
- func (mock *ShardedDataCacheNotifierMock) Clear()
- func (mock *ShardedDataCacheNotifierMock) ClearShardStore(cacheId string)
- func (mock *ShardedDataCacheNotifierMock) GetCounts() counting.CountsWithSize
- func (mock *ShardedDataCacheNotifierMock) ImmunizeSetOfDataAgainstEviction(_ [][]byte, _ string)
- func (mock *ShardedDataCacheNotifierMock) IsInterfaceNil() bool
- func (mock *ShardedDataCacheNotifierMock) Keys() [][]byte
- func (mock *ShardedDataCacheNotifierMock) MergeShardStores(_, _ string)
- func (mock *ShardedDataCacheNotifierMock) RegisterOnAdded(_ func(key []byte, value interface{}))
- func (mock *ShardedDataCacheNotifierMock) RemoveData(key []byte, cacheId string)
- func (mock *ShardedDataCacheNotifierMock) RemoveDataFromAllShards(key []byte)
- func (mock *ShardedDataCacheNotifierMock) RemoveSetOfDataFromPool(keys [][]byte, cacheId string)
- func (mock *ShardedDataCacheNotifierMock) SearchFirstData(key []byte) (interface{}, bool)
- func (mock *ShardedDataCacheNotifierMock) ShardDataStore(cacheId string) (c storage.Cacher)
- type ShardedDataStub
- func (sd *ShardedDataStub) AddData(key []byte, data interface{}, sizeInBytes int, cacheID string)
- func (sd *ShardedDataStub) Clear()
- func (sd *ShardedDataStub) ClearShardStore(cacheID string)
- func (sd *ShardedDataStub) GetCounts() counting.CountsWithSize
- func (sd *ShardedDataStub) ImmunizeSetOfDataAgainstEviction(keys [][]byte, cacheID string)
- func (sd *ShardedDataStub) IsInterfaceNil() bool
- func (sd *ShardedDataStub) Keys() [][]byte
- func (sd *ShardedDataStub) MergeShardStores(sourceCacheID, destCacheID string)
- func (sd *ShardedDataStub) RegisterOnAdded(handler func(key []byte, value interface{}))
- func (sd *ShardedDataStub) RemoveData(key []byte, cacheID string)
- func (sd *ShardedDataStub) RemoveDataFromAllShards(key []byte)
- func (sd *ShardedDataStub) RemoveSetOfDataFromPool(keys [][]byte, cacheID string)
- func (sd *ShardedDataStub) SearchFirstData(key []byte) (value interface{}, ok bool)
- func (sd *ShardedDataStub) ShardDataStore(cacheID string) storage.Cacher
- type ShardsCoordinatorMock
- func (scm *ShardsCoordinatorMock) CommunicationIdentifier(destShardID uint32) string
- func (scm *ShardsCoordinatorMock) ComputeId(address []byte) uint32
- func (scm *ShardsCoordinatorMock) IsInterfaceNil() bool
- func (scm *ShardsCoordinatorMock) NumberOfShards() uint32
- func (scm *ShardsCoordinatorMock) SameShard(_, _ []byte) bool
- func (scm *ShardsCoordinatorMock) SelfId() uint32
- func (scm *ShardsCoordinatorMock) SetNoShards(noShards uint32)
- func (scm *ShardsCoordinatorMock) SetSelfId(_ uint32) error
- type SimpleNFTStorageHandlerStub
- func (s *SimpleNFTStorageHandlerStub) GetESDTNFTTokenOnDestination(accnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64) (*esdt.ESDigitalToken, bool, error)
- func (s *SimpleNFTStorageHandlerStub) IsInterfaceNil() bool
- func (s *SimpleNFTStorageHandlerStub) SaveNFTMetaDataToSystemAccount(tx data.TransactionHandler) error
- type SizeSyncStatisticsHandlerStub
- func (stub *SizeSyncStatisticsHandlerStub) AddNumBytesReceived(bytes uint64)
- func (stub *SizeSyncStatisticsHandlerStub) AddNumLarge(value int)
- func (stub *SizeSyncStatisticsHandlerStub) AddNumProcessed(value int)
- func (stub *SizeSyncStatisticsHandlerStub) AddProcessingTime(duration time.Duration)
- func (stub *SizeSyncStatisticsHandlerStub) IncrementIteration()
- func (stub *SizeSyncStatisticsHandlerStub) IsInterfaceNil() bool
- func (stub *SizeSyncStatisticsHandlerStub) NumBytesReceived() uint64
- func (stub *SizeSyncStatisticsHandlerStub) NumIterations() int
- func (stub *SizeSyncStatisticsHandlerStub) NumLarge() int
- func (stub *SizeSyncStatisticsHandlerStub) NumMissing() int
- func (stub *SizeSyncStatisticsHandlerStub) NumProcessed() int
- func (stub *SizeSyncStatisticsHandlerStub) NumTries() int
- func (stub *SizeSyncStatisticsHandlerStub) ProcessingTime() time.Duration
- func (stub *SizeSyncStatisticsHandlerStub) Reset()
- func (stub *SizeSyncStatisticsHandlerStub) SetNumMissing(rootHash []byte, value int)
- type SmartContractResultsProcessorMock
- type SnapshotPruningStorerMock
- func (spsm *SnapshotPruningStorerMock) GetFromCurrentEpoch(key []byte) ([]byte, error)
- func (spsm *SnapshotPruningStorerMock) GetFromEpoch(key []byte, _ uint32) ([]byte, error)
- func (spsm *SnapshotPruningStorerMock) GetFromLastEpoch(key []byte) ([]byte, error)
- func (spsm *SnapshotPruningStorerMock) GetFromOldEpochsWithoutAddingToCache(key []byte) ([]byte, core.OptionalUint32, error)
- func (spsm *SnapshotPruningStorerMock) GetLatestStorageEpoch() (uint32, error)
- func (spsm *SnapshotPruningStorerMock) PutInEpoch(key []byte, data []byte, _ uint32) error
- func (spsm *SnapshotPruningStorerMock) PutInEpochWithoutCache(key []byte, data []byte, _ uint32) error
- func (spsm *SnapshotPruningStorerMock) RemoveFromCurrentEpoch(key []byte) error
- type StateComponentsMock
- func (scm *StateComponentsMock) AccountsAdapter() state.AccountsAdapter
- func (scm *StateComponentsMock) AccountsAdapterAPI() state.AccountsAdapter
- func (scm *StateComponentsMock) AccountsRepository() state.AccountsRepository
- func (scm *StateComponentsMock) CheckSubcomponents() error
- func (scm *StateComponentsMock) Close() error
- func (scm *StateComponentsMock) Create() error
- func (scm *StateComponentsMock) IsInterfaceNil() bool
- func (scm *StateComponentsMock) PeerAccounts() state.AccountsAdapter
- func (scm *StateComponentsMock) String() string
- func (scm *StateComponentsMock) TrieStorageManagers() map[string]common.StorageManager
- func (scm *StateComponentsMock) TriesContainer() common.TriesHolder
- type StatusMetricsStub
- func (sms *StatusMetricsStub) BootstrapMetrics() (map[string]interface{}, error)
- func (sms *StatusMetricsStub) ConfigMetrics() (map[string]interface{}, error)
- func (sms *StatusMetricsStub) EconomicsMetrics() (map[string]interface{}, error)
- func (sms *StatusMetricsStub) EnableEpochsMetrics() (map[string]interface{}, error)
- func (sms *StatusMetricsStub) IsInterfaceNil() bool
- func (sms *StatusMetricsStub) NetworkMetrics() (map[string]interface{}, error)
- func (sms *StatusMetricsStub) RatingsMetrics() (map[string]interface{}, error)
- func (sms *StatusMetricsStub) StatusMetricsMapWithoutP2P() (map[string]interface{}, error)
- func (sms *StatusMetricsStub) StatusMetricsWithoutP2PPrometheusString() (string, error)
- func (sms *StatusMetricsStub) StatusP2pMetricsMap() (map[string]interface{}, error)
- type StorageManagerStub
- func (sms *StorageManagerStub) AddDirtyCheckpointHashes(rootHash []byte, hashes common.ModifiedHashes) bool
- func (sms *StorageManagerStub) Close() error
- func (sms *StorageManagerStub) EnterPruningBufferingMode()
- func (sms *StorageManagerStub) ExitPruningBufferingMode()
- func (sms *StorageManagerStub) Get(key []byte) ([]byte, error)
- func (sms *StorageManagerStub) GetBaseTrieStorageManager() common.StorageManager
- func (sms *StorageManagerStub) GetFromCurrentEpoch(key []byte) ([]byte, error)
- func (sms *StorageManagerStub) GetLatestStorageEpoch() (uint32, error)
- func (sms *StorageManagerStub) IsClosed() bool
- func (sms *StorageManagerStub) IsInterfaceNil() bool
- func (sms *StorageManagerStub) IsPruningBlocked() bool
- func (sms *StorageManagerStub) IsPruningEnabled() bool
- func (sms *StorageManagerStub) Put(key []byte, val []byte) error
- func (sms *StorageManagerStub) PutInEpoch(key []byte, val []byte, epoch uint32) error
- func (sms *StorageManagerStub) PutInEpochWithoutCache(key []byte, val []byte, epoch uint32) error
- func (sms *StorageManagerStub) Remove(hash []byte) error
- func (sms *StorageManagerStub) RemoveFromCheckpointHashesHolder(hash []byte)
- func (sms *StorageManagerStub) RemoveFromCurrentEpoch(hash []byte) error
- func (sms *StorageManagerStub) SetCheckpoint(rootHash []byte, mainTrieRootHash []byte, ...)
- func (sms *StorageManagerStub) SetEpochForPutOperation(epoch uint32)
- func (sms *StorageManagerStub) ShouldTakeSnapshot() bool
- func (sms *StorageManagerStub) TakeSnapshot(address string, rootHash []byte, mainTrieRootHash []byte, ...)
- type SyncTimerStub
- type TimeCacheStub
- type TransactionCoordinatorMock
- func (tcm *TransactionCoordinatorMock) AddIntermediateTransactions(mapSCRs map[block.Type][]data.TransactionHandler) error
- func (tcm *TransactionCoordinatorMock) AddTransactions(txHandlers []data.TransactionHandler, blockType block.Type)
- func (tcm *TransactionCoordinatorMock) AddTxsFromMiniBlocks(miniBlocks block.MiniBlockSlice)
- func (tcm *TransactionCoordinatorMock) ComputeTransactionType(tx data.TransactionHandler) (process.TransactionType, process.TransactionType)
- func (tcm *TransactionCoordinatorMock) CreateBlockStarted()
- func (tcm *TransactionCoordinatorMock) CreateMarshalizedData(body *block.Body) map[string][][]byte
- func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessCrossShardTransactionsDstMe(header data.HeaderHandler, ...) (block.MiniBlockSlice, uint32, bool, error)
- func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessTransactionsFromMe(haveTime func() bool, _ []byte) block.MiniBlockSlice
- func (tcm *TransactionCoordinatorMock) CreatePostProcessMiniBlocks() block.MiniBlockSlice
- func (tcm *TransactionCoordinatorMock) CreateReceiptsHash() ([]byte, error)
- func (tcm *TransactionCoordinatorMock) GetAllCurrentLogs() []*data.LogData
- func (tcm *TransactionCoordinatorMock) GetAllCurrentUsedTxs(blockType block.Type) map[string]data.TransactionHandler
- func (tcm *TransactionCoordinatorMock) GetAllIntermediateTxs() map[block.Type]map[string]data.TransactionHandler
- func (tcm *TransactionCoordinatorMock) GetCreatedInShardMiniBlocks() []*block.MiniBlock
- func (tcm *TransactionCoordinatorMock) IsDataPreparedForProcessing(haveTime func() time.Duration) error
- func (tcm *TransactionCoordinatorMock) IsInterfaceNil() bool
- func (tcm *TransactionCoordinatorMock) ProcessBlockTransaction(header data.HeaderHandler, body *block.Body, haveTime func() time.Duration) error
- func (tcm *TransactionCoordinatorMock) RemoveBlockDataFromPool(body *block.Body) error
- func (tcm *TransactionCoordinatorMock) RemoveTxsFromPool(body *block.Body) error
- func (tcm *TransactionCoordinatorMock) RequestBlockTransactions(body *block.Body)
- func (tcm *TransactionCoordinatorMock) RequestMiniBlocks(header data.HeaderHandler)
- func (tcm *TransactionCoordinatorMock) RestoreBlockDataFromStorage(body *block.Body) (int, error)
- func (tcm *TransactionCoordinatorMock) SaveTxsToStorage(body *block.Body)
- func (tcm *TransactionCoordinatorMock) VerifyCreatedBlockTransactions(hdr data.HeaderHandler, body *block.Body) error
- func (tcm *TransactionCoordinatorMock) VerifyCreatedMiniBlocks(hdr data.HeaderHandler, body *block.Body) error
- type TxProcessorMock
- func (etm *TxProcessorMock) IsInterfaceNil() bool
- func (etm *TxProcessorMock) ProcessSmartContractResult(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)
- func (etm *TxProcessorMock) ProcessTransaction(transaction *transaction.Transaction) (vmcommon.ReturnCode, error)
- func (etm *TxProcessorMock) SetBalancesToTrie(accBalance map[string]*big.Int) (rootHash []byte, err error)
- func (etm *TxProcessorMock) VerifyTransaction(tx *transaction.Transaction) error
- type TxProcessorStub
- type TxTypeHandlerMock
- type TxVersionCheckerStub
- func (tvcs *TxVersionCheckerStub) CheckTxVersion(tx *transaction.Transaction) error
- func (tvcs *TxVersionCheckerStub) IsGuardedTransaction(tx *transaction.Transaction) bool
- func (tvcs *TxVersionCheckerStub) IsInterfaceNil() bool
- func (tvcs *TxVersionCheckerStub) IsSignedWithHash(tx *transaction.Transaction) bool
- type UnsignedTxHandlerStub
- func (ut *UnsignedTxHandlerStub) AddRewardTxFromBlock(tx data.TransactionHandler)
- func (ut *UnsignedTxHandlerStub) CleanProcessedUTxs()
- func (ut *UnsignedTxHandlerStub) CreateAllUTxs() []data.TransactionHandler
- func (ut *UnsignedTxHandlerStub) CreateBlockStarted(_ scheduled.GasAndFees)
- func (ut *UnsignedTxHandlerStub) GetAccumulatedFees() *big.Int
- func (ut *UnsignedTxHandlerStub) GetDeveloperFees() *big.Int
- func (ut *UnsignedTxHandlerStub) IsInterfaceNil() bool
- func (ut *UnsignedTxHandlerStub) ProcessTransactionFee(cost *big.Int, devFee *big.Int, txHash []byte)
- func (ut *UnsignedTxHandlerStub) ProcessTransactionFeeRelayedUserTx(cost *big.Int, devFee *big.Int, userTxHash []byte, originalTxHash []byte)
- func (ut *UnsignedTxHandlerStub) RevertFees(txHashes [][]byte)
- func (ut *UnsignedTxHandlerStub) VerifyCreatedUTxs() error
- type VersionedHeaderFactoryStub
- type WatchdogMock
- type WhiteListHandlerStub
- func (w *WhiteListHandlerStub) Add(keys [][]byte)
- func (w *WhiteListHandlerStub) IsForCurrentShard(interceptedData process.InterceptedData) bool
- func (w *WhiteListHandlerStub) IsInterfaceNil() bool
- func (w *WhiteListHandlerStub) IsWhiteListed(interceptedData process.InterceptedData) bool
- func (w *WhiteListHandlerStub) IsWhiteListedAtLeastOne(identifiers [][]byte) bool
- func (w *WhiteListHandlerStub) Remove(keys [][]byte)
Constants ¶
const HashSize = 32
HashSize holds the size of a typical hash used by the protocol
Variables ¶
var ( // TestAddressAlice is a test address TestAddressAlice = "erd1qyu5wthldzr8wx5c9ucg8kjagg0jfs53s8nr3zpz3hypefsdd8ssycr6th" // TestPubKeyAlice is a test pubkey TestPubKeyAlice, _ = RealWorldBech32PubkeyConverter.Decode(TestAddressAlice) // TestPubKeyHexAlice is a test pubkey TestPubKeyHexAlice = hex.EncodeToString(TestPubKeyAlice) // TestAddressBob is a test address TestAddressBob = "erd1spyavw0956vq68xj8y4tenjpq2wd5a9p2c6j8gsz7ztyrnpxrruqzu66jx" // TestPubKeyBob is a test pubkey TestPubKeyBob, _ = RealWorldBech32PubkeyConverter.Decode(TestAddressBob) // TestPubKeyHexBob is a test pubkey TestPubKeyHexBob = hex.EncodeToString(TestPubKeyBob) )
var ErrMockMarshalizer = errors.New("MarshalizerMock generic error")
ErrMockMarshalizer -
var ErrNotImplemented = errors.New("not implemented")
ErrNotImplemented signals that a method is not implemented for an interface implementation
var RealWorldBech32PubkeyConverter, _ = pubkeyConverter.NewBech32PubkeyConverter(32, logger.GetOrCreate("testscommon"))
RealWorldBech32PubkeyConverter is a bech32 converter, to be used in tests
Functions ¶
func CreateGinContextWithRawQuery ¶
CreateGinContextWithRawQuery creates a test gin context
func CreateMemUnit ¶
CreateMemUnit creates a new in-memory storage unit
func GetEconomicsConfig ¶
func GetEconomicsConfig() config.EconomicsConfig
GetEconomicsConfig returns the common configuration used for testing
func GetGeneralConfig ¶
GetGeneralConfig returns the common configuration used for testing
func NewNonceHashConverterMock ¶
func NewNonceHashConverterMock() *nonceHashConverterMock
NewNonceHashConverterMock -
func NewTimeoutHandlerMock ¶
NewTimeoutHandlerMock -
Types ¶
type AlarmSchedulerStub ¶
type AlarmSchedulerStub struct { AddCalled func(func(alarmID string), time.Duration, string) CancelCalled func(string) CloseCalled func() ResetCalled func(string) }
AlarmSchedulerStub -
func (*AlarmSchedulerStub) Add ¶
func (a *AlarmSchedulerStub) Add(callback func(alarmID string), duration time.Duration, alarmID string)
Add -
func (*AlarmSchedulerStub) IsInterfaceNil ¶
func (a *AlarmSchedulerStub) IsInterfaceNil() bool
IsInterfaceNil -
type AlteredAccountsProviderStub ¶
type AlteredAccountsProviderStub struct {
ExtractAlteredAccountsFromPoolCalled func(txPool *outport.Pool, options shared.AlteredAccountsOptions) (map[string]*outport.AlteredAccount, error)
}
AlteredAccountsProviderStub -
func (*AlteredAccountsProviderStub) ExtractAlteredAccountsFromPool ¶
func (a *AlteredAccountsProviderStub) ExtractAlteredAccountsFromPool(txPool *outport.Pool, options shared.AlteredAccountsOptions) (map[string]*outport.AlteredAccount, error)
ExtractAlteredAccountsFromPool -
func (*AlteredAccountsProviderStub) IsInterfaceNil ¶
func (a *AlteredAccountsProviderStub) IsInterfaceNil() bool
IsInterfaceNil -
type BalanceComputationStub ¶
type BalanceComputationStub struct { InitCalled func() SetBalanceToAddressCalled func(address []byte, value *big.Int) AddBalanceToAddressCalled func(address []byte, value *big.Int) bool SubBalanceFromAddressCalled func(address []byte, value *big.Int) bool IsAddressSetCalled func(address []byte) bool AddressHasEnoughBalanceCalled func(address []byte, value *big.Int) bool }
BalanceComputationStub -
func (*BalanceComputationStub) AddBalanceToAddress ¶
func (bcs *BalanceComputationStub) AddBalanceToAddress(address []byte, value *big.Int) bool
AddBalanceToAddress -
func (*BalanceComputationStub) AddressHasEnoughBalance ¶
func (bcs *BalanceComputationStub) AddressHasEnoughBalance(address []byte, value *big.Int) bool
AddressHasEnoughBalance -
func (*BalanceComputationStub) IsAddressSet ¶
func (bcs *BalanceComputationStub) IsAddressSet(address []byte) bool
IsAddressSet -
func (*BalanceComputationStub) IsInterfaceNil ¶
func (bcs *BalanceComputationStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*BalanceComputationStub) SetBalanceToAddress ¶
func (bcs *BalanceComputationStub) SetBalanceToAddress(address []byte, value *big.Int)
SetBalanceToAddress -
func (*BalanceComputationStub) SubBalanceFromAddress ¶
func (bcs *BalanceComputationStub) SubBalanceFromAddress(address []byte, value *big.Int) bool
SubBalanceFromAddress -
type BlockChainHookCounterStub ¶
type BlockChainHookCounterStub struct { ProcessCrtNumberOfTrieReadsCounterCalled func() error ProcessMaxBuiltInCountersCalled func(input *vmcommon.ContractCallInput) error ResetCountersCalled func() SetMaximumValuesCalled func(mapsOfValues map[string]uint64) GetCounterValuesCalled func() map[string]uint64 }
BlockChainHookCounterStub -
func (*BlockChainHookCounterStub) GetCounterValues ¶
func (stub *BlockChainHookCounterStub) GetCounterValues() map[string]uint64
GetCounterValues -
func (*BlockChainHookCounterStub) IsInterfaceNil ¶
func (stub *BlockChainHookCounterStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*BlockChainHookCounterStub) ProcessCrtNumberOfTrieReadsCounter ¶
func (stub *BlockChainHookCounterStub) ProcessCrtNumberOfTrieReadsCounter() error
ProcessCrtNumberOfTrieReadsCounter -
func (*BlockChainHookCounterStub) ProcessMaxBuiltInCounters ¶
func (stub *BlockChainHookCounterStub) ProcessMaxBuiltInCounters(input *vmcommon.ContractCallInput) error
ProcessMaxBuiltInCounters -
func (*BlockChainHookCounterStub) ResetCounters ¶
func (stub *BlockChainHookCounterStub) ResetCounters()
ResetCounters -
func (*BlockChainHookCounterStub) SetMaximumValues ¶
func (stub *BlockChainHookCounterStub) SetMaximumValues(mapsOfValues map[string]uint64)
SetMaximumValues -
type BlockChainHookStub ¶
type BlockChainHookStub struct { NewAddressCalled func(creatorAddress []byte, creatorNonce uint64, vmType []byte) ([]byte, error) GetStorageDataCalled func(accountsAddress []byte, index []byte) ([]byte, uint32, error) GetBlockHashCalled func(nonce uint64) ([]byte, error) LastNonceCalled func() uint64 LastRoundCalled func() uint64 LastTimeStampCalled func() uint64 LastRandomSeedCalled func() []byte LastEpochCalled func() uint32 GetStateRootHashCalled func() []byte CurrentNonceCalled func() uint64 CurrentRoundCalled func() uint64 CurrentTimeStampCalled func() uint64 CurrentRandomSeedCalled func() []byte CurrentEpochCalled func() uint32 ProcessBuiltInFunctionCalled func(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error) GetBuiltinFunctionNamesCalled func() vmcommon.FunctionNames GetBuiltinFunctionsContainerCalled func() vmcommon.BuiltInFunctionContainer GetAllStateCalled func(address []byte) (map[string][]byte, error) GetUserAccountCalled func(address []byte) (vmcommon.UserAccountHandler, error) GetShardOfAddressCalled func(address []byte) uint32 IsSmartContractCalled func(address []byte) bool IsPayableCalled func(sndAddress []byte, recvAddress []byte) (bool, error) GetCompiledCodeCalled func(codeHash []byte) (bool, []byte) SaveCompiledCodeCalled func(codeHash []byte, code []byte) ClearCompiledCodesCalled func() GetCodeCalled func(account vmcommon.UserAccountHandler) []byte GetESDTTokenCalled func(address []byte, tokenID []byte, nonce uint64) (*esdt.ESDigitalToken, error) NumberOfShardsCalled func() uint32 GetSnapshotCalled func() int RevertToSnapshotCalled func(snapshot int) error SetCurrentHeaderCalled func(hdr data.HeaderHandler) DeleteCompiledCodeCalled func(codeHash []byte) SaveNFTMetaDataToSystemAccountCalled func(tx data.TransactionHandler) error CloseCalled func() error FilterCodeMetadataForUpgradeCalled func(input []byte) ([]byte, error) ApplyFiltersOnCodeMetadataCalled func(codeMetadata vmcommon.CodeMetadata) vmcommon.CodeMetadata ResetCountersCalled func() GetCounterValuesCalled func() map[string]uint64 }
BlockChainHookStub -
func (*BlockChainHookStub) ApplyFiltersOnSCCodeMetadata ¶ added in v1.5.0
func (stub *BlockChainHookStub) ApplyFiltersOnSCCodeMetadata(codeMetadata vmcommon.CodeMetadata) vmcommon.CodeMetadata
ApplyFiltersOnSCCodeMetadata -
func (*BlockChainHookStub) ClearCompiledCodes ¶
func (stub *BlockChainHookStub) ClearCompiledCodes()
ClearCompiledCodes -
func (*BlockChainHookStub) CurrentEpoch ¶
func (stub *BlockChainHookStub) CurrentEpoch() uint32
CurrentEpoch -
func (*BlockChainHookStub) CurrentNonce ¶
func (stub *BlockChainHookStub) CurrentNonce() uint64
CurrentNonce -
func (*BlockChainHookStub) CurrentRandomSeed ¶
func (stub *BlockChainHookStub) CurrentRandomSeed() []byte
CurrentRandomSeed -
func (*BlockChainHookStub) CurrentRound ¶
func (stub *BlockChainHookStub) CurrentRound() uint64
CurrentRound -
func (*BlockChainHookStub) CurrentTimeStamp ¶
func (stub *BlockChainHookStub) CurrentTimeStamp() uint64
CurrentTimeStamp -
func (*BlockChainHookStub) DeleteCompiledCode ¶
func (stub *BlockChainHookStub) DeleteCompiledCode(codeHash []byte)
DeleteCompiledCode -
func (*BlockChainHookStub) FilterCodeMetadataForUpgrade ¶
func (stub *BlockChainHookStub) FilterCodeMetadataForUpgrade(input []byte) ([]byte, error)
FilterCodeMetadataForUpgrade -
func (*BlockChainHookStub) GetAllState ¶
func (stub *BlockChainHookStub) GetAllState(address []byte) (map[string][]byte, error)
GetAllState -
func (*BlockChainHookStub) GetBlockhash ¶
func (stub *BlockChainHookStub) GetBlockhash(nonce uint64) ([]byte, error)
GetBlockhash -
func (*BlockChainHookStub) GetBuiltinFunctionNames ¶
func (stub *BlockChainHookStub) GetBuiltinFunctionNames() vmcommon.FunctionNames
GetBuiltinFunctionNames -
func (*BlockChainHookStub) GetBuiltinFunctionsContainer ¶
func (stub *BlockChainHookStub) GetBuiltinFunctionsContainer() vmcommon.BuiltInFunctionContainer
GetBuiltinFunctionsContainer -
func (*BlockChainHookStub) GetCode ¶
func (stub *BlockChainHookStub) GetCode(account vmcommon.UserAccountHandler) []byte
GetCode -
func (*BlockChainHookStub) GetCompiledCode ¶
func (stub *BlockChainHookStub) GetCompiledCode(codeHash []byte) (bool, []byte)
GetCompiledCode -
func (*BlockChainHookStub) GetCounterValues ¶
func (stub *BlockChainHookStub) GetCounterValues() map[string]uint64
GetCounterValues -
func (*BlockChainHookStub) GetESDTToken ¶
func (stub *BlockChainHookStub) GetESDTToken(address []byte, tokenID []byte, nonce uint64) (*esdt.ESDigitalToken, error)
GetESDTToken -
func (*BlockChainHookStub) GetShardOfAddress ¶
func (stub *BlockChainHookStub) GetShardOfAddress(address []byte) uint32
GetShardOfAddress -
func (*BlockChainHookStub) GetSnapshot ¶
func (stub *BlockChainHookStub) GetSnapshot() int
GetSnapshot -
func (*BlockChainHookStub) GetStateRootHash ¶
func (stub *BlockChainHookStub) GetStateRootHash() []byte
GetStateRootHash -
func (*BlockChainHookStub) GetStorageData ¶
func (stub *BlockChainHookStub) GetStorageData(accountAddress []byte, index []byte) ([]byte, uint32, error)
GetStorageData -
func (*BlockChainHookStub) GetUserAccount ¶
func (stub *BlockChainHookStub) GetUserAccount(address []byte) (vmcommon.UserAccountHandler, error)
GetUserAccount -
func (*BlockChainHookStub) IsInterfaceNil ¶
func (stub *BlockChainHookStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*BlockChainHookStub) IsLimitedTransfer ¶
func (stub *BlockChainHookStub) IsLimitedTransfer(_ []byte) bool
IsLimitedTransfer -
func (*BlockChainHookStub) IsPaused ¶
func (stub *BlockChainHookStub) IsPaused(_ []byte) bool
IsPaused -
func (*BlockChainHookStub) IsPayable ¶
func (stub *BlockChainHookStub) IsPayable(sndAddress []byte, recvAddress []byte) (bool, error)
IsPayable -
func (*BlockChainHookStub) IsSmartContract ¶
func (stub *BlockChainHookStub) IsSmartContract(address []byte) bool
IsSmartContract -
func (*BlockChainHookStub) LastEpoch ¶
func (stub *BlockChainHookStub) LastEpoch() uint32
LastEpoch -
func (*BlockChainHookStub) LastNonce ¶
func (stub *BlockChainHookStub) LastNonce() uint64
LastNonce -
func (*BlockChainHookStub) LastRandomSeed ¶
func (stub *BlockChainHookStub) LastRandomSeed() []byte
LastRandomSeed -
func (*BlockChainHookStub) LastRound ¶
func (stub *BlockChainHookStub) LastRound() uint64
LastRound -
func (*BlockChainHookStub) LastTimeStamp ¶
func (stub *BlockChainHookStub) LastTimeStamp() uint64
LastTimeStamp -
func (*BlockChainHookStub) NewAddress ¶
func (stub *BlockChainHookStub) NewAddress(creatorAddress []byte, creatorNonce uint64, vmType []byte) ([]byte, error)
NewAddress -
func (*BlockChainHookStub) NumberOfShards ¶
func (stub *BlockChainHookStub) NumberOfShards() uint32
NumberOfShards -
func (*BlockChainHookStub) ProcessBuiltInFunction ¶
func (stub *BlockChainHookStub) ProcessBuiltInFunction(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error)
ProcessBuiltInFunction -
func (*BlockChainHookStub) ResetCounters ¶
func (stub *BlockChainHookStub) ResetCounters()
ResetCounters -
func (*BlockChainHookStub) RevertToSnapshot ¶
func (stub *BlockChainHookStub) RevertToSnapshot(snapshot int) error
RevertToSnapshot -
func (*BlockChainHookStub) SaveCompiledCode ¶
func (stub *BlockChainHookStub) SaveCompiledCode(codeHash []byte, code []byte)
SaveCompiledCode -
func (*BlockChainHookStub) SaveNFTMetaDataToSystemAccount ¶
func (stub *BlockChainHookStub) SaveNFTMetaDataToSystemAccount(tx data.TransactionHandler) error
SaveNFTMetaDataToSystemAccount -
func (*BlockChainHookStub) SetCurrentHeader ¶
func (stub *BlockChainHookStub) SetCurrentHeader(hdr data.HeaderHandler)
SetCurrentHeader -
type BlockInfoProviderStub ¶
BlockInfoProviderStub -
func (*BlockInfoProviderStub) GetBlockInfo ¶
func (stub *BlockInfoProviderStub) GetBlockInfo() common.BlockInfo
GetBlockInfo -
func (*BlockInfoProviderStub) IsInterfaceNil ¶
func (stub *BlockInfoProviderStub) IsInterfaceNil() bool
IsInterfaceNil -
type BlockProcessorStub ¶
type BlockProcessorStub struct { SetNumProcessedObjCalled func(numObj uint64) ProcessBlockCalled func(header data.HeaderHandler, body data.BodyHandler, haveTime func() time.Duration) error ProcessScheduledBlockCalled func(header data.HeaderHandler, body data.BodyHandler, haveTime func() time.Duration) error CommitBlockCalled func(header data.HeaderHandler, body data.BodyHandler) error RevertCurrentBlockCalled func() PruneStateOnRollbackCalled func(currHeader data.HeaderHandler, currHeaderHash []byte, prevHeader data.HeaderHandler, prevHeaderHash []byte) CreateBlockCalled func(initialHdrData data.HeaderHandler, haveTime func() bool) (data.HeaderHandler, data.BodyHandler, error) RestoreBlockIntoPoolsCalled func(header data.HeaderHandler, body data.BodyHandler) error RestoreBlockBodyIntoPoolsCalled func(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 CreateNewHeaderCalled func(round uint64, nonce uint64) (data.HeaderHandler, error) RevertStateToBlockCalled func(header data.HeaderHandler, rootHash []byte) error NonceOfFirstCommittedBlockCalled func() core.OptionalUint64 CloseCalled func() error }
BlockProcessorStub mocks the implementation for a blockProcessor
func (*BlockProcessorStub) CommitBlock ¶
func (bps *BlockProcessorStub) CommitBlock(header data.HeaderHandler, body data.BodyHandler) error
CommitBlock mocks the commit of a block
func (*BlockProcessorStub) CreateBlock ¶
func (bps *BlockProcessorStub) CreateBlock(initialHdrData data.HeaderHandler, haveTime func() bool) (data.HeaderHandler, data.BodyHandler, error)
CreateBlock mocks the creation of a new block with header and body
func (*BlockProcessorStub) CreateNewHeader ¶
func (bps *BlockProcessorStub) CreateNewHeader(round uint64, nonce uint64) (data.HeaderHandler, error)
CreateNewHeader creates a new header
func (*BlockProcessorStub) DecodeBlockBody ¶
func (bps *BlockProcessorStub) DecodeBlockBody(dta []byte) data.BodyHandler
DecodeBlockBody -
func (*BlockProcessorStub) DecodeBlockHeader ¶
func (bps *BlockProcessorStub) DecodeBlockHeader(dta []byte) data.HeaderHandler
DecodeBlockHeader -
func (*BlockProcessorStub) IsInterfaceNil ¶
func (bps *BlockProcessorStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*BlockProcessorStub) MarshalizedDataToBroadcast ¶
func (bps *BlockProcessorStub) MarshalizedDataToBroadcast(header data.HeaderHandler, body data.BodyHandler) (map[uint32][]byte, map[string][][]byte, error)
MarshalizedDataToBroadcast -
func (*BlockProcessorStub) NonceOfFirstCommittedBlock ¶
func (bps *BlockProcessorStub) NonceOfFirstCommittedBlock() core.OptionalUint64
NonceOfFirstCommittedBlock -
func (*BlockProcessorStub) ProcessBlock ¶
func (bps *BlockProcessorStub) ProcessBlock(header data.HeaderHandler, body data.BodyHandler, haveTime func() time.Duration) error
ProcessBlock mocks processing a block
func (*BlockProcessorStub) ProcessScheduledBlock ¶
func (bps *BlockProcessorStub) ProcessScheduledBlock(header data.HeaderHandler, body data.BodyHandler, haveTime func() time.Duration) error
ProcessScheduledBlock mocks processing a scheduled block
func (*BlockProcessorStub) PruneStateOnRollback ¶
func (bps *BlockProcessorStub) PruneStateOnRollback(currHeader data.HeaderHandler, currHeaderHash []byte, prevHeader data.HeaderHandler, prevHeaderHash []byte)
PruneStateOnRollback recreates the state tries to the root hashes indicated by the provided header
func (*BlockProcessorStub) RestoreBlockBodyIntoPools ¶
func (bps *BlockProcessorStub) RestoreBlockBodyIntoPools(body data.BodyHandler) error
RestoreBlockBodyIntoPools -
func (*BlockProcessorStub) RestoreBlockIntoPools ¶
func (bps *BlockProcessorStub) RestoreBlockIntoPools(header data.HeaderHandler, body data.BodyHandler) error
RestoreBlockIntoPools -
func (*BlockProcessorStub) RevertCurrentBlock ¶
func (bps *BlockProcessorStub) RevertCurrentBlock()
RevertCurrentBlock mocks revert of the current block
func (*BlockProcessorStub) RevertStateToBlock ¶
func (bps *BlockProcessorStub) RevertStateToBlock(header data.HeaderHandler, rootHash []byte) error
RevertStateToBlock recreates the state tries to the root hashes indicated by the provided header
func (*BlockProcessorStub) SetNumProcessedObj ¶
func (bps *BlockProcessorStub) SetNumProcessedObj(numObj uint64)
SetNumProcessedObj -
type BlockSizeComputationStub ¶
type BlockSizeComputationStub struct { InitCalled func() AddNumMiniBlocksCalled func(int) AddNumTxsCalled func(int) IsMaxBlockSizeReachedCalled func(int, int) bool IsMaxBlockSizeWithoutThrottleReachedCalled func(int, int) bool }
BlockSizeComputationStub -
func (*BlockSizeComputationStub) AddNumMiniBlocks ¶
func (bscs *BlockSizeComputationStub) AddNumMiniBlocks(numMiniBlocks int)
AddNumMiniBlocks -
func (*BlockSizeComputationStub) AddNumTxs ¶
func (bscs *BlockSizeComputationStub) AddNumTxs(numTxs int)
AddNumTxs -
func (*BlockSizeComputationStub) IsInterfaceNil ¶
func (bscs *BlockSizeComputationStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*BlockSizeComputationStub) IsMaxBlockSizeReached ¶
func (bscs *BlockSizeComputationStub) IsMaxBlockSizeReached(numNewMiniBlocks int, numNewTxs int) bool
IsMaxBlockSizeReached -
func (*BlockSizeComputationStub) IsMaxBlockSizeWithoutThrottleReached ¶
func (bscs *BlockSizeComputationStub) IsMaxBlockSizeWithoutThrottleReached(numNewMiniBlocks int, numNewTxs int) bool
IsMaxBlockSizeWithoutThrottleReached -
type BuiltInCostHandlerStub ¶
type BuiltInCostHandlerStub struct { ComputeBuiltInCostCalled func(tx data.TransactionWithFeeHandler) uint64 IsBuiltInFuncCallCalled func(tx data.TransactionWithFeeHandler) bool }
BuiltInCostHandlerStub -
func (*BuiltInCostHandlerStub) ComputeBuiltInCost ¶
func (stub *BuiltInCostHandlerStub) ComputeBuiltInCost(tx data.TransactionWithFeeHandler) uint64
ComputeBuiltInCost -
func (*BuiltInCostHandlerStub) IsBuiltInFuncCall ¶
func (stub *BuiltInCostHandlerStub) IsBuiltInFuncCall(tx data.TransactionWithFeeHandler) bool
IsBuiltInFuncCall -
func (*BuiltInCostHandlerStub) IsInterfaceNil ¶
func (stub *BuiltInCostHandlerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if underlying object is nil
type CacherMock ¶
type CacherMock struct {
// contains filtered or unexported fields
}
CacherMock -
func (*CacherMock) Get ¶
func (cacher *CacherMock) Get(key []byte) (value interface{}, ok bool)
Get -
func (*CacherMock) HasOrAdd ¶
func (cacher *CacherMock) HasOrAdd(key []byte, value interface{}, _ int) (has, added bool)
HasOrAdd -
func (*CacherMock) IsInterfaceNil ¶
func (cacher *CacherMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*CacherMock) Peek ¶
func (cacher *CacherMock) Peek(key []byte) (value interface{}, ok bool)
Peek -
func (*CacherMock) Put ¶
func (cacher *CacherMock) Put(key []byte, value interface{}, _ int) (evicted bool)
Put -
func (*CacherMock) RegisterHandler ¶
func (cacher *CacherMock) RegisterHandler(handler func(key []byte, value interface{}), _ string)
RegisterHandler -
func (*CacherMock) SizeInBytesContained ¶
func (cacher *CacherMock) SizeInBytesContained() uint64
SizeInBytesContained -
func (*CacherMock) UnRegisterHandler ¶
func (cacher *CacherMock) UnRegisterHandler(string)
UnRegisterHandler -
type CacherStub ¶
type CacherStub struct { ClearCalled func() PutCalled func(key []byte, value interface{}, sizeInBytes int) (evicted bool) GetCalled func(key []byte) (value interface{}, ok bool) HasCalled func(key []byte) bool PeekCalled func(key []byte) (value interface{}, ok bool) HasOrAddCalled func(key []byte, value interface{}, sizeInBytes int) (has, added bool) RemoveCalled func(key []byte) RemoveOldestCalled func() KeysCalled func() [][]byte LenCalled func() int MaxSizeCalled func() int RegisterHandlerCalled func(func(key []byte, value interface{})) UnRegisterHandlerCalled func(id string) CloseCalled func() error }
CacherStub -
func (*CacherStub) Get ¶
func (cacher *CacherStub) Get(key []byte) (value interface{}, ok bool)
Get -
func (*CacherStub) HasOrAdd ¶
func (cacher *CacherStub) HasOrAdd(key []byte, value interface{}, sizeInBytes int) (has, added bool)
HasOrAdd -
func (*CacherStub) IsInterfaceNil ¶
func (cacher *CacherStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*CacherStub) Peek ¶
func (cacher *CacherStub) Peek(key []byte) (value interface{}, ok bool)
Peek -
func (*CacherStub) Put ¶
func (cacher *CacherStub) Put(key []byte, value interface{}, sizeInBytes int) (evicted bool)
Put -
func (*CacherStub) RegisterHandler ¶
func (cacher *CacherStub) RegisterHandler(handler func(key []byte, value interface{}), _ string)
RegisterHandler -
func (*CacherStub) SizeInBytesContained ¶
func (cacher *CacherStub) SizeInBytesContained() uint64
SizeInBytesContained -
func (*CacherStub) UnRegisterHandler ¶
func (cacher *CacherStub) UnRegisterHandler(id string)
UnRegisterHandler -
type ChainHandlerMock ¶
type ChainHandlerMock struct {
// contains filtered or unexported fields
}
ChainHandlerMock -
func (*ChainHandlerMock) GetCurrentBlockHeader ¶
func (mock *ChainHandlerMock) GetCurrentBlockHeader() data.HeaderHandler
GetCurrentBlockHeader -
func (*ChainHandlerMock) GetCurrentBlockHeaderHash ¶
func (mock *ChainHandlerMock) GetCurrentBlockHeaderHash() []byte
GetCurrentBlockHeaderHash -
func (*ChainHandlerMock) GetCurrentBlockRootHash ¶
func (mock *ChainHandlerMock) GetCurrentBlockRootHash() []byte
GetCurrentBlockRootHash -
func (*ChainHandlerMock) GetFinalBlockInfo ¶
func (mock *ChainHandlerMock) GetFinalBlockInfo() (nonce uint64, blockHash []byte, rootHash []byte)
GetFinalBlockInfo -
func (*ChainHandlerMock) GetGenesisHeader ¶
func (mock *ChainHandlerMock) GetGenesisHeader() data.HeaderHandler
GetGenesisHeader -
func (*ChainHandlerMock) GetGenesisHeaderHash ¶
func (mock *ChainHandlerMock) GetGenesisHeaderHash() []byte
GetGenesisHeaderHash -
func (*ChainHandlerMock) IsInterfaceNil ¶
func (mock *ChainHandlerMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*ChainHandlerMock) SetCurrentBlockHeaderAndRootHash ¶
func (mock *ChainHandlerMock) SetCurrentBlockHeaderAndRootHash(header data.HeaderHandler, rootHash []byte) error
SetCurrentBlockHeaderAndRootHash -
func (*ChainHandlerMock) SetCurrentBlockHeaderHash ¶
func (mock *ChainHandlerMock) SetCurrentBlockHeaderHash(hash []byte)
SetCurrentBlockHeaderHash -
func (*ChainHandlerMock) SetFinalBlockInfo ¶
func (mock *ChainHandlerMock) SetFinalBlockInfo(nonce uint64, headerHash []byte, rootHash []byte)
SetFinalBlockInfo -
func (*ChainHandlerMock) SetGenesisHeader ¶
func (mock *ChainHandlerMock) SetGenesisHeader(genesisBlock data.HeaderHandler) error
SetGenesisHeader -
func (*ChainHandlerMock) SetGenesisHeaderHash ¶
func (mock *ChainHandlerMock) SetGenesisHeaderHash(hash []byte)
SetGenesisHeaderHash -
type ChainHandlerStub ¶
type ChainHandlerStub struct { GetGenesisHeaderCalled func() data.HeaderHandler SetGenesisHeaderCalled func(handler data.HeaderHandler) error GetGenesisHeaderHashCalled func() []byte SetGenesisHeaderHashCalled func([]byte) GetCurrentBlockHeaderCalled func() data.HeaderHandler SetCurrentBlockHeaderAndRootHashCalled func(header data.HeaderHandler, rootHash []byte) error GetCurrentBlockHeaderHashCalled func() []byte SetCurrentBlockHeaderHashCalled func([]byte) GetCurrentBlockRootHashCalled func() []byte SetFinalBlockInfoCalled func(nonce uint64, headerHash []byte, rootHash []byte) GetFinalBlockInfoCalled func() (nonce uint64, blockHash []byte, rootHash []byte) }
ChainHandlerStub -
func (*ChainHandlerStub) GetCurrentBlockHeader ¶
func (stub *ChainHandlerStub) GetCurrentBlockHeader() data.HeaderHandler
GetCurrentBlockHeader -
func (*ChainHandlerStub) GetCurrentBlockHeaderHash ¶
func (stub *ChainHandlerStub) GetCurrentBlockHeaderHash() []byte
GetCurrentBlockHeaderHash -
func (*ChainHandlerStub) GetCurrentBlockRootHash ¶
func (stub *ChainHandlerStub) GetCurrentBlockRootHash() []byte
GetCurrentBlockRootHash -
func (*ChainHandlerStub) GetFinalBlockInfo ¶
func (stub *ChainHandlerStub) GetFinalBlockInfo() (nonce uint64, blockHash []byte, rootHash []byte)
GetFinalBlockInfo -
func (*ChainHandlerStub) GetGenesisHeader ¶
func (stub *ChainHandlerStub) GetGenesisHeader() data.HeaderHandler
GetGenesisHeader -
func (*ChainHandlerStub) GetGenesisHeaderHash ¶
func (stub *ChainHandlerStub) GetGenesisHeaderHash() []byte
GetGenesisHeaderHash -
func (*ChainHandlerStub) IsInterfaceNil ¶
func (stub *ChainHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ChainHandlerStub) SetCurrentBlockHeaderAndRootHash ¶
func (stub *ChainHandlerStub) SetCurrentBlockHeaderAndRootHash(header data.HeaderHandler, rootHash []byte) error
SetCurrentBlockHeaderAndRootHash -
func (*ChainHandlerStub) SetCurrentBlockHeaderHash ¶
func (stub *ChainHandlerStub) SetCurrentBlockHeaderHash(hash []byte)
SetCurrentBlockHeaderHash -
func (*ChainHandlerStub) SetFinalBlockInfo ¶
func (stub *ChainHandlerStub) SetFinalBlockInfo(nonce uint64, headerHash []byte, rootHash []byte)
SetFinalBlockInfo -
func (*ChainHandlerStub) SetGenesisHeader ¶
func (stub *ChainHandlerStub) SetGenesisHeader(genesisBlock data.HeaderHandler) error
SetGenesisHeader -
func (*ChainHandlerStub) SetGenesisHeaderHash ¶
func (stub *ChainHandlerStub) SetGenesisHeaderHash(hash []byte)
SetGenesisHeaderHash -
type CurrentEpochProviderStub ¶
CurrentEpochProviderStub -
func (*CurrentEpochProviderStub) EpochIsActiveInNetwork ¶
func (c *CurrentEpochProviderStub) EpochIsActiveInNetwork(epoch uint32) bool
EpochIsActiveInNetwork -
func (*CurrentEpochProviderStub) IsInterfaceNil ¶
func (c *CurrentEpochProviderStub) IsInterfaceNil() bool
IsInterfaceNil -
type CustomDatabaseRemoverStub ¶
type CustomDatabaseRemoverStub struct {
ShouldRemoveCalled func(dbIdentifier string, epoch uint32) bool
}
CustomDatabaseRemoverStub -
func (*CustomDatabaseRemoverStub) IsInterfaceNil ¶
func (c *CustomDatabaseRemoverStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*CustomDatabaseRemoverStub) ShouldRemove ¶
func (c *CustomDatabaseRemoverStub) ShouldRemove(dbIdentifier string, epoch uint32) bool
ShouldRemove -
type DataFieldParserStub ¶
type DataFieldParserStub struct {
ParseCalled func(dataField []byte, sender, receiver []byte, numOfShards uint32) *datafield.ResponseParseData
}
DataFieldParserStub -
func (*DataFieldParserStub) Parse ¶
func (df *DataFieldParserStub) Parse(dataField []byte, sender, receiver []byte, numOfShards uint32) *datafield.ResponseParseData
Parse -
type ESDTGlobalSettingsHandlerStub ¶
type ESDTGlobalSettingsHandlerStub struct { IsPausedCalled func(esdtTokenKey []byte) bool IsLimitedTransferCalled func(esdtTokenKey []byte) bool }
ESDTGlobalSettingsHandlerStub -
func (*ESDTGlobalSettingsHandlerStub) IsInterfaceNil ¶
func (e *ESDTGlobalSettingsHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ESDTGlobalSettingsHandlerStub) IsLimitedTransfer ¶
func (e *ESDTGlobalSettingsHandlerStub) IsLimitedTransfer(esdtTokenKey []byte) bool
IsLimitedTransfer -
func (*ESDTGlobalSettingsHandlerStub) IsPaused ¶
func (e *ESDTGlobalSettingsHandlerStub) IsPaused(esdtTokenKey []byte) bool
IsPaused -
type ESDTTransferParserStub ¶
type ESDTTransferParserStub struct {
ParseESDTTransfersCalled func(sndAddr []byte, rcvAddr []byte, function string, args [][]byte) (*vmcommon.ParsedESDTTransfers, error)
}
ESDTTransferParserStub -
func (*ESDTTransferParserStub) IsInterfaceNil ¶
func (stub *ESDTTransferParserStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ESDTTransferParserStub) ParseESDTTransfers ¶
func (stub *ESDTTransferParserStub) ParseESDTTransfers(sndAddr []byte, rcvAddr []byte, function string, args [][]byte) (*vmcommon.ParsedESDTTransfers, error)
ParseESDTTransfers -
type EnableEpochsHandlerStub ¶
type EnableEpochsHandlerStub struct { sync.RWMutex ResetPenalizedTooMuchGasFlagCalled func() BlockGasAndFeesReCheckEnableEpochField uint32 StakingV2EnableEpochField uint32 ScheduledMiniBlocksEnableEpochField uint32 SwitchJailWaitingEnableEpochField uint32 BalanceWaitingListsEnableEpochField uint32 WaitingListFixEnableEpochField uint32 MultiESDTTransferAsyncCallBackEnableEpochField uint32 FixOOGReturnCodeEnableEpochField uint32 RemoveNonUpdatedStorageEnableEpochField uint32 CreateNFTThroughExecByCallerEnableEpochField uint32 FixFailExecutionOnErrorEnableEpochField uint32 ManagedCryptoAPIEnableEpochField uint32 DisableExecByCallerEnableEpochField uint32 RefactorContextEnableEpochField uint32 CheckExecuteReadOnlyEnableEpochField uint32 StorageAPICostOptimizationEnableEpochField uint32 MiniBlockPartialExecutionEnableEpochField uint32 RefactorPeersMiniBlocksEnableEpochField uint32 IsSCDeployFlagEnabledField bool IsBuiltInFunctionsFlagEnabledField bool IsRelayedTransactionsFlagEnabledField bool IsPenalizedTooMuchGasFlagEnabledField bool IsSwitchJailWaitingFlagEnabledField bool IsBelowSignedThresholdFlagEnabledField bool IsSwitchHysteresisForMinNodesFlagEnabledField bool IsSwitchHysteresisForMinNodesFlagEnabledForCurrentEpochField bool IsTransactionSignedWithTxHashFlagEnabledField bool IsMetaProtectionFlagEnabledField bool IsAheadOfTimeGasUsageFlagEnabledField bool IsGasPriceModifierFlagEnabledField bool IsRepairCallbackFlagEnabledField bool IsBalanceWaitingListsFlagEnabledField bool IsReturnDataToLastTransferFlagEnabledField bool IsSenderInOutTransferFlagEnabledField bool IsStakeFlagEnabledField bool IsStakingV2FlagEnabledField bool IsStakingV2OwnerFlagEnabledField bool IsStakingV2FlagEnabledForActivationEpochCompletedField bool IsDoubleKeyProtectionFlagEnabledField bool IsESDTFlagEnabledField bool IsESDTFlagEnabledForCurrentEpochField bool IsGovernanceFlagEnabledField bool IsGovernanceFlagEnabledForCurrentEpochField bool IsDelegationManagerFlagEnabledField bool IsDelegationSmartContractFlagEnabledField bool IsDelegationSmartContractFlagForCurrentEpochEnabledField bool IsCorrectLastUnJailedFlagEnabledField bool IsCorrectLastUnJailedFlagEnabledForCurrentEpochField bool IsRelayedTransactionsV2FlagEnabledField bool IsUnBondTokensV2FlagEnabledField bool IsSaveJailedAlwaysFlagEnabledField bool IsReDelegateBelowMinCheckFlagEnabledField bool IsValidatorToDelegationFlagEnabledField bool IsWaitingListFixFlagEnabledField bool IsIncrementSCRNonceInMultiTransferFlagEnabledField bool IsESDTMultiTransferFlagEnabledField bool IsGlobalMintBurnFlagEnabledField bool IsESDTTransferRoleFlagEnabledField bool IsBuiltInFunctionOnMetaFlagEnabledField bool IsComputeRewardCheckpointFlagEnabledField bool IsSCRSizeInvariantCheckFlagEnabledField bool IsBackwardCompSaveKeyValueFlagEnabledField bool IsESDTNFTCreateOnMultiShardFlagEnabledField bool IsMetaESDTSetFlagEnabledField bool IsAddTokensToDelegationFlagEnabledField bool IsMultiESDTTransferFixOnCallBackFlagEnabledField bool IsOptimizeGasUsedInCrossMiniBlocksFlagEnabledField bool IsCorrectFirstQueuedFlagEnabledField bool IsDeleteDelegatorAfterClaimRewardsFlagEnabledField bool IsFixOOGReturnCodeFlagEnabledField bool IsRemoveNonUpdatedStorageFlagEnabledField bool IsOptimizeNFTStoreFlagEnabledField bool IsCreateNFTThroughExecByCallerFlagEnabledField bool IsStopDecreasingValidatorRatingWhenStuckFlagEnabledField bool IsFrontRunningProtectionFlagEnabledField bool IsPayableBySCFlagEnabledField bool IsCleanUpInformativeSCRsFlagEnabledField bool IsStorageAPICostOptimizationFlagEnabledField bool IsESDTRegisterAndSetAllRolesFlagEnabledField bool IsScheduledMiniBlocksFlagEnabledField bool IsCorrectJailedNotUnStakedEmptyQueueFlagEnabledField bool IsDoNotReturnOldBlockInBlockchainHookFlagEnabledField bool IsAddFailedRelayedTxToInvalidMBsFlagField bool IsSCRSizeInvariantOnBuiltInResultFlagEnabledField bool IsCheckCorrectTokenIDForTransferRoleFlagEnabledField bool IsFailExecutionOnEveryAPIErrorFlagEnabledField bool IsMiniBlockPartialExecutionFlagEnabledField bool IsManagedCryptoAPIsFlagEnabledField bool IsESDTMetadataContinuousCleanupFlagEnabledField bool IsDisableExecByCallerFlagEnabledField bool IsRefactorContextFlagEnabledField bool IsCheckFunctionArgumentFlagEnabledField bool IsCheckExecuteOnReadOnlyFlagEnabledField bool IsFixAsyncCallbackCheckFlagEnabledField bool IsSaveToSystemAccountFlagEnabledField bool IsCheckFrozenCollectionFlagEnabledField bool IsSendAlwaysFlagEnabledField bool IsValueLengthCheckFlagEnabledField bool IsCheckTransferFlagEnabledField bool IsTransferToMetaFlagEnabledField bool IsESDTNFTImprovementV1FlagEnabledField bool IsSetSenderInEeiOutputTransferFlagEnabledField bool IsChangeDelegationOwnerFlagEnabledField bool IsRefactorPeersMiniBlocksFlagEnabledField bool IsFixAsyncCallBackArgsListFlagEnabledField bool IsFixOldTokenLiquidityEnabledField bool IsRuntimeMemStoreLimitEnabledField bool IsRuntimeCodeSizeFixEnabledField bool IsMaxBlockchainHookCountersFlagEnabledField bool IsWipeSingleNFTLiquidityDecreaseEnabledField bool IsAlwaysSaveTokenMetaDataEnabledField bool IsSetGuardianEnabledField bool IsRelayedNonceFixEnabledField bool }
EnableEpochsHandlerStub -
func (*EnableEpochsHandlerStub) BalanceWaitingListsEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) BalanceWaitingListsEnableEpoch() uint32
BalanceWaitingListsEnableEpoch -
func (*EnableEpochsHandlerStub) BlockGasAndFeesReCheckEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) BlockGasAndFeesReCheckEnableEpoch() uint32
BlockGasAndFeesReCheckEnableEpoch -
func (*EnableEpochsHandlerStub) CheckExecuteReadOnlyEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) CheckExecuteReadOnlyEnableEpoch() uint32
CheckExecuteReadOnlyEnableEpoch -
func (*EnableEpochsHandlerStub) CreateNFTThroughExecByCallerEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) CreateNFTThroughExecByCallerEnableEpoch() uint32
CreateNFTThroughExecByCallerEnableEpoch -
func (*EnableEpochsHandlerStub) DisableExecByCallerEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) DisableExecByCallerEnableEpoch() uint32
DisableExecByCallerEnableEpoch -
func (*EnableEpochsHandlerStub) FixFailExecutionOnErrorEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) FixFailExecutionOnErrorEnableEpoch() uint32
FixFailExecutionOnErrorEnableEpoch -
func (*EnableEpochsHandlerStub) FixOOGReturnCodeEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) FixOOGReturnCodeEnableEpoch() uint32
FixOOGReturnCodeEnableEpoch -
func (*EnableEpochsHandlerStub) IsAddFailedRelayedTxToInvalidMBsFlag ¶
func (stub *EnableEpochsHandlerStub) IsAddFailedRelayedTxToInvalidMBsFlag() bool
IsAddFailedRelayedTxToInvalidMBsFlag -
func (*EnableEpochsHandlerStub) IsAddTokensToDelegationFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsAddTokensToDelegationFlagEnabled() bool
IsAddTokensToDelegationFlagEnabled -
func (*EnableEpochsHandlerStub) IsAheadOfTimeGasUsageFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsAheadOfTimeGasUsageFlagEnabled() bool
IsAheadOfTimeGasUsageFlagEnabled -
func (*EnableEpochsHandlerStub) IsAlwaysSaveTokenMetaDataEnabled ¶
func (stub *EnableEpochsHandlerStub) IsAlwaysSaveTokenMetaDataEnabled() bool
IsAlwaysSaveTokenMetaDataEnabled -
func (*EnableEpochsHandlerStub) IsBackwardCompSaveKeyValueFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsBackwardCompSaveKeyValueFlagEnabled() bool
IsBackwardCompSaveKeyValueFlagEnabled -
func (*EnableEpochsHandlerStub) IsBalanceWaitingListsFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsBalanceWaitingListsFlagEnabled() bool
IsBalanceWaitingListsFlagEnabled -
func (*EnableEpochsHandlerStub) IsBelowSignedThresholdFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsBelowSignedThresholdFlagEnabled() bool
IsBelowSignedThresholdFlagEnabled -
func (*EnableEpochsHandlerStub) IsBuiltInFunctionOnMetaFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsBuiltInFunctionOnMetaFlagEnabled() bool
IsBuiltInFunctionOnMetaFlagEnabled -
func (*EnableEpochsHandlerStub) IsBuiltInFunctionsFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsBuiltInFunctionsFlagEnabled() bool
IsBuiltInFunctionsFlagEnabled -
func (*EnableEpochsHandlerStub) IsChangeDelegationOwnerFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsChangeDelegationOwnerFlagEnabled() bool
IsChangeDelegationOwnerFlagEnabled -
func (*EnableEpochsHandlerStub) IsCheckCorrectTokenIDForTransferRoleFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsCheckCorrectTokenIDForTransferRoleFlagEnabled() bool
IsCheckCorrectTokenIDForTransferRoleFlagEnabled -
func (*EnableEpochsHandlerStub) IsCheckExecuteOnReadOnlyFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsCheckExecuteOnReadOnlyFlagEnabled() bool
IsCheckExecuteOnReadOnlyFlagEnabled -
func (*EnableEpochsHandlerStub) IsCheckFrozenCollectionFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsCheckFrozenCollectionFlagEnabled() bool
IsCheckFrozenCollectionFlagEnabled -
func (*EnableEpochsHandlerStub) IsCheckFunctionArgumentFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsCheckFunctionArgumentFlagEnabled() bool
IsCheckFunctionArgumentFlagEnabled -
func (*EnableEpochsHandlerStub) IsCheckTransferFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsCheckTransferFlagEnabled() bool
IsCheckTransferFlagEnabled -
func (*EnableEpochsHandlerStub) IsCleanUpInformativeSCRsFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsCleanUpInformativeSCRsFlagEnabled() bool
IsCleanUpInformativeSCRsFlagEnabled -
func (*EnableEpochsHandlerStub) IsComputeRewardCheckpointFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsComputeRewardCheckpointFlagEnabled() bool
IsComputeRewardCheckpointFlagEnabled -
func (*EnableEpochsHandlerStub) IsCorrectFirstQueuedFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsCorrectFirstQueuedFlagEnabled() bool
IsCorrectFirstQueuedFlagEnabled -
func (*EnableEpochsHandlerStub) IsCorrectJailedNotUnStakedEmptyQueueFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsCorrectJailedNotUnStakedEmptyQueueFlagEnabled() bool
IsCorrectJailedNotUnStakedEmptyQueueFlagEnabled -
func (*EnableEpochsHandlerStub) IsCorrectLastUnJailedFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsCorrectLastUnJailedFlagEnabled() bool
IsCorrectLastUnJailedFlagEnabled -
func (*EnableEpochsHandlerStub) IsCorrectLastUnJailedFlagEnabledForCurrentEpoch ¶
func (stub *EnableEpochsHandlerStub) IsCorrectLastUnJailedFlagEnabledForCurrentEpoch() bool
IsCorrectLastUnJailedFlagEnabledForCurrentEpoch -
func (*EnableEpochsHandlerStub) IsCreateNFTThroughExecByCallerFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsCreateNFTThroughExecByCallerFlagEnabled() bool
IsCreateNFTThroughExecByCallerFlagEnabled -
func (*EnableEpochsHandlerStub) IsDelegationManagerFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsDelegationManagerFlagEnabled() bool
IsDelegationManagerFlagEnabled -
func (*EnableEpochsHandlerStub) IsDelegationSmartContractFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsDelegationSmartContractFlagEnabled() bool
IsDelegationSmartContractFlagEnabled -
func (*EnableEpochsHandlerStub) IsDelegationSmartContractFlagEnabledForCurrentEpoch ¶
func (stub *EnableEpochsHandlerStub) IsDelegationSmartContractFlagEnabledForCurrentEpoch() bool
IsDelegationSmartContractFlagEnabledForCurrentEpoch -
func (*EnableEpochsHandlerStub) IsDeleteDelegatorAfterClaimRewardsFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsDeleteDelegatorAfterClaimRewardsFlagEnabled() bool
IsDeleteDelegatorAfterClaimRewardsFlagEnabled -
func (*EnableEpochsHandlerStub) IsDisableExecByCallerFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsDisableExecByCallerFlagEnabled() bool
IsDisableExecByCallerFlagEnabled -
func (*EnableEpochsHandlerStub) IsDoNotReturnOldBlockInBlockchainHookFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsDoNotReturnOldBlockInBlockchainHookFlagEnabled() bool
IsDoNotReturnOldBlockInBlockchainHookFlagEnabled -
func (*EnableEpochsHandlerStub) IsDoubleKeyProtectionFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsDoubleKeyProtectionFlagEnabled() bool
IsDoubleKeyProtectionFlagEnabled -
func (*EnableEpochsHandlerStub) IsESDTFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsESDTFlagEnabled() bool
IsESDTFlagEnabled -
func (*EnableEpochsHandlerStub) IsESDTFlagEnabledForCurrentEpoch ¶
func (stub *EnableEpochsHandlerStub) IsESDTFlagEnabledForCurrentEpoch() bool
IsESDTFlagEnabledForCurrentEpoch -
func (*EnableEpochsHandlerStub) IsESDTMetadataContinuousCleanupFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsESDTMetadataContinuousCleanupFlagEnabled() bool
IsESDTMetadataContinuousCleanupFlagEnabled -
func (*EnableEpochsHandlerStub) IsESDTMultiTransferFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsESDTMultiTransferFlagEnabled() bool
IsESDTMultiTransferFlagEnabled -
func (*EnableEpochsHandlerStub) IsESDTNFTCreateOnMultiShardFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsESDTNFTCreateOnMultiShardFlagEnabled() bool
IsESDTNFTCreateOnMultiShardFlagEnabled -
func (*EnableEpochsHandlerStub) IsESDTNFTImprovementV1FlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsESDTNFTImprovementV1FlagEnabled() bool
IsESDTNFTImprovementV1FlagEnabled -
func (*EnableEpochsHandlerStub) IsESDTRegisterAndSetAllRolesFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsESDTRegisterAndSetAllRolesFlagEnabled() bool
IsESDTRegisterAndSetAllRolesFlagEnabled -
func (*EnableEpochsHandlerStub) IsESDTTransferRoleFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsESDTTransferRoleFlagEnabled() bool
IsESDTTransferRoleFlagEnabled -
func (*EnableEpochsHandlerStub) IsFailExecutionOnEveryAPIErrorFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsFailExecutionOnEveryAPIErrorFlagEnabled() bool
IsFailExecutionOnEveryAPIErrorFlagEnabled -
func (*EnableEpochsHandlerStub) IsFixAsyncCallBackArgsListFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsFixAsyncCallBackArgsListFlagEnabled() bool
IsFixAsyncCallBackArgsListFlagEnabled -
func (*EnableEpochsHandlerStub) IsFixAsyncCallbackCheckFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsFixAsyncCallbackCheckFlagEnabled() bool
IsFixAsyncCallbackCheckFlagEnabled -
func (*EnableEpochsHandlerStub) IsFixOOGReturnCodeFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsFixOOGReturnCodeFlagEnabled() bool
IsFixOOGReturnCodeFlagEnabled -
func (*EnableEpochsHandlerStub) IsFixOldTokenLiquidityEnabled ¶
func (stub *EnableEpochsHandlerStub) IsFixOldTokenLiquidityEnabled() bool
IsFixOldTokenLiquidityEnabled -
func (*EnableEpochsHandlerStub) IsFrontRunningProtectionFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsFrontRunningProtectionFlagEnabled() bool
IsFrontRunningProtectionFlagEnabled -
func (*EnableEpochsHandlerStub) IsGasPriceModifierFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsGasPriceModifierFlagEnabled() bool
IsGasPriceModifierFlagEnabled -
func (*EnableEpochsHandlerStub) IsGlobalMintBurnFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsGlobalMintBurnFlagEnabled() bool
IsGlobalMintBurnFlagEnabled -
func (*EnableEpochsHandlerStub) IsGovernanceFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsGovernanceFlagEnabled() bool
IsGovernanceFlagEnabled -
func (*EnableEpochsHandlerStub) IsGovernanceFlagEnabledForCurrentEpoch ¶
func (stub *EnableEpochsHandlerStub) IsGovernanceFlagEnabledForCurrentEpoch() bool
IsGovernanceFlagEnabledForCurrentEpoch -
func (*EnableEpochsHandlerStub) IsIncrementSCRNonceInMultiTransferFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsIncrementSCRNonceInMultiTransferFlagEnabled() bool
IsIncrementSCRNonceInMultiTransferFlagEnabled -
func (*EnableEpochsHandlerStub) IsInterfaceNil ¶
func (stub *EnableEpochsHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EnableEpochsHandlerStub) IsManagedCryptoAPIsFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsManagedCryptoAPIsFlagEnabled() bool
IsManagedCryptoAPIsFlagEnabled -
func (*EnableEpochsHandlerStub) IsMaxBlockchainHookCountersFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsMaxBlockchainHookCountersFlagEnabled() bool
IsMaxBlockchainHookCountersFlagEnabled -
func (*EnableEpochsHandlerStub) IsMetaESDTSetFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsMetaESDTSetFlagEnabled() bool
IsMetaESDTSetFlagEnabled -
func (*EnableEpochsHandlerStub) IsMetaProtectionFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsMetaProtectionFlagEnabled() bool
IsMetaProtectionFlagEnabled -
func (*EnableEpochsHandlerStub) IsMiniBlockPartialExecutionFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsMiniBlockPartialExecutionFlagEnabled() bool
IsMiniBlockPartialExecutionFlagEnabled -
func (*EnableEpochsHandlerStub) IsMultiESDTTransferFixOnCallBackFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsMultiESDTTransferFixOnCallBackFlagEnabled() bool
IsMultiESDTTransferFixOnCallBackFlagEnabled -
func (*EnableEpochsHandlerStub) IsOptimizeGasUsedInCrossMiniBlocksFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsOptimizeGasUsedInCrossMiniBlocksFlagEnabled() bool
IsOptimizeGasUsedInCrossMiniBlocksFlagEnabled -
func (*EnableEpochsHandlerStub) IsOptimizeNFTStoreFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsOptimizeNFTStoreFlagEnabled() bool
IsOptimizeNFTStoreFlagEnabled -
func (*EnableEpochsHandlerStub) IsPayableBySCFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsPayableBySCFlagEnabled() bool
IsPayableBySCFlagEnabled -
func (*EnableEpochsHandlerStub) IsPenalizedTooMuchGasFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsPenalizedTooMuchGasFlagEnabled() bool
IsPenalizedTooMuchGasFlagEnabled -
func (*EnableEpochsHandlerStub) IsReDelegateBelowMinCheckFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsReDelegateBelowMinCheckFlagEnabled() bool
IsReDelegateBelowMinCheckFlagEnabled -
func (*EnableEpochsHandlerStub) IsRefactorContextFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsRefactorContextFlagEnabled() bool
IsRefactorContextFlagEnabled -
func (*EnableEpochsHandlerStub) IsRefactorPeersMiniBlocksFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsRefactorPeersMiniBlocksFlagEnabled() bool
IsRefactorPeersMiniBlocksFlagEnabled -
func (*EnableEpochsHandlerStub) IsRelayedNonceFixEnabled ¶ added in v1.4.17
func (stub *EnableEpochsHandlerStub) IsRelayedNonceFixEnabled() bool
IsRelayedNonceFixEnabled -
func (*EnableEpochsHandlerStub) IsRelayedTransactionsFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsRelayedTransactionsFlagEnabled() bool
IsRelayedTransactionsFlagEnabled -
func (*EnableEpochsHandlerStub) IsRelayedTransactionsV2FlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsRelayedTransactionsV2FlagEnabled() bool
IsRelayedTransactionsV2FlagEnabled -
func (*EnableEpochsHandlerStub) IsRemoveNonUpdatedStorageFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsRemoveNonUpdatedStorageFlagEnabled() bool
IsRemoveNonUpdatedStorageFlagEnabled -
func (*EnableEpochsHandlerStub) IsRepairCallbackFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsRepairCallbackFlagEnabled() bool
IsRepairCallbackFlagEnabled -
func (*EnableEpochsHandlerStub) IsReturnDataToLastTransferFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsReturnDataToLastTransferFlagEnabled() bool
IsReturnDataToLastTransferFlagEnabled -
func (*EnableEpochsHandlerStub) IsRuntimeCodeSizeFixEnabled ¶ added in v1.4.9
func (stub *EnableEpochsHandlerStub) IsRuntimeCodeSizeFixEnabled() bool
IsRuntimeCodeSizeFixEnabled -
func (*EnableEpochsHandlerStub) IsRuntimeMemStoreLimitEnabled ¶
func (stub *EnableEpochsHandlerStub) IsRuntimeMemStoreLimitEnabled() bool
IsRuntimeMemStoreLimitEnabled -
func (*EnableEpochsHandlerStub) IsSCDeployFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsSCDeployFlagEnabled() bool
IsSCDeployFlagEnabled -
func (*EnableEpochsHandlerStub) IsSCRSizeInvariantCheckFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsSCRSizeInvariantCheckFlagEnabled() bool
IsSCRSizeInvariantCheckFlagEnabled -
func (*EnableEpochsHandlerStub) IsSCRSizeInvariantOnBuiltInResultFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsSCRSizeInvariantOnBuiltInResultFlagEnabled() bool
IsSCRSizeInvariantOnBuiltInResultFlagEnabled -
func (*EnableEpochsHandlerStub) IsSaveJailedAlwaysFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsSaveJailedAlwaysFlagEnabled() bool
IsSaveJailedAlwaysFlagEnabled -
func (*EnableEpochsHandlerStub) IsSaveToSystemAccountFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsSaveToSystemAccountFlagEnabled() bool
IsSaveToSystemAccountFlagEnabled -
func (*EnableEpochsHandlerStub) IsScheduledMiniBlocksFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsScheduledMiniBlocksFlagEnabled() bool
IsScheduledMiniBlocksFlagEnabled -
func (*EnableEpochsHandlerStub) IsSendAlwaysFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsSendAlwaysFlagEnabled() bool
IsSendAlwaysFlagEnabled -
func (*EnableEpochsHandlerStub) IsSenderInOutTransferFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsSenderInOutTransferFlagEnabled() bool
IsSenderInOutTransferFlagEnabled -
func (*EnableEpochsHandlerStub) IsSetGuardianEnabled ¶ added in v1.5.0
func (stub *EnableEpochsHandlerStub) IsSetGuardianEnabled() bool
IsSetGuardianEnabled -
func (*EnableEpochsHandlerStub) IsSetSenderInEeiOutputTransferFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsSetSenderInEeiOutputTransferFlagEnabled() bool
IsSetSenderInEeiOutputTransferFlagEnabled -
func (*EnableEpochsHandlerStub) IsStakeFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsStakeFlagEnabled() bool
IsStakeFlagEnabled -
func (*EnableEpochsHandlerStub) IsStakingV2FlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsStakingV2FlagEnabled() bool
IsStakingV2FlagEnabled -
func (*EnableEpochsHandlerStub) IsStakingV2FlagEnabledForActivationEpochCompleted ¶
func (stub *EnableEpochsHandlerStub) IsStakingV2FlagEnabledForActivationEpochCompleted() bool
IsStakingV2FlagEnabledForActivationEpochCompleted -
func (*EnableEpochsHandlerStub) IsStakingV2OwnerFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsStakingV2OwnerFlagEnabled() bool
IsStakingV2OwnerFlagEnabled -
func (*EnableEpochsHandlerStub) IsStopDecreasingValidatorRatingWhenStuckFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsStopDecreasingValidatorRatingWhenStuckFlagEnabled() bool
IsStopDecreasingValidatorRatingWhenStuckFlagEnabled -
func (*EnableEpochsHandlerStub) IsStorageAPICostOptimizationFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsStorageAPICostOptimizationFlagEnabled() bool
IsStorageAPICostOptimizationFlagEnabled -
func (*EnableEpochsHandlerStub) IsSwitchHysteresisForMinNodesFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsSwitchHysteresisForMinNodesFlagEnabled() bool
IsSwitchHysteresisForMinNodesFlagEnabled -
func (*EnableEpochsHandlerStub) IsSwitchHysteresisForMinNodesFlagEnabledForCurrentEpoch ¶
func (stub *EnableEpochsHandlerStub) IsSwitchHysteresisForMinNodesFlagEnabledForCurrentEpoch() bool
IsSwitchHysteresisForMinNodesFlagEnabledForCurrentEpoch -
func (*EnableEpochsHandlerStub) IsSwitchJailWaitingFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsSwitchJailWaitingFlagEnabled() bool
IsSwitchJailWaitingFlagEnabled -
func (*EnableEpochsHandlerStub) IsTransactionSignedWithTxHashFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsTransactionSignedWithTxHashFlagEnabled() bool
IsTransactionSignedWithTxHashFlagEnabled -
func (*EnableEpochsHandlerStub) IsTransferToMetaFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsTransferToMetaFlagEnabled() bool
IsTransferToMetaFlagEnabled -
func (*EnableEpochsHandlerStub) IsUnBondTokensV2FlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsUnBondTokensV2FlagEnabled() bool
IsUnBondTokensV2FlagEnabled -
func (*EnableEpochsHandlerStub) IsValidatorToDelegationFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsValidatorToDelegationFlagEnabled() bool
IsValidatorToDelegationFlagEnabled -
func (*EnableEpochsHandlerStub) IsValueLengthCheckFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsValueLengthCheckFlagEnabled() bool
IsValueLengthCheckFlagEnabled -
func (*EnableEpochsHandlerStub) IsWaitingListFixFlagEnabled ¶
func (stub *EnableEpochsHandlerStub) IsWaitingListFixFlagEnabled() bool
IsWaitingListFixFlagEnabled -
func (*EnableEpochsHandlerStub) IsWipeSingleNFTLiquidityDecreaseEnabled ¶
func (stub *EnableEpochsHandlerStub) IsWipeSingleNFTLiquidityDecreaseEnabled() bool
IsWipeSingleNFTLiquidityDecreaseEnabled -
func (*EnableEpochsHandlerStub) ManagedCryptoAPIEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) ManagedCryptoAPIEnableEpoch() uint32
ManagedCryptoAPIEnableEpoch -
func (*EnableEpochsHandlerStub) MiniBlockPartialExecutionEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) MiniBlockPartialExecutionEnableEpoch() uint32
MiniBlockPartialExecutionEnableEpoch -
func (*EnableEpochsHandlerStub) MultiESDTTransferAsyncCallBackEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) MultiESDTTransferAsyncCallBackEnableEpoch() uint32
MultiESDTTransferAsyncCallBackEnableEpoch -
func (*EnableEpochsHandlerStub) RefactorContextEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) RefactorContextEnableEpoch() uint32
RefactorContextEnableEpoch -
func (*EnableEpochsHandlerStub) RefactorPeersMiniBlocksEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) RefactorPeersMiniBlocksEnableEpoch() uint32
RefactorPeersMiniBlocksEnableEpoch -
func (*EnableEpochsHandlerStub) RemoveNonUpdatedStorageEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) RemoveNonUpdatedStorageEnableEpoch() uint32
RemoveNonUpdatedStorageEnableEpoch -
func (*EnableEpochsHandlerStub) ResetPenalizedTooMuchGasFlag ¶
func (stub *EnableEpochsHandlerStub) ResetPenalizedTooMuchGasFlag()
ResetPenalizedTooMuchGasFlag -
func (*EnableEpochsHandlerStub) ScheduledMiniBlocksEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) ScheduledMiniBlocksEnableEpoch() uint32
ScheduledMiniBlocksEnableEpoch -
func (*EnableEpochsHandlerStub) StakingV2EnableEpoch ¶
func (stub *EnableEpochsHandlerStub) StakingV2EnableEpoch() uint32
StakingV2EnableEpoch -
func (*EnableEpochsHandlerStub) StorageAPICostOptimizationEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) StorageAPICostOptimizationEnableEpoch() uint32
StorageAPICostOptimizationEnableEpoch -
func (*EnableEpochsHandlerStub) SwitchJailWaitingEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) SwitchJailWaitingEnableEpoch() uint32
SwitchJailWaitingEnableEpoch -
func (*EnableEpochsHandlerStub) WaitingListFixEnableEpoch ¶
func (stub *EnableEpochsHandlerStub) WaitingListFixEnableEpoch() uint32
WaitingListFixEnableEpoch -
type EnableRoundsHandlerStub ¶
type EnableRoundsHandlerStub struct { CheckRoundCalled func(round uint64) IsExampleEnabledChecked func() bool }
EnableRoundsHandlerStub -
func (*EnableRoundsHandlerStub) CheckRound ¶
func (stub *EnableRoundsHandlerStub) CheckRound(round uint64)
CheckRound -
func (*EnableRoundsHandlerStub) IsExampleEnabled ¶
func (stub *EnableRoundsHandlerStub) IsExampleEnabled() bool
IsExampleEnabled -
func (*EnableRoundsHandlerStub) IsInterfaceNil ¶
func (stub *EnableRoundsHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
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 EpochFinalityAttestingRoundCalled func() uint64 EpochStartMetaHdrHashCalled func() []byte }
EpochStartTriggerStub -
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) 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 ¶
func (e *EpochStartTriggerStub) MetaEpoch() uint32
MetaEpoch -
func (*EpochStartTriggerStub) NotifyAll ¶
func (e *EpochStartTriggerStub) NotifyAll(_ data.HeaderHandler)
NotifyAll -
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 ¶
func (e *EpochStartTriggerStub) SetAppStatusHandler(_ core.AppStatusHandler) error
SetAppStatusHandler -
func (*EpochStartTriggerStub) SetCurrentEpochStartRound ¶
func (e *EpochStartTriggerStub) SetCurrentEpochStartRound(_ uint64)
SetCurrentEpochStartRound -
func (*EpochStartTriggerStub) SetFinalityAttestingRound ¶
func (e *EpochStartTriggerStub) SetFinalityAttestingRound(_ uint64)
SetFinalityAttestingRound -
func (*EpochStartTriggerStub) SetProcessed ¶
func (e *EpochStartTriggerStub) SetProcessed(header data.HeaderHandler, _ data.BodyHandler)
SetProcessed -
func (*EpochStartTriggerStub) Update ¶
func (e *EpochStartTriggerStub) Update(round uint64, nonce uint64)
Update -
type EsdtStorageHandlerStub ¶
type EsdtStorageHandlerStub struct { SaveESDTNFTTokenCalled func(senderAddress []byte, acnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64, esdtData *esdt.ESDigitalToken, isCreation bool, isReturnWithError bool) ([]byte, error) GetESDTNFTTokenOnSenderCalled func(acnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64) (*esdt.ESDigitalToken, error) GetESDTNFTTokenOnDestinationCalled func(acnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64) (*esdt.ESDigitalToken, bool, error) GetESDTNFTTokenOnDestinationWithCustomSystemAccountCalled func(accnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64, systemAccount vmcommon.UserAccountHandler) (*esdt.ESDigitalToken, bool, error) WasAlreadySentToDestinationShardAndUpdateStateCalled func(tickerID []byte, nonce uint64, dstAddress []byte) (bool, error) SaveNFTMetaDataToSystemAccountCalled func(tx data.TransactionHandler) error AddToLiquiditySystemAccCalled func(esdtTokenKey []byte, nonce uint64, transferValue *big.Int) error }
EsdtStorageHandlerStub -
func (*EsdtStorageHandlerStub) AddToLiquiditySystemAcc ¶
func (e *EsdtStorageHandlerStub) AddToLiquiditySystemAcc(esdtTokenKey []byte, nonce uint64, transferValue *big.Int) error
AddToLiquiditySystemAcc -
func (*EsdtStorageHandlerStub) GetESDTNFTTokenOnDestination ¶
func (e *EsdtStorageHandlerStub) GetESDTNFTTokenOnDestination(acnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64) (*esdt.ESDigitalToken, bool, error)
GetESDTNFTTokenOnDestination -
func (*EsdtStorageHandlerStub) GetESDTNFTTokenOnDestinationWithCustomSystemAccount ¶
func (e *EsdtStorageHandlerStub) GetESDTNFTTokenOnDestinationWithCustomSystemAccount(accnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64, systemAccount vmcommon.UserAccountHandler) (*esdt.ESDigitalToken, bool, error)
GetESDTNFTTokenOnDestinationWithCustomSystemAccount -
func (*EsdtStorageHandlerStub) GetESDTNFTTokenOnSender ¶
func (e *EsdtStorageHandlerStub) GetESDTNFTTokenOnSender(acnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64) (*esdt.ESDigitalToken, error)
GetESDTNFTTokenOnSender -
func (*EsdtStorageHandlerStub) IsInterfaceNil ¶
func (e *EsdtStorageHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EsdtStorageHandlerStub) SaveESDTNFTToken ¶
func (e *EsdtStorageHandlerStub) SaveESDTNFTToken(senderAddress []byte, acnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64, esdtData *esdt.ESDigitalToken, isCreation bool, isReturnWithError bool) ([]byte, error)
SaveESDTNFTToken -
func (*EsdtStorageHandlerStub) SaveNFTMetaDataToSystemAccount ¶
func (e *EsdtStorageHandlerStub) SaveNFTMetaDataToSystemAccount(tx data.TransactionHandler) error
SaveNFTMetaDataToSystemAccount -
func (*EsdtStorageHandlerStub) WasAlreadySentToDestinationShardAndUpdateState ¶
func (e *EsdtStorageHandlerStub) WasAlreadySentToDestinationShardAndUpdateState(tickerID []byte, nonce uint64, dstAddress []byte) (bool, error)
WasAlreadySentToDestinationShardAndUpdateState -
type FallBackHeaderValidatorStub ¶
type FallBackHeaderValidatorStub struct {
ShouldApplyFallbackValidationCalled func(headerHandler data.HeaderHandler) bool
}
FallBackHeaderValidatorStub -
func (*FallBackHeaderValidatorStub) IsInterfaceNil ¶
func (fhvs *FallBackHeaderValidatorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*FallBackHeaderValidatorStub) ShouldApplyFallbackValidation ¶
func (fhvs *FallBackHeaderValidatorStub) ShouldApplyFallbackValidation(headerHandler data.HeaderHandler) bool
ShouldApplyFallbackValidation -
type FeeComputerStub ¶
type FeeComputerStub struct { ComputeTransactionFeeCalled func(tx *transaction.ApiTransactionResult) *big.Int ComputeGasUsedAndFeeBasedOnRefundValueCalled func(tx *transaction.ApiTransactionResult, refundValue *big.Int) (uint64, *big.Int) ComputeTxFeeBasedOnGasUsedCalled func(tx *transaction.ApiTransactionResult, gasUsed uint64) *big.Int ComputeGasLimitCalled func(tx *transaction.ApiTransactionResult) uint64 }
FeeComputerStub -
func (*FeeComputerStub) ComputeGasLimit ¶ added in v1.4.5
func (stub *FeeComputerStub) ComputeGasLimit(tx *transaction.ApiTransactionResult) uint64
ComputeGasLimit -
func (*FeeComputerStub) ComputeGasUsedAndFeeBasedOnRefundValue ¶ added in v1.4.5
func (stub *FeeComputerStub) ComputeGasUsedAndFeeBasedOnRefundValue(tx *transaction.ApiTransactionResult, refundValue *big.Int) (uint64, *big.Int)
ComputeGasUsedAndFeeBasedOnRefundValue -
func (*FeeComputerStub) ComputeTransactionFee ¶
func (stub *FeeComputerStub) ComputeTransactionFee(tx *transaction.ApiTransactionResult) *big.Int
ComputeTransactionFee -
func (*FeeComputerStub) ComputeTxFeeBasedOnGasUsed ¶ added in v1.4.5
func (stub *FeeComputerStub) ComputeTxFeeBasedOnGasUsed(tx *transaction.ApiTransactionResult, gasUsed uint64) *big.Int
ComputeTxFeeBasedOnGasUsed -
func (*FeeComputerStub) IsInterfaceNil ¶
func (stub *FeeComputerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type GasHandlerStub ¶
type GasHandlerStub struct { InitCalled func() ResetCalled func(key []byte) SetGasProvidedCalled func(gasProvided uint64, hash []byte) SetGasProvidedAsScheduledCalled func(gasProvided uint64, hash []byte) SetGasRefundedCalled func(gasRefunded uint64, hash []byte) SetGasPenalizedCalled func(gasPenalized uint64, hash []byte) GasProvidedCalled func(hash []byte) uint64 GasProvidedAsScheduledCalled func(hash []byte) uint64 GasRefundedCalled func(hash []byte) uint64 GasPenalizedCalled func(hash []byte) uint64 TotalGasProvidedCalled func() uint64 TotalGasProvidedAsScheduledCalled func() uint64 TotalGasProvidedWithScheduledCalled func() uint64 TotalGasRefundedCalled func() uint64 TotalGasPenalizedCalled func() uint64 RemoveGasProvidedCalled func(hashes [][]byte) RemoveGasProvidedAsScheduledCalled func(hashes [][]byte) RemoveGasRefundedCalled func(hashes [][]byte) RemoveGasPenalizedCalled func(hashes [][]byte) RestoreGasSinceLastResetCalled func(key []byte) ComputeGasProvidedByMiniBlockCalled func(miniBlock *block.MiniBlock, mapHashTx map[string]data.TransactionHandler) (uint64, uint64, error) ComputeGasProvidedByTxCalled func(txSenderShardId uint32, txReceiverSharedId uint32, txHandler data.TransactionHandler) (uint64, uint64, error) }
GasHandlerStub -
func (*GasHandlerStub) ComputeGasProvidedByMiniBlock ¶
func (ghs *GasHandlerStub) ComputeGasProvidedByMiniBlock(miniBlock *block.MiniBlock, mapHashTx map[string]data.TransactionHandler) (uint64, uint64, error)
ComputeGasProvidedByMiniBlock -
func (*GasHandlerStub) ComputeGasProvidedByTx ¶
func (ghs *GasHandlerStub) ComputeGasProvidedByTx(txSenderShardId uint32, txReceiverShardId uint32, txHandler data.TransactionHandler) (uint64, uint64, error)
ComputeGasProvidedByTx -
func (*GasHandlerStub) GasPenalized ¶
func (ghs *GasHandlerStub) GasPenalized(hash []byte) uint64
GasPenalized -
func (*GasHandlerStub) GasProvided ¶
func (ghs *GasHandlerStub) GasProvided(hash []byte) uint64
GasProvided -
func (*GasHandlerStub) GasProvidedAsScheduled ¶
func (ghs *GasHandlerStub) GasProvidedAsScheduled(hash []byte) uint64
GasProvidedAsScheduled -
func (*GasHandlerStub) GasRefunded ¶
func (ghs *GasHandlerStub) GasRefunded(hash []byte) uint64
GasRefunded -
func (*GasHandlerStub) IsInterfaceNil ¶
func (ghs *GasHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*GasHandlerStub) RemoveGasPenalized ¶
func (ghs *GasHandlerStub) RemoveGasPenalized(hashes [][]byte)
RemoveGasPenalized -
func (*GasHandlerStub) RemoveGasProvided ¶
func (ghs *GasHandlerStub) RemoveGasProvided(hashes [][]byte)
RemoveGasProvided -
func (*GasHandlerStub) RemoveGasProvidedAsScheduled ¶
func (ghs *GasHandlerStub) RemoveGasProvidedAsScheduled(hashes [][]byte)
RemoveGasProvidedAsScheduled -
func (*GasHandlerStub) RemoveGasRefunded ¶
func (ghs *GasHandlerStub) RemoveGasRefunded(hashes [][]byte)
RemoveGasRefunded -
func (*GasHandlerStub) RestoreGasSinceLastReset ¶
func (ghs *GasHandlerStub) RestoreGasSinceLastReset(key []byte)
RestoreGasSinceLastReset -
func (*GasHandlerStub) SetGasPenalized ¶
func (ghs *GasHandlerStub) SetGasPenalized(gasPenalized uint64, hash []byte)
SetGasPenalized -
func (*GasHandlerStub) SetGasProvided ¶
func (ghs *GasHandlerStub) SetGasProvided(gasProvided uint64, hash []byte)
SetGasProvided -
func (*GasHandlerStub) SetGasProvidedAsScheduled ¶
func (ghs *GasHandlerStub) SetGasProvidedAsScheduled(gasProvided uint64, hash []byte)
SetGasProvidedAsScheduled -
func (*GasHandlerStub) SetGasRefunded ¶
func (ghs *GasHandlerStub) SetGasRefunded(gasRefunded uint64, hash []byte)
SetGasRefunded -
func (*GasHandlerStub) TotalGasPenalized ¶
func (ghs *GasHandlerStub) TotalGasPenalized() uint64
TotalGasPenalized -
func (*GasHandlerStub) TotalGasProvided ¶
func (ghs *GasHandlerStub) TotalGasProvided() uint64
TotalGasProvided -
func (*GasHandlerStub) TotalGasProvidedAsScheduled ¶
func (ghs *GasHandlerStub) TotalGasProvidedAsScheduled() uint64
TotalGasProvidedAsScheduled -
func (*GasHandlerStub) TotalGasProvidedWithScheduled ¶
func (ghs *GasHandlerStub) TotalGasProvidedWithScheduled() uint64
TotalGasProvidedWithScheduled -
func (*GasHandlerStub) TotalGasRefunded ¶
func (ghs *GasHandlerStub) TotalGasRefunded() uint64
TotalGasRefunded -
type GasScheduleNotifierMock ¶
type GasScheduleNotifierMock struct { GasSchedule map[string]map[string]uint64 RegisterNotifyHandlerCalled func(handler core.GasScheduleSubscribeHandler) LatestGasScheduleCalled func() map[string]map[string]uint64 LatestGasScheduleCopyCalled func() map[string]map[string]uint64 }
GasScheduleNotifierMock -
func NewGasScheduleNotifierMock ¶
func NewGasScheduleNotifierMock(gasSchedule map[string]map[string]uint64) *GasScheduleNotifierMock
NewGasScheduleNotifierMock -
func (*GasScheduleNotifierMock) IsInterfaceNil ¶
func (g *GasScheduleNotifierMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*GasScheduleNotifierMock) LatestGasSchedule ¶
func (g *GasScheduleNotifierMock) LatestGasSchedule() map[string]map[string]uint64
LatestGasSchedule -
func (*GasScheduleNotifierMock) LatestGasScheduleCopy ¶
func (g *GasScheduleNotifierMock) LatestGasScheduleCopy() map[string]map[string]uint64
LatestGasScheduleCopy -
func (*GasScheduleNotifierMock) RegisterNotifyHandler ¶
func (g *GasScheduleNotifierMock) RegisterNotifyHandler(handler core.GasScheduleSubscribeHandler)
RegisterNotifyHandler -
func (*GasScheduleNotifierMock) UnRegisterAll ¶
func (g *GasScheduleNotifierMock) UnRegisterAll()
UnRegisterAll -
type HardforkTriggerStub ¶
type HardforkTriggerStub struct { SetExportFactoryHandlerCalled func(exportFactoryHandler update.ExportFactoryHandler) error 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 NotifyTriggerReceivedV2Called func() <-chan struct{} }
HardforkTriggerStub -
func (*HardforkTriggerStub) AddCloser ¶
func (hts *HardforkTriggerStub) AddCloser(closer update.Closer) error
AddCloser -
func (*HardforkTriggerStub) CreateData ¶
func (hts *HardforkTriggerStub) CreateData() []byte
CreateData -
func (*HardforkTriggerStub) IsInterfaceNil ¶
func (hts *HardforkTriggerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HardforkTriggerStub) IsSelfTrigger ¶
func (hts *HardforkTriggerStub) IsSelfTrigger() bool
IsSelfTrigger -
func (*HardforkTriggerStub) NotifyTriggerReceivedV2 ¶
func (hts *HardforkTriggerStub) NotifyTriggerReceivedV2() <-chan struct{}
NotifyTriggerReceivedV2 -
func (*HardforkTriggerStub) RecordedTriggerMessage ¶
func (hts *HardforkTriggerStub) RecordedTriggerMessage() ([]byte, bool)
RecordedTriggerMessage -
func (*HardforkTriggerStub) SetExportFactoryHandler ¶
func (hts *HardforkTriggerStub) SetExportFactoryHandler(exportFactoryHandler update.ExportFactoryHandler) error
SetExportFactoryHandler -
func (*HardforkTriggerStub) Trigger ¶
func (hts *HardforkTriggerStub) Trigger(epoch uint32, withEarlyEndOfEpoch bool) error
Trigger -
func (*HardforkTriggerStub) TriggerReceived ¶
func (hts *HardforkTriggerStub) TriggerReceived(payload []byte, data []byte, pkBytes []byte) (bool, error)
TriggerReceived -
type HasherStub ¶
type HasherStub struct { ComputeCalled func(s string) []byte EmptyHashCalled func() []byte SizeCalled func() int }
HasherStub -
func (*HasherStub) IsInterfaceNil ¶
func (hash *HasherStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type HeaderHandlerStub ¶
type HeaderHandlerStub struct { EpochField uint32 TimestampField uint64 GetMiniBlockHeadersWithDstCalled func(destId uint32) map[string]uint32 GetOrderedCrossMiniblocksWithDstCalled func(destId uint32) []*data.MiniBlockInfo GetPubKeysBitmapCalled func() []byte GetSignatureCalled func() []byte GetRootHashCalled func() []byte GetRandSeedCalled func() []byte GetPrevRandSeedCalled func() []byte GetPrevHashCalled func() []byte CloneCalled func() data.HeaderHandler GetChainIDCalled func() []byte CheckChainIDCalled func(reference []byte) error GetReservedCalled func() []byte IsStartOfEpochBlockCalled func() bool HasScheduledMiniBlocksCalled func() bool GetNonceCalled func() uint64 CheckFieldsForNilCalled func() error }
HeaderHandlerStub -
func (*HeaderHandlerStub) CheckFieldsForNil ¶ added in v1.4.6
func (hhs *HeaderHandlerStub) CheckFieldsForNil() error
CheckFieldsForNil -
func (*HeaderHandlerStub) GetAccumulatedFees ¶
func (hhs *HeaderHandlerStub) GetAccumulatedFees() *big.Int
GetAccumulatedFees -
func (*HeaderHandlerStub) GetAdditionalData ¶
func (hhs *HeaderHandlerStub) GetAdditionalData() headerVersionData.HeaderAdditionalData
GetAdditionalData gets the additional version-related data
func (*HeaderHandlerStub) GetBlockBodyTypeInt32 ¶
func (hhs *HeaderHandlerStub) GetBlockBodyTypeInt32() int32
GetBlockBodyTypeInt32 -
func (*HeaderHandlerStub) GetChainID ¶
func (hhs *HeaderHandlerStub) GetChainID() []byte
GetChainID -
func (*HeaderHandlerStub) GetDevFeesInEpoch ¶
func (hhs *HeaderHandlerStub) GetDevFeesInEpoch() *big.Int
GetDevFeesInEpoch -
func (*HeaderHandlerStub) GetDeveloperFees ¶
func (hhs *HeaderHandlerStub) GetDeveloperFees() *big.Int
GetDeveloperFees -
func (*HeaderHandlerStub) GetEpochStartHandler ¶
func (hhs *HeaderHandlerStub) GetEpochStartHandler() data.EpochStartHandler
GetEpochStartHandler -
func (*HeaderHandlerStub) GetEpochStartMetaHash ¶
func (hhs *HeaderHandlerStub) GetEpochStartMetaHash() []byte
GetEpochStartMetaHash -
func (*HeaderHandlerStub) GetLeaderSignature ¶
func (hhs *HeaderHandlerStub) GetLeaderSignature() []byte
GetLeaderSignature -
func (*HeaderHandlerStub) GetMetaBlockHashes ¶
func (hhs *HeaderHandlerStub) GetMetaBlockHashes() [][]byte
GetMetaBlockHashes -
func (*HeaderHandlerStub) GetMiniBlockHeaderHandlers ¶
func (hhs *HeaderHandlerStub) GetMiniBlockHeaderHandlers() []data.MiniBlockHeaderHandler
GetMiniBlockHeaderHandlers -
func (*HeaderHandlerStub) GetMiniBlockHeadersHashes ¶
func (hhs *HeaderHandlerStub) GetMiniBlockHeadersHashes() [][]byte
GetMiniBlockHeadersHashes -
func (*HeaderHandlerStub) GetMiniBlockHeadersWithDst ¶
func (hhs *HeaderHandlerStub) GetMiniBlockHeadersWithDst(destId uint32) map[string]uint32
GetMiniBlockHeadersWithDst -
func (*HeaderHandlerStub) GetOrderedCrossMiniblocksWithDst ¶
func (hhs *HeaderHandlerStub) GetOrderedCrossMiniblocksWithDst(destId uint32) []*data.MiniBlockInfo
GetOrderedCrossMiniblocksWithDst -
func (*HeaderHandlerStub) GetPrevHash ¶
func (hhs *HeaderHandlerStub) GetPrevHash() []byte
GetPrevHash -
func (*HeaderHandlerStub) GetPrevRandSeed ¶
func (hhs *HeaderHandlerStub) GetPrevRandSeed() []byte
GetPrevRandSeed -
func (*HeaderHandlerStub) GetPubKeysBitmap ¶
func (hhs *HeaderHandlerStub) GetPubKeysBitmap() []byte
GetPubKeysBitmap -
func (*HeaderHandlerStub) GetRandSeed ¶
func (hhs *HeaderHandlerStub) GetRandSeed() []byte
GetRandSeed -
func (*HeaderHandlerStub) GetReceiptsHash ¶
func (hhs *HeaderHandlerStub) GetReceiptsHash() []byte
GetReceiptsHash -
func (*HeaderHandlerStub) GetReserved ¶
func (hhs *HeaderHandlerStub) GetReserved() []byte
GetReserved -
func (*HeaderHandlerStub) GetRootHash ¶
func (hhs *HeaderHandlerStub) GetRootHash() []byte
GetRootHash -
func (*HeaderHandlerStub) GetShardID ¶
func (hhs *HeaderHandlerStub) GetShardID() uint32
GetShardID -
func (*HeaderHandlerStub) GetShardInfoHandlers ¶
func (hhs *HeaderHandlerStub) GetShardInfoHandlers() []data.ShardDataHandler
GetShardInfoHandlers -
func (*HeaderHandlerStub) GetSignature ¶
func (hhs *HeaderHandlerStub) GetSignature() []byte
GetSignature -
func (*HeaderHandlerStub) GetSoftwareVersion ¶
func (hhs *HeaderHandlerStub) GetSoftwareVersion() []byte
GetSoftwareVersion -
func (*HeaderHandlerStub) GetTimeStamp ¶
func (hhs *HeaderHandlerStub) GetTimeStamp() uint64
GetTimeStamp -
func (*HeaderHandlerStub) GetTxCount ¶
func (hhs *HeaderHandlerStub) GetTxCount() uint32
GetTxCount -
func (*HeaderHandlerStub) GetValidatorStatsRootHash ¶
func (hhs *HeaderHandlerStub) GetValidatorStatsRootHash() []byte
GetValidatorStatsRootHash -
func (*HeaderHandlerStub) HasScheduledMiniBlocks ¶
func (hhs *HeaderHandlerStub) HasScheduledMiniBlocks() bool
HasScheduledMiniBlocks -
func (*HeaderHandlerStub) HasScheduledSupport ¶
func (hhs *HeaderHandlerStub) HasScheduledSupport() bool
HasScheduledSupport -
func (*HeaderHandlerStub) IsInterfaceNil ¶
func (hhs *HeaderHandlerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*HeaderHandlerStub) IsStartOfEpochBlock ¶
func (hhs *HeaderHandlerStub) IsStartOfEpochBlock() bool
IsStartOfEpochBlock -
func (*HeaderHandlerStub) MapMiniBlockHashesToShards ¶
func (hhs *HeaderHandlerStub) MapMiniBlockHashesToShards() map[string]uint32
MapMiniBlockHashesToShards -
func (*HeaderHandlerStub) SetAccumulatedFees ¶
func (hhs *HeaderHandlerStub) SetAccumulatedFees(_ *big.Int) error
SetAccumulatedFees -
func (*HeaderHandlerStub) SetAccumulatedFeesInEpoch ¶
func (hhs *HeaderHandlerStub) SetAccumulatedFeesInEpoch(_ *big.Int) error
SetAccumulatedFeesInEpoch -
func (*HeaderHandlerStub) SetAdditionalData ¶
func (hhs *HeaderHandlerStub) SetAdditionalData(_ headerVersionData.HeaderAdditionalData) error
SetAdditionalData sets the additional version-related data
func (*HeaderHandlerStub) SetChainID ¶
func (hhs *HeaderHandlerStub) SetChainID(_ []byte) error
SetChainID -
func (*HeaderHandlerStub) SetDevFeesInEpoch ¶
func (hhs *HeaderHandlerStub) SetDevFeesInEpoch(_ *big.Int) error
SetDevFeesInEpoch -
func (*HeaderHandlerStub) SetDeveloperFees ¶
func (hhs *HeaderHandlerStub) SetDeveloperFees(_ *big.Int) error
SetDeveloperFees -
func (*HeaderHandlerStub) SetEpoch ¶
func (hhs *HeaderHandlerStub) SetEpoch(_ uint32) error
SetEpoch -
func (*HeaderHandlerStub) SetEpochStartMetaHash ¶
func (hhs *HeaderHandlerStub) SetEpochStartMetaHash(_ []byte) error
SetEpochStartMetaHash -
func (*HeaderHandlerStub) SetLeaderSignature ¶
func (hhs *HeaderHandlerStub) SetLeaderSignature(_ []byte) error
SetLeaderSignature -
func (*HeaderHandlerStub) SetMetaBlockHashes ¶
func (hhs *HeaderHandlerStub) SetMetaBlockHashes(_ [][]byte) error
SetMetaBlockHashes -
func (*HeaderHandlerStub) SetMiniBlockHeaderHandlers ¶
func (hhs *HeaderHandlerStub) SetMiniBlockHeaderHandlers(_ []data.MiniBlockHeaderHandler) error
SetMiniBlockHeaderHandlers -
func (*HeaderHandlerStub) SetNonce ¶
func (hhs *HeaderHandlerStub) SetNonce(_ uint64) error
SetNonce -
func (*HeaderHandlerStub) SetPrevHash ¶
func (hhs *HeaderHandlerStub) SetPrevHash(_ []byte) error
SetPrevHash -
func (*HeaderHandlerStub) SetPrevRandSeed ¶
func (hhs *HeaderHandlerStub) SetPrevRandSeed(_ []byte) error
SetPrevRandSeed -
func (*HeaderHandlerStub) SetPubKeysBitmap ¶
func (hhs *HeaderHandlerStub) SetPubKeysBitmap(_ []byte) error
SetPubKeysBitmap -
func (*HeaderHandlerStub) SetRandSeed ¶
func (hhs *HeaderHandlerStub) SetRandSeed(_ []byte) error
SetRandSeed -
func (*HeaderHandlerStub) SetReceiptsHash ¶
func (hhs *HeaderHandlerStub) SetReceiptsHash(_ []byte) error
SetReceiptsHash -
func (*HeaderHandlerStub) SetRootHash ¶
func (hhs *HeaderHandlerStub) SetRootHash(_ []byte) error
SetRootHash -
func (*HeaderHandlerStub) SetRound ¶
func (hhs *HeaderHandlerStub) SetRound(_ uint64) error
SetRound -
func (*HeaderHandlerStub) SetScheduledRootHash ¶
func (hhs *HeaderHandlerStub) SetScheduledRootHash(_ []byte) error
SetScheduledRootHash -
func (*HeaderHandlerStub) SetShardID ¶
func (hhs *HeaderHandlerStub) SetShardID(_ uint32) error
SetShardID -
func (*HeaderHandlerStub) SetShardInfoHandlers ¶
func (hhs *HeaderHandlerStub) SetShardInfoHandlers(_ []data.ShardDataHandler) error
SetShardInfoHandlers -
func (*HeaderHandlerStub) SetSignature ¶
func (hhs *HeaderHandlerStub) SetSignature(_ []byte) error
SetSignature -
func (*HeaderHandlerStub) SetSoftwareVersion ¶
func (hhs *HeaderHandlerStub) SetSoftwareVersion(_ []byte) error
SetSoftwareVersion -
func (*HeaderHandlerStub) SetTimeStamp ¶
func (hhs *HeaderHandlerStub) SetTimeStamp(_ uint64) error
SetTimeStamp -
func (*HeaderHandlerStub) SetTxCount ¶
func (hhs *HeaderHandlerStub) SetTxCount(_ uint32) error
SetTxCount -
func (*HeaderHandlerStub) SetValidatorStatsRootHash ¶
func (hhs *HeaderHandlerStub) SetValidatorStatsRootHash(_ []byte) error
SetValidatorStatsRootHash -
func (*HeaderHandlerStub) ShallowClone ¶
func (hhs *HeaderHandlerStub) ShallowClone() data.HeaderHandler
ShallowClone -
func (*HeaderHandlerStub) ValidateHeaderVersion ¶
func (hhs *HeaderHandlerStub) ValidateHeaderVersion() error
ValidateHeaderVersion -
type HeaderVersionHandlerStub ¶
type HeaderVersionHandlerStub struct { GetVersionCalled func(epoch uint32) string VerifyCalled func(hdr data.HeaderHandler) error IsInterfaceNilCalled func() bool }
HeaderVersionHandlerStub -
func (*HeaderVersionHandlerStub) GetVersion ¶
func (hvm *HeaderVersionHandlerStub) GetVersion(epoch uint32) string
GetVersion -
func (*HeaderVersionHandlerStub) IsInterfaceNil ¶
func (hvm *HeaderVersionHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HeaderVersionHandlerStub) Verify ¶
func (hvm *HeaderVersionHandlerStub) Verify(hdr data.HeaderHandler) error
Verify -
type ImportStartHandlerStub ¶
type ImportStartHandlerStub struct { SetStartImportCalled func() error ResetStartImportCalled func() error IsAfterExportBeforeImportCalled func() bool ShouldStartImportCalled func() bool }
ImportStartHandlerStub -
func (*ImportStartHandlerStub) IsAfterExportBeforeImport ¶
func (ish *ImportStartHandlerStub) IsAfterExportBeforeImport() bool
IsAfterExportBeforeImport -
func (*ImportStartHandlerStub) IsInterfaceNil ¶
func (ish *ImportStartHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ImportStartHandlerStub) ResetStartImport ¶
func (ish *ImportStartHandlerStub) ResetStartImport() error
ResetStartImport -
func (*ImportStartHandlerStub) SetStartImport ¶
func (ish *ImportStartHandlerStub) SetStartImport() error
SetStartImport -
func (*ImportStartHandlerStub) ShouldStartImport ¶
func (ish *ImportStartHandlerStub) ShouldStartImport() bool
ShouldStartImport -
type InterceptedDataStub ¶
type InterceptedDataStub struct { CheckValidityCalled func() error IsForCurrentShardCalled func() bool HashCalled func() []byte TypeCalled func() string IdentifiersCalled func() [][]byte StringCalled func() string }
InterceptedDataStub -
func (*InterceptedDataStub) CheckValidity ¶
func (ids *InterceptedDataStub) CheckValidity() error
CheckValidity -
func (*InterceptedDataStub) Identifiers ¶
func (ids *InterceptedDataStub) Identifiers() [][]byte
Identifiers -
func (*InterceptedDataStub) IsForCurrentShard ¶
func (ids *InterceptedDataStub) IsForCurrentShard() bool
IsForCurrentShard -
func (*InterceptedDataStub) IsInterfaceNil ¶
func (ids *InterceptedDataStub) IsInterfaceNil() bool
IsInterfaceNil -
type InterceptorStub ¶
type InterceptorStub struct { ProcessReceivedMessageCalled func(message p2p.MessageP2P) error SetInterceptedDebugHandlerCalled func(debugger process.InterceptedDebugger) error RegisterHandlerCalled func(handler func(topic string, hash []byte, data interface{})) CloseCalled func() error }
InterceptorStub -
func (*InterceptorStub) IsInterfaceNil ¶
func (is *InterceptorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*InterceptorStub) ProcessReceivedMessage ¶
func (is *InterceptorStub) ProcessReceivedMessage(message p2p.MessageP2P, _ core.PeerID) error
ProcessReceivedMessage -
func (*InterceptorStub) RegisterHandler ¶
func (is *InterceptorStub) RegisterHandler(handler func(topic string, hash []byte, data interface{}))
RegisterHandler -
func (*InterceptorStub) SetInterceptedDebugHandler ¶
func (is *InterceptorStub) SetInterceptedDebugHandler(debugger process.InterceptedDebugger) error
SetInterceptedDebugHandler -
type InterceptorsContainerStub ¶
type InterceptorsContainerStub struct { IterateCalled func(handler func(key string, interceptor process.Interceptor) bool) GetCalled func(string) (process.Interceptor, error) AddCalled func(key string, interceptor process.Interceptor) error AddMultipleCalled func(keys []string, interceptors []process.Interceptor) error ReplaceCalled func(key string, interceptor process.Interceptor) error RemoveCalled func(key string) LenCalled func() int CloseCalled func() error }
InterceptorsContainerStub -
func (*InterceptorsContainerStub) Add ¶
func (ics *InterceptorsContainerStub) Add(key string, interceptor process.Interceptor) error
Add -
func (*InterceptorsContainerStub) AddMultiple ¶
func (ics *InterceptorsContainerStub) AddMultiple(keys []string, interceptors []process.Interceptor) error
AddMultiple -
func (*InterceptorsContainerStub) Close ¶
func (ics *InterceptorsContainerStub) Close() error
Close -
func (*InterceptorsContainerStub) Get ¶
func (ics *InterceptorsContainerStub) Get(topic string) (process.Interceptor, error)
Get -
func (*InterceptorsContainerStub) IsInterfaceNil ¶
func (ics *InterceptorsContainerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*InterceptorsContainerStub) Iterate ¶
func (ics *InterceptorsContainerStub) Iterate(handler func(key string, interceptor process.Interceptor) bool)
Iterate -
func (*InterceptorsContainerStub) Remove ¶
func (ics *InterceptorsContainerStub) Remove(key string)
Remove -
func (*InterceptorsContainerStub) Replace ¶
func (ics *InterceptorsContainerStub) Replace(key string, interceptor process.Interceptor) error
Replace -
type KeccakMock ¶
type KeccakMock struct { }
KeccakMock is a sha3-Keccak implementation of the hasher interface.
func (KeccakMock) Compute ¶
func (k KeccakMock) Compute(s string) []byte
Compute takes a string, and returns the sha3-Keccak hash of that string
func (KeccakMock) EmptyHash ¶
func (k KeccakMock) EmptyHash() []byte
EmptyHash returns the sha3-Keccak hash of the empty string
func (KeccakMock) IsInterfaceNil ¶
func (k KeccakMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (KeccakMock) Size ¶
func (KeccakMock) Size() int
Size returns the size, in number of bytes, of a sha3-Keccak hash
type LoggerStub ¶
type LoggerStub struct { TraceCalled func(message string, args ...interface{}) DebugCalled func(message string, args ...interface{}) InfoCalled func(message string, args ...interface{}) WarnCalled func(message string, args ...interface{}) ErrorCalled func(message string, args ...interface{}) LogIfErrorCalled func(err error, args ...interface{}) LogCalled func(logLevel logger.LogLevel, message string, args ...interface{}) LogLineCalled func(line *logger.LogLine) SetLevelCalled func(logLevel logger.LogLevel) GetLevelCalled func() logger.LogLevel }
LoggerStub -
func (*LoggerStub) Debug ¶
func (stub *LoggerStub) Debug(message string, args ...interface{})
Debug -
func (*LoggerStub) Error ¶
func (stub *LoggerStub) Error(message string, args ...interface{})
Error -
func (*LoggerStub) Log ¶
func (stub *LoggerStub) Log(logLevel logger.LogLevel, message string, args ...interface{})
Log -
func (*LoggerStub) LogIfError ¶
func (stub *LoggerStub) LogIfError(err error, args ...interface{})
LogIfError -
func (*LoggerStub) Trace ¶
func (stub *LoggerStub) Trace(message string, args ...interface{})
Trace -
type LogsFacadeStub ¶
type LogsFacadeStub struct { GetLogCalled func(txHash []byte, epoch uint32) (*transaction.ApiLogs, error) IncludeLogsInTransactionsCalled func(txs []*transaction.ApiTransactionResult, logsKeys [][]byte, epoch uint32) error }
LogsFacadeStub -
func (*LogsFacadeStub) GetLog ¶
func (stub *LogsFacadeStub) GetLog(logKey []byte, epoch uint32) (*transaction.ApiLogs, error)
GetLog -
func (*LogsFacadeStub) IncludeLogsInTransactions ¶
func (stub *LogsFacadeStub) IncludeLogsInTransactions(txs []*transaction.ApiTransactionResult, logsKeys [][]byte, epoch uint32) error
IncludeLogsInTransactions -
func (*LogsFacadeStub) IsInterfaceNil ¶
func (stub *LogsFacadeStub) IsInterfaceNil() bool
IsInterfaceNil -
type MarshalizerMock ¶
type MarshalizerMock struct {
Fail bool
}
MarshalizerMock that will be used for testing
func (MarshalizerMock) IsInterfaceNil ¶
func (mm MarshalizerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (MarshalizerMock) Marshal ¶
func (mm MarshalizerMock) Marshal(obj interface{}) ([]byte, error)
Marshal converts the input object in a slice of bytes
func (MarshalizerMock) Unmarshal ¶
func (mm MarshalizerMock) Unmarshal(obj interface{}, buff []byte) error
Unmarshal applies the serialized values over an instantiated object
type MarshalizerStub ¶
type MarshalizerStub struct { MarshalCalled func(obj interface{}) ([]byte, error) UnmarshalCalled func(obj interface{}, buff []byte) error }
MarshalizerStub -
func (*MarshalizerStub) IsInterfaceNil ¶
func (ms *MarshalizerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*MarshalizerStub) Marshal ¶
func (ms *MarshalizerStub) Marshal(obj interface{}) ([]byte, error)
Marshal -
func (*MarshalizerStub) Unmarshal ¶
func (ms *MarshalizerStub) Unmarshal(obj interface{}, buff []byte) error
Unmarshal -
type MemDbMock ¶
type MemDbMock struct { PutCalled func(key, val []byte) error GetCalled func(key []byte) ([]byte, error) // contains filtered or unexported fields }
MemDbMock represents the memory database storage. It holds a map of key value pairs and a mutex to handle concurrent accesses to the map
func (*MemDbMock) DestroyClosed ¶
DestroyClosed removes the already closed storage medium stored data
func (*MemDbMock) Has ¶
Has returns true if the given key is present in the persistence medium, false otherwise
func (*MemDbMock) IsInterfaceNil ¶
IsInterfaceNil returns true if there is no value under the interface
type MessageSignVerifierMock ¶
type MessageSignVerifierMock struct { }
MessageSignVerifierMock -
func (*MessageSignVerifierMock) IsInterfaceNil ¶
func (m *MessageSignVerifierMock) IsInterfaceNil() bool
IsInterfaceNil -
type NodesSetupStub ¶
type NodesSetupStub struct { InitialNodesPubKeysCalled func() map[uint32][]string InitialEligibleNodesPubKeysForShardCalled func(shardId uint32) ([]string, error) GetShardIDForPubKeyCalled func(pubKey []byte) (uint32, error) NumberOfShardsCalled func() uint32 GetShardConsensusGroupSizeCalled func() uint32 GetMetaConsensusGroupSizeCalled func() uint32 GetRoundDurationCalled func() uint64 MinNumberOfMetaNodesCalled func() uint32 MinNumberOfShardNodesCalled func() uint32 GetHysteresisCalled func() float32 GetAdaptivityCalled func() bool InitialNodesInfoForShardCalled func(shardId uint32) ([]nodesCoordinator.GenesisNodeInfoHandler, []nodesCoordinator.GenesisNodeInfoHandler, error) InitialNodesInfoCalled func() (map[uint32][]nodesCoordinator.GenesisNodeInfoHandler, map[uint32][]nodesCoordinator.GenesisNodeInfoHandler) GetStartTimeCalled func() int64 MinNumberOfNodesCalled func() uint32 AllInitialNodesCalled func() []nodesCoordinator.GenesisNodeInfoHandler MinNumberOfNodesWithHysteresisCalled func() uint32 }
NodesSetupStub -
func (*NodesSetupStub) AllInitialNodes ¶
func (n *NodesSetupStub) AllInitialNodes() []nodesCoordinator.GenesisNodeInfoHandler
AllInitialNodes -
func (*NodesSetupStub) GetAdaptivity ¶
func (n *NodesSetupStub) GetAdaptivity() bool
GetAdaptivity -
func (*NodesSetupStub) GetHysteresis ¶
func (n *NodesSetupStub) GetHysteresis() float32
GetHysteresis -
func (*NodesSetupStub) GetMetaConsensusGroupSize ¶
func (n *NodesSetupStub) GetMetaConsensusGroupSize() uint32
GetMetaConsensusGroupSize -
func (*NodesSetupStub) GetRoundDuration ¶
func (n *NodesSetupStub) GetRoundDuration() uint64
GetRoundDuration -
func (*NodesSetupStub) GetShardConsensusGroupSize ¶
func (n *NodesSetupStub) GetShardConsensusGroupSize() uint32
GetShardConsensusGroupSize -
func (*NodesSetupStub) GetShardIDForPubKey ¶
func (n *NodesSetupStub) GetShardIDForPubKey(pubkey []byte) (uint32, error)
GetShardIDForPubKey -
func (*NodesSetupStub) InitialEligibleNodesPubKeysForShard ¶
func (n *NodesSetupStub) InitialEligibleNodesPubKeysForShard(shardId uint32) ([]string, error)
InitialEligibleNodesPubKeysForShard -
func (*NodesSetupStub) InitialNodesInfo ¶
func (n *NodesSetupStub) InitialNodesInfo() (map[uint32][]nodesCoordinator.GenesisNodeInfoHandler, map[uint32][]nodesCoordinator.GenesisNodeInfoHandler)
InitialNodesInfo -
func (*NodesSetupStub) InitialNodesInfoForShard ¶
func (n *NodesSetupStub) InitialNodesInfoForShard( shardId uint32, ) ([]nodesCoordinator.GenesisNodeInfoHandler, []nodesCoordinator.GenesisNodeInfoHandler, error)
InitialNodesInfoForShard -
func (*NodesSetupStub) InitialNodesPubKeys ¶
func (n *NodesSetupStub) InitialNodesPubKeys() map[uint32][]string
InitialNodesPubKeys -
func (*NodesSetupStub) IsInterfaceNil ¶
func (n *NodesSetupStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*NodesSetupStub) MinNumberOfMetaNodes ¶
func (n *NodesSetupStub) MinNumberOfMetaNodes() uint32
MinNumberOfMetaNodes -
func (*NodesSetupStub) MinNumberOfNodes ¶
func (n *NodesSetupStub) MinNumberOfNodes() uint32
MinNumberOfNodes -
func (*NodesSetupStub) MinNumberOfNodesWithHysteresis ¶
func (n *NodesSetupStub) MinNumberOfNodesWithHysteresis() uint32
MinNumberOfNodesWithHysteresis -
func (*NodesSetupStub) MinNumberOfShardNodes ¶
func (n *NodesSetupStub) MinNumberOfShardNodes() uint32
MinNumberOfShardNodes -
func (*NodesSetupStub) NumberOfShards ¶
func (n *NodesSetupStub) NumberOfShards() uint32
NumberOfShards -
type OldDataCleanerProviderStub ¶
type OldDataCleanerProviderStub struct {
ShouldCleanCalled func() bool
}
OldDataCleanerProviderStub -
func (*OldDataCleanerProviderStub) IsInterfaceNil ¶
func (o *OldDataCleanerProviderStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*OldDataCleanerProviderStub) ShouldClean ¶
func (o *OldDataCleanerProviderStub) ShouldClean() bool
ShouldClean -
type PanicDoubleTransactionsDetector ¶
type PanicDoubleTransactionsDetector struct { }
PanicDoubleTransactionsDetector -
func (*PanicDoubleTransactionsDetector) IsInterfaceNil ¶
func (detector *PanicDoubleTransactionsDetector) IsInterfaceNil() bool
IsInterfaceNil -
func (*PanicDoubleTransactionsDetector) ProcessBlockBody ¶
func (detector *PanicDoubleTransactionsDetector) ProcessBlockBody(body *block.Body)
ProcessBlockBody -
type PathManagerStub ¶
type PathManagerStub struct { PathForEpochCalled func(shardId string, epoch uint32, identifier string) string PathForStaticCalled func(shardId string, identifier string) string DatabasePathCalled func() string }
PathManagerStub -
func (*PathManagerStub) DatabasePath ¶
func (p *PathManagerStub) DatabasePath() string
DatabasePath -
func (*PathManagerStub) IsInterfaceNil ¶
func (p *PathManagerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*PathManagerStub) PathForEpoch ¶
func (p *PathManagerStub) PathForEpoch(shardId string, epoch uint32, identifier string) string
PathForEpoch -
func (*PathManagerStub) PathForStatic ¶
func (p *PathManagerStub) PathForStatic(shardId string, identifier string) string
PathForStatic -
type PeerAuthenticationPayloadValidatorStub ¶
type PeerAuthenticationPayloadValidatorStub struct {
ValidateTimestampCalled func(payloadTimestamp int64) error
}
PeerAuthenticationPayloadValidatorStub -
func (*PeerAuthenticationPayloadValidatorStub) IsInterfaceNil ¶
func (stub *PeerAuthenticationPayloadValidatorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*PeerAuthenticationPayloadValidatorStub) ValidateTimestamp ¶
func (stub *PeerAuthenticationPayloadValidatorStub) ValidateTimestamp(payloadTimestamp int64) error
ValidateTimestamp -
type PeerHonestyHandlerStub ¶
PeerHonestyHandlerStub -
func (*PeerHonestyHandlerStub) ChangeScore ¶
func (phhs *PeerHonestyHandlerStub) ChangeScore(pk string, topic string, units int)
ChangeScore -
func (*PeerHonestyHandlerStub) IsInterfaceNil ¶
func (phhs *PeerHonestyHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
type PreProcessorExecutionInfoHandlerMock ¶
type PreProcessorExecutionInfoHandlerMock struct { GetNumOfCrossInterMbsAndTxsCalled func() (int, int) InitProcessedTxsResultsCalled func(key []byte) RevertProcessedTxsResultsCalled func(txHashes [][]byte, key []byte) }
PreProcessorExecutionInfoHandlerMock -
func (*PreProcessorExecutionInfoHandlerMock) GetNumOfCrossInterMbsAndTxs ¶
func (ppeihm *PreProcessorExecutionInfoHandlerMock) GetNumOfCrossInterMbsAndTxs() (int, int)
GetNumOfCrossInterMbsAndTxs -
func (*PreProcessorExecutionInfoHandlerMock) InitProcessedTxsResults ¶
func (ppeihm *PreProcessorExecutionInfoHandlerMock) InitProcessedTxsResults(key []byte)
InitProcessedTxsResults -
func (*PreProcessorExecutionInfoHandlerMock) RevertProcessedTxsResults ¶
func (ppeihm *PreProcessorExecutionInfoHandlerMock) RevertProcessedTxsResults(txHashes [][]byte, key []byte)
RevertProcessedTxsResults -
type ProcessDebuggerStub ¶
type ProcessDebuggerStub struct { SetLastCommittedBlockRoundCalled func(round uint64) CloseCalled func() error }
ProcessDebuggerStub -
func (*ProcessDebuggerStub) IsInterfaceNil ¶
func (stub *ProcessDebuggerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ProcessDebuggerStub) SetLastCommittedBlockRound ¶
func (stub *ProcessDebuggerStub) SetLastCommittedBlockRound(round uint64)
SetLastCommittedBlockRound -
type ProcessStatusHandlerStub ¶
type ProcessStatusHandlerStub struct { SetBusyCalled func(reason string) SetIdleCalled func() IsIdleCalled func() bool }
ProcessStatusHandlerStub -
func (*ProcessStatusHandlerStub) IsIdle ¶
func (stub *ProcessStatusHandlerStub) IsIdle() bool
IsIdle -
func (*ProcessStatusHandlerStub) IsInterfaceNil ¶
func (stub *ProcessStatusHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ProcessStatusHandlerStub) SetBusy ¶
func (stub *ProcessStatusHandlerStub) SetBusy(reason string)
SetBusy -
func (*ProcessStatusHandlerStub) SetIdle ¶
func (stub *ProcessStatusHandlerStub) SetIdle()
SetIdle -
type ProcessedMiniBlocksTrackerStub ¶
type ProcessedMiniBlocksTrackerStub struct { SetProcessedMiniBlockInfoCalled func(metaBlockHash []byte, miniBlockHash []byte, processedMbInfo *processedMb.ProcessedMiniBlockInfo) RemoveMetaBlockHashCalled func(metaBlockHash []byte) RemoveMiniBlockHashCalled func(miniBlockHash []byte) GetProcessedMiniBlocksInfoCalled func(metaBlockHash []byte) map[string]*processedMb.ProcessedMiniBlockInfo GetProcessedMiniBlockInfoCalled func(miniBlockHash []byte) (*processedMb.ProcessedMiniBlockInfo, []byte) IsMiniBlockFullyProcessedCalled func(metaBlockHash []byte, miniBlockHash []byte) bool ConvertProcessedMiniBlocksMapToSliceCalled func() []bootstrapStorage.MiniBlocksInMeta ConvertSliceToProcessedMiniBlocksMapCalled func(miniBlocksInMetaBlocks []bootstrapStorage.MiniBlocksInMeta) DisplayProcessedMiniBlocksCalled func() }
ProcessedMiniBlocksTrackerStub -
func (*ProcessedMiniBlocksTrackerStub) ConvertProcessedMiniBlocksMapToSlice ¶
func (pmbts *ProcessedMiniBlocksTrackerStub) ConvertProcessedMiniBlocksMapToSlice() []bootstrapStorage.MiniBlocksInMeta
ConvertProcessedMiniBlocksMapToSlice -
func (*ProcessedMiniBlocksTrackerStub) ConvertSliceToProcessedMiniBlocksMap ¶
func (pmbts *ProcessedMiniBlocksTrackerStub) ConvertSliceToProcessedMiniBlocksMap(miniBlocksInMetaBlocks []bootstrapStorage.MiniBlocksInMeta)
ConvertSliceToProcessedMiniBlocksMap -
func (*ProcessedMiniBlocksTrackerStub) DisplayProcessedMiniBlocks ¶
func (pmbts *ProcessedMiniBlocksTrackerStub) DisplayProcessedMiniBlocks()
DisplayProcessedMiniBlocks -
func (*ProcessedMiniBlocksTrackerStub) GetProcessedMiniBlockInfo ¶
func (pmbts *ProcessedMiniBlocksTrackerStub) GetProcessedMiniBlockInfo(miniBlockHash []byte) (*processedMb.ProcessedMiniBlockInfo, []byte)
GetProcessedMiniBlockInfo -
func (*ProcessedMiniBlocksTrackerStub) GetProcessedMiniBlocksInfo ¶
func (pmbts *ProcessedMiniBlocksTrackerStub) GetProcessedMiniBlocksInfo(metaBlockHash []byte) map[string]*processedMb.ProcessedMiniBlockInfo
GetProcessedMiniBlocksInfo -
func (*ProcessedMiniBlocksTrackerStub) IsInterfaceNil ¶
func (pmbts *ProcessedMiniBlocksTrackerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ProcessedMiniBlocksTrackerStub) IsMiniBlockFullyProcessed ¶
func (pmbts *ProcessedMiniBlocksTrackerStub) IsMiniBlockFullyProcessed(metaBlockHash []byte, miniBlockHash []byte) bool
IsMiniBlockFullyProcessed -
func (*ProcessedMiniBlocksTrackerStub) RemoveMetaBlockHash ¶
func (pmbts *ProcessedMiniBlocksTrackerStub) RemoveMetaBlockHash(metaBlockHash []byte)
RemoveMetaBlockHash -
func (*ProcessedMiniBlocksTrackerStub) RemoveMiniBlockHash ¶
func (pmbts *ProcessedMiniBlocksTrackerStub) RemoveMiniBlockHash(miniBlockHash []byte)
RemoveMiniBlockHash -
func (*ProcessedMiniBlocksTrackerStub) SetProcessedMiniBlockInfo ¶
func (pmbts *ProcessedMiniBlocksTrackerStub) SetProcessedMiniBlockInfo(metaBlockHash []byte, miniBlockHash []byte, processedMbInfo *processedMb.ProcessedMiniBlockInfo)
SetProcessedMiniBlockInfo -
type ProtoMarshalizerMock ¶
type ProtoMarshalizerMock struct { }
ProtoMarshalizerMock implements marshaling with protobuf
func (*ProtoMarshalizerMock) IsInterfaceNil ¶
func (pmm *ProtoMarshalizerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ProtoMarshalizerMock) Marshal ¶
func (pmm *ProtoMarshalizerMock) Marshal(obj interface{}) ([]byte, error)
Marshal does the actual serialization of an object The object to be serialized must implement the gogoProtoObj interface
func (*ProtoMarshalizerMock) Unmarshal ¶
func (pmm *ProtoMarshalizerMock) Unmarshal(obj interface{}, buff []byte) error
Unmarshal does the actual deserialization of an object The object to be deserialized must implement the gogoProtoObj interface
type ProtobufMarshalizerMock ¶
type ProtobufMarshalizerMock struct { }
ProtobufMarshalizerMock implements marshaling with protobuf
func (*ProtobufMarshalizerMock) IsInterfaceNil ¶
func (x *ProtobufMarshalizerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ProtobufMarshalizerMock) Marshal ¶
func (x *ProtobufMarshalizerMock) Marshal(obj interface{}) ([]byte, error)
Marshal does the actual serialization of an object through protobuf
func (*ProtobufMarshalizerMock) Unmarshal ¶
func (x *ProtobufMarshalizerMock) Unmarshal(obj interface{}, buff []byte) error
Unmarshal does the actual deserialization of an object through protobuf
type PubkeyConverterMock ¶
type PubkeyConverterMock struct {
// contains filtered or unexported fields
}
PubkeyConverterMock -
func NewPubkeyConverterMock ¶
func NewPubkeyConverterMock(addressLen int) *PubkeyConverterMock
NewPubkeyConverterMock -
func (*PubkeyConverterMock) Decode ¶
func (pcm *PubkeyConverterMock) Decode(humanReadable string) ([]byte, error)
Decode -
func (*PubkeyConverterMock) Encode ¶
func (pcm *PubkeyConverterMock) Encode(pkBytes []byte) string
Encode -
func (*PubkeyConverterMock) IsInterfaceNil ¶
func (pcm *PubkeyConverterMock) IsInterfaceNil() bool
IsInterfaceNil -
type RaterMock ¶
type RaterMock struct { StartRating uint32 MinRating uint32 MaxRating uint32 Chance uint32 IncreaseProposer int32 DecreaseProposer int32 IncreaseValidator int32 DecreaseValidator int32 MetaIncreaseProposer int32 MetaDecreaseProposer int32 MetaIncreaseValidator int32 MetaDecreaseValidator int32 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 RevertIncreaseValidatorCalled func(shardId uint32, rating uint32, nrReverts uint32) uint32 ComputeIncreaseValidatorCalled func(shardId uint32, rating uint32) uint32 ComputeDecreaseValidatorCalled func(shardId uint32, rating uint32) uint32 GetChancesCalled func(val 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 ¶
GetSignedBlocksThreshold -
type RatingsInfoMock ¶
type RatingsInfoMock struct { StartRatingProperty uint32 MaxRatingProperty uint32 MinRatingProperty uint32 SignedBlocksThresholdProperty float32 MetaRatingsStepDataProperty process.RatingsStepHandler ShardRatingsStepDataProperty process.RatingsStepHandler SelectionChancesProperty []process.SelectionChance }
RatingsInfoMock -
func (*RatingsInfoMock) IsInterfaceNil ¶
func (rd *RatingsInfoMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*RatingsInfoMock) MetaChainRatingsStepHandler ¶
func (rd *RatingsInfoMock) MetaChainRatingsStepHandler() process.RatingsStepHandler
MetaChainRatingsStepHandler -
func (*RatingsInfoMock) SelectionChances ¶
func (rd *RatingsInfoMock) SelectionChances() []process.SelectionChance
SelectionChances -
func (*RatingsInfoMock) ShardChainRatingsStepHandler ¶
func (rd *RatingsInfoMock) ShardChainRatingsStepHandler() process.RatingsStepHandler
ShardChainRatingsStepHandler -
func (*RatingsInfoMock) SignedBlocksThreshold ¶
func (rd *RatingsInfoMock) SignedBlocksThreshold() float32
SignedBlocksThreshold -
type ReceiptsRepositoryStub ¶
type ReceiptsRepositoryStub struct { SaveReceiptsCalled func(holder common.ReceiptsHolder, header data.HeaderHandler, headerHash []byte) error LoadReceiptsCalled func(header data.HeaderHandler, headerHash []byte) (common.ReceiptsHolder, error) }
ReceiptsRepositoryStub -
func (*ReceiptsRepositoryStub) IsInterfaceNil ¶
func (stub *ReceiptsRepositoryStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ReceiptsRepositoryStub) LoadReceipts ¶
func (stub *ReceiptsRepositoryStub) LoadReceipts(header data.HeaderHandler, headerHash []byte) (common.ReceiptsHolder, error)
LoadReceipts -
func (*ReceiptsRepositoryStub) SaveReceipts ¶
func (stub *ReceiptsRepositoryStub) SaveReceipts(holder common.ReceiptsHolder, header data.HeaderHandler, headerHash []byte) error
SaveReceipts -
type RequestHandlerStub ¶
type RequestHandlerStub struct { RequestShardHeaderCalled func(shardID uint32, hash []byte) RequestMetaHeaderCalled func(hash []byte) RequestMetaHeaderByNonceCalled func(nonce uint64) RequestShardHeaderByNonceCalled func(shardID uint32, nonce uint64) RequestTransactionHandlerCalled func(destShardID uint32, txHashes [][]byte) RequestScrHandlerCalled func(destShardID uint32, txHashes [][]byte) RequestRewardTxHandlerCalled func(destShardID uint32, txHashes [][]byte) RequestMiniBlockHandlerCalled func(destShardID uint32, miniblockHash []byte) RequestMiniBlocksHandlerCalled func(destShardID uint32, miniblocksHashes [][]byte) RequestTrieNodesCalled func(destShardID uint32, hashes [][]byte, topic string) RequestStartOfEpochMetaBlockCalled func(epoch uint32) SetNumPeersToQueryCalled func(key string, intra int, cross int) error GetNumPeersToQueryCalled func(key string) (int, int, error) RequestTrieNodeCalled func(requestHash []byte, topic string, chunkIndex uint32) CreateTrieNodeIdentifierCalled func(requestHash []byte, chunkIndex uint32) []byte RequestPeerAuthenticationsByHashesCalled func(destShardID uint32, hashes [][]byte) RequestValidatorInfoCalled func(hash []byte) RequestValidatorsInfoCalled func(hashes [][]byte) }
RequestHandlerStub -
func (*RequestHandlerStub) CreateTrieNodeIdentifier ¶
func (rhs *RequestHandlerStub) CreateTrieNodeIdentifier(requestHash []byte, chunkIndex uint32) []byte
CreateTrieNodeIdentifier -
func (*RequestHandlerStub) GetNumPeersToQuery ¶
func (rhs *RequestHandlerStub) GetNumPeersToQuery(key string) (int, int, error)
GetNumPeersToQuery -
func (*RequestHandlerStub) IsInterfaceNil ¶
func (rhs *RequestHandlerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*RequestHandlerStub) RequestInterval ¶
func (rhs *RequestHandlerStub) RequestInterval() time.Duration
RequestInterval -
func (*RequestHandlerStub) RequestMetaHeader ¶
func (rhs *RequestHandlerStub) RequestMetaHeader(hash []byte)
RequestMetaHeader -
func (*RequestHandlerStub) RequestMetaHeaderByNonce ¶
func (rhs *RequestHandlerStub) RequestMetaHeaderByNonce(nonce uint64)
RequestMetaHeaderByNonce -
func (*RequestHandlerStub) RequestMiniBlock ¶
func (rhs *RequestHandlerStub) RequestMiniBlock(destShardID uint32, miniblockHash []byte)
RequestMiniBlock -
func (*RequestHandlerStub) RequestMiniBlocks ¶
func (rhs *RequestHandlerStub) RequestMiniBlocks(destShardID uint32, miniblocksHashes [][]byte)
RequestMiniBlocks -
func (*RequestHandlerStub) RequestPeerAuthenticationsByHashes ¶
func (rhs *RequestHandlerStub) RequestPeerAuthenticationsByHashes(destShardID uint32, hashes [][]byte)
RequestPeerAuthenticationsByHashes -
func (*RequestHandlerStub) RequestRewardTransactions ¶
func (rhs *RequestHandlerStub) RequestRewardTransactions(destShardID uint32, txHashes [][]byte)
RequestRewardTransactions -
func (*RequestHandlerStub) RequestShardHeader ¶
func (rhs *RequestHandlerStub) RequestShardHeader(shardID uint32, hash []byte)
RequestShardHeader -
func (*RequestHandlerStub) RequestShardHeaderByNonce ¶
func (rhs *RequestHandlerStub) RequestShardHeaderByNonce(shardID uint32, nonce uint64)
RequestShardHeaderByNonce -
func (*RequestHandlerStub) RequestStartOfEpochMetaBlock ¶
func (rhs *RequestHandlerStub) RequestStartOfEpochMetaBlock(epoch uint32)
RequestStartOfEpochMetaBlock -
func (*RequestHandlerStub) RequestTransaction ¶
func (rhs *RequestHandlerStub) RequestTransaction(destShardID uint32, txHashes [][]byte)
RequestTransaction -
func (*RequestHandlerStub) RequestTrieNode ¶
func (rhs *RequestHandlerStub) RequestTrieNode(requestHash []byte, topic string, chunkIndex uint32)
RequestTrieNode -
func (*RequestHandlerStub) RequestTrieNodes ¶
func (rhs *RequestHandlerStub) RequestTrieNodes(destShardID uint32, hashes [][]byte, topic string)
RequestTrieNodes -
func (*RequestHandlerStub) RequestUnsignedTransactions ¶
func (rhs *RequestHandlerStub) RequestUnsignedTransactions(destShardID uint32, txHashes [][]byte)
RequestUnsignedTransactions -
func (*RequestHandlerStub) RequestValidatorInfo ¶
func (rhs *RequestHandlerStub) RequestValidatorInfo(hash []byte)
RequestValidatorInfo -
func (*RequestHandlerStub) RequestValidatorsInfo ¶
func (rhs *RequestHandlerStub) RequestValidatorsInfo(hashes [][]byte)
RequestValidatorsInfo -
func (*RequestHandlerStub) SetNumPeersToQuery ¶
func (rhs *RequestHandlerStub) SetNumPeersToQuery(key string, intra int, cross int) error
SetNumPeersToQuery -
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 RewardTxProcessorMock ¶
type RewardTxProcessorMock struct {
ProcessRewardTransactionCalled func(rTx *rewardTx.RewardTx) error
}
RewardTxProcessorMock -
func (*RewardTxProcessorMock) IsInterfaceNil ¶
func (scrp *RewardTxProcessorMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*RewardTxProcessorMock) ProcessRewardTransaction ¶
func (scrp *RewardTxProcessorMock) ProcessRewardTransaction(rTx *rewardTx.RewardTx) error
ProcessRewardTransaction -
type RoundHandlerMock ¶
type RoundHandlerMock struct { IndexCalled func() int64 TimeDurationCalled func() time.Duration TimeStampCalled func() time.Time UpdateRoundCalled func(time.Time, time.Time) RemainingTimeCalled func(startTime time.Time, maxTime time.Duration) time.Duration BeforeGenesisCalled func() bool // contains filtered or unexported fields }
RoundHandlerMock -
func (*RoundHandlerMock) BeforeGenesis ¶
func (rndm *RoundHandlerMock) BeforeGenesis() bool
BeforeGenesis -
func (*RoundHandlerMock) IsInterfaceNil ¶
func (rndm *RoundHandlerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*RoundHandlerMock) RemainingTime ¶
func (rndm *RoundHandlerMock) RemainingTime(startTime time.Time, maxTime time.Duration) time.Duration
RemainingTime -
func (*RoundHandlerMock) TimeDuration ¶
func (rndm *RoundHandlerMock) TimeDuration() time.Duration
TimeDuration -
func (*RoundHandlerMock) TimeStamp ¶
func (rndm *RoundHandlerMock) TimeStamp() time.Time
TimeStamp -
func (*RoundHandlerMock) UpdateRound ¶
func (rndm *RoundHandlerMock) UpdateRound(genesisRoundTimeStamp time.Time, timeStamp time.Time)
UpdateRound -
type SCProcessorMock ¶
type SCProcessorMock struct { ComputeTransactionTypeCalled func(tx data.TransactionHandler) (process.TransactionType, process.TransactionType) ExecuteSmartContractTransactionCalled func(tx data.TransactionHandler, acntSrc, acntDst state.UserAccountHandler) (vmcommon.ReturnCode, error) ExecuteBuiltInFunctionCalled func(tx data.TransactionHandler, acntSrc, acntDst state.UserAccountHandler) (vmcommon.ReturnCode, error) DeploySmartContractCalled func(tx data.TransactionHandler, acntSrc state.UserAccountHandler) (vmcommon.ReturnCode, error) ProcessSmartContractResultCalled func(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error) ProcessIfErrorCalled func(acntSnd state.UserAccountHandler, txHash []byte, tx data.TransactionHandler, returnCode string, returnMessage []byte, snapshot int, gasLocked uint64) error IsPayableCalled func(sndAddress, recvAddress []byte) (bool, error) CheckBuiltinFunctionIsExecutableCalled func(expectedBuiltinFunction string, tx data.TransactionHandler) error }
SCProcessorMock -
func (*SCProcessorMock) CheckBuiltinFunctionIsExecutable ¶ added in v1.5.3
func (sc *SCProcessorMock) CheckBuiltinFunctionIsExecutable(expectedBuiltinFunction string, tx data.TransactionHandler) error
CheckBuiltinFunctionIsExecutable -
func (*SCProcessorMock) ComputeTransactionType ¶
func (sc *SCProcessorMock) ComputeTransactionType(tx data.TransactionHandler) (process.TransactionType, process.TransactionType)
ComputeTransactionType -
func (*SCProcessorMock) DeploySmartContract ¶
func (sc *SCProcessorMock) DeploySmartContract(tx data.TransactionHandler, acntSrc state.UserAccountHandler) (vmcommon.ReturnCode, error)
DeploySmartContract -
func (*SCProcessorMock) ExecuteBuiltInFunction ¶
func (sc *SCProcessorMock) ExecuteBuiltInFunction( tx data.TransactionHandler, acntSrc, acntDst state.UserAccountHandler, ) (vmcommon.ReturnCode, error)
ExecuteBuiltInFunction -
func (*SCProcessorMock) ExecuteSmartContractTransaction ¶
func (sc *SCProcessorMock) ExecuteSmartContractTransaction( tx data.TransactionHandler, acntSrc, acntDst state.UserAccountHandler, ) (vmcommon.ReturnCode, error)
ExecuteSmartContractTransaction -
func (*SCProcessorMock) IsInterfaceNil ¶
func (sc *SCProcessorMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*SCProcessorMock) IsPayable ¶
func (sc *SCProcessorMock) IsPayable(sndAddress []byte, recvAddress []byte) (bool, error)
IsPayable -
func (*SCProcessorMock) ProcessIfError ¶
func (sc *SCProcessorMock) ProcessIfError( acntSnd state.UserAccountHandler, txHash []byte, tx data.TransactionHandler, returnCode string, returnMessage []byte, snapshot int, gasLocked uint64, ) error
ProcessIfError -
func (*SCProcessorMock) ProcessSmartContractResult ¶
func (sc *SCProcessorMock) ProcessSmartContractResult(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)
ProcessSmartContractResult -
type ScheduledTxsExecutionStub ¶
type ScheduledTxsExecutionStub struct { InitCalled func() AddScheduledTxCalled func([]byte, data.TransactionHandler) bool AddScheduledMiniBlocksCalled func(miniBlocks block.MiniBlockSlice) ExecuteCalled func([]byte) error ExecuteAllCalled func(func() time.Duration) error GetScheduledIntermediateTxsCalled func() map[block.Type][]data.TransactionHandler GetScheduledMiniBlocksCalled func() block.MiniBlockSlice SetScheduledInfoCalled func(scheduledInfo *process.ScheduledInfo) GetScheduledRootHashForHeaderCalled func(headerHash []byte) ([]byte, error) GetScheduledRootHashForHeaderWithEpochCalled func(headerHash []byte, epoch uint32) ([]byte, error) RollBackToBlockCalled func(headerHash []byte) error GetScheduledRootHashCalled func() []byte GetScheduledGasAndFeesCalled func() scheduled.GasAndFees SetScheduledRootHashCalled func([]byte) SetScheduledGasAndFeesCalled func(gasAndFees scheduled.GasAndFees) SetTransactionProcessorCalled func(process.TransactionProcessor) SetTransactionCoordinatorCalled func(process.TransactionCoordinator) HaveScheduledTxsCalled func() bool SaveStateIfNeededCalled func(headerHash []byte) SaveStateCalled func(headerHash []byte, scheduledInfo *process.ScheduledInfo) LoadStateCalled func(headerHash []byte) IsScheduledTxCalled func([]byte) bool IsMiniBlockExecutedCalled func([]byte) bool }
ScheduledTxsExecutionStub -
func (*ScheduledTxsExecutionStub) AddScheduledMiniBlocks ¶
func (stes *ScheduledTxsExecutionStub) AddScheduledMiniBlocks(miniBlocks block.MiniBlockSlice)
AddScheduledMiniBlocks -
func (*ScheduledTxsExecutionStub) AddScheduledTx ¶
func (stes *ScheduledTxsExecutionStub) AddScheduledTx(txHash []byte, tx data.TransactionHandler) bool
AddScheduledTx -
func (*ScheduledTxsExecutionStub) Execute ¶
func (stes *ScheduledTxsExecutionStub) Execute(txHash []byte) error
Execute -
func (*ScheduledTxsExecutionStub) ExecuteAll ¶
func (stes *ScheduledTxsExecutionStub) ExecuteAll(haveTime func() time.Duration) error
ExecuteAll -
func (*ScheduledTxsExecutionStub) GetScheduledGasAndFees ¶
func (stes *ScheduledTxsExecutionStub) GetScheduledGasAndFees() scheduled.GasAndFees
GetScheduledGasAndFees returns the scheduled SC calls gas and fees
func (*ScheduledTxsExecutionStub) GetScheduledIntermediateTxs ¶
func (stes *ScheduledTxsExecutionStub) GetScheduledIntermediateTxs() map[block.Type][]data.TransactionHandler
GetScheduledIntermediateTxs -
func (*ScheduledTxsExecutionStub) GetScheduledMiniBlocks ¶
func (stes *ScheduledTxsExecutionStub) GetScheduledMiniBlocks() block.MiniBlockSlice
GetScheduledMiniBlocks -
func (*ScheduledTxsExecutionStub) GetScheduledRootHash ¶
func (stes *ScheduledTxsExecutionStub) GetScheduledRootHash() []byte
GetScheduledRootHash -
func (*ScheduledTxsExecutionStub) GetScheduledRootHashForHeader ¶
func (stes *ScheduledTxsExecutionStub) GetScheduledRootHashForHeader(headerHash []byte) ([]byte, error)
GetScheduledRootHashForHeader -
func (*ScheduledTxsExecutionStub) GetScheduledRootHashForHeaderWithEpoch ¶
func (stes *ScheduledTxsExecutionStub) GetScheduledRootHashForHeaderWithEpoch(headerHash []byte, epoch uint32) ([]byte, error)
GetScheduledRootHashForHeaderWithEpoch -
func (*ScheduledTxsExecutionStub) IsInterfaceNil ¶
func (stes *ScheduledTxsExecutionStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ScheduledTxsExecutionStub) IsMiniBlockExecuted ¶
func (stes *ScheduledTxsExecutionStub) IsMiniBlockExecuted(mbHash []byte) bool
IsMiniBlockExecuted -
func (*ScheduledTxsExecutionStub) IsScheduledTx ¶
func (stes *ScheduledTxsExecutionStub) IsScheduledTx(txHash []byte) bool
IsScheduledTx -
func (*ScheduledTxsExecutionStub) RollBackToBlock ¶
func (stes *ScheduledTxsExecutionStub) RollBackToBlock(headerHash []byte) error
RollBackToBlock -
func (*ScheduledTxsExecutionStub) SaveState ¶
func (stes *ScheduledTxsExecutionStub) SaveState( headerHash []byte, scheduledInfo *process.ScheduledInfo, )
SaveState -
func (*ScheduledTxsExecutionStub) SaveStateIfNeeded ¶
func (stes *ScheduledTxsExecutionStub) SaveStateIfNeeded(headerHash []byte)
SaveStateIfNeeded -
func (*ScheduledTxsExecutionStub) SetScheduledGasAndFees ¶
func (stes *ScheduledTxsExecutionStub) SetScheduledGasAndFees(gasAndFees scheduled.GasAndFees)
SetScheduledGasAndFees -
func (*ScheduledTxsExecutionStub) SetScheduledInfo ¶
func (stes *ScheduledTxsExecutionStub) SetScheduledInfo(scheduledInfo *process.ScheduledInfo)
SetScheduledInfo -
func (*ScheduledTxsExecutionStub) SetScheduledRootHash ¶
func (stes *ScheduledTxsExecutionStub) SetScheduledRootHash(rootHash []byte)
SetScheduledRootHash -
func (*ScheduledTxsExecutionStub) SetTransactionCoordinator ¶
func (stes *ScheduledTxsExecutionStub) SetTransactionCoordinator(txCoordinator process.TransactionCoordinator)
SetTransactionCoordinator -
func (*ScheduledTxsExecutionStub) SetTransactionProcessor ¶
func (stes *ScheduledTxsExecutionStub) SetTransactionProcessor(txProcessor process.TransactionProcessor)
SetTransactionProcessor -
type ShardedDataCacheNotifierMock ¶
type ShardedDataCacheNotifierMock struct {
// contains filtered or unexported fields
}
ShardedDataCacheNotifierMock -
func NewShardedDataCacheNotifierMock ¶
func NewShardedDataCacheNotifierMock() *ShardedDataCacheNotifierMock
NewShardedDataCacheNotifierMock -
func (*ShardedDataCacheNotifierMock) AddData ¶
func (mock *ShardedDataCacheNotifierMock) AddData(key []byte, data interface{}, sizeInBytes int, cacheId string)
AddData -
func (*ShardedDataCacheNotifierMock) Clear ¶
func (mock *ShardedDataCacheNotifierMock) Clear()
Clear -
func (*ShardedDataCacheNotifierMock) ClearShardStore ¶
func (mock *ShardedDataCacheNotifierMock) ClearShardStore(cacheId string)
ClearShardStore -
func (*ShardedDataCacheNotifierMock) GetCounts ¶
func (mock *ShardedDataCacheNotifierMock) GetCounts() counting.CountsWithSize
GetCounts -
func (*ShardedDataCacheNotifierMock) ImmunizeSetOfDataAgainstEviction ¶
func (mock *ShardedDataCacheNotifierMock) ImmunizeSetOfDataAgainstEviction(_ [][]byte, _ string)
ImmunizeSetOfDataAgainstEviction -
func (*ShardedDataCacheNotifierMock) IsInterfaceNil ¶
func (mock *ShardedDataCacheNotifierMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*ShardedDataCacheNotifierMock) Keys ¶
func (mock *ShardedDataCacheNotifierMock) Keys() [][]byte
Keys -
func (*ShardedDataCacheNotifierMock) MergeShardStores ¶
func (mock *ShardedDataCacheNotifierMock) MergeShardStores(_, _ string)
MergeShardStores -
func (*ShardedDataCacheNotifierMock) RegisterOnAdded ¶
func (mock *ShardedDataCacheNotifierMock) RegisterOnAdded(_ func(key []byte, value interface{}))
RegisterOnAdded -
func (*ShardedDataCacheNotifierMock) RemoveData ¶
func (mock *ShardedDataCacheNotifierMock) RemoveData(key []byte, cacheId string)
RemoveData -
func (*ShardedDataCacheNotifierMock) RemoveDataFromAllShards ¶
func (mock *ShardedDataCacheNotifierMock) RemoveDataFromAllShards(key []byte)
RemoveDataFromAllShards -
func (*ShardedDataCacheNotifierMock) RemoveSetOfDataFromPool ¶
func (mock *ShardedDataCacheNotifierMock) RemoveSetOfDataFromPool(keys [][]byte, cacheId string)
RemoveSetOfDataFromPool -
func (*ShardedDataCacheNotifierMock) SearchFirstData ¶
func (mock *ShardedDataCacheNotifierMock) SearchFirstData(key []byte) (interface{}, bool)
SearchFirstData -
func (*ShardedDataCacheNotifierMock) ShardDataStore ¶
func (mock *ShardedDataCacheNotifierMock) ShardDataStore(cacheId string) (c storage.Cacher)
ShardDataStore -
type ShardedDataStub ¶
type ShardedDataStub struct { RegisterOnAddedCalled func(func(key []byte, value interface{})) ShardDataStoreCalled func(cacheID string) storage.Cacher AddDataCalled func(key []byte, data interface{}, sizeInBytes int, cacheID string) SearchFirstDataCalled func(key []byte) (value interface{}, ok bool) RemoveDataCalled func(key []byte, cacheID string) RemoveDataFromAllShardsCalled func(key []byte) MergeShardStoresCalled func(sourceCacheID, destCacheID string) MoveDataCalled func(sourceCacheID, destCacheID string, key [][]byte) ClearCalled func() ClearShardStoreCalled func(cacheID string) RemoveSetOfDataFromPoolCalled func(keys [][]byte, destCacheID string) ImmunizeSetOfDataAgainstEvictionCalled func(keys [][]byte, cacheID string) CreateShardStoreCalled func(destCacheID string) GetCountsCalled func() counting.CountsWithSize KeysCalled func() [][]byte }
ShardedDataStub -
func (*ShardedDataStub) AddData ¶
func (sd *ShardedDataStub) AddData(key []byte, data interface{}, sizeInBytes int, cacheID string)
AddData -
func (*ShardedDataStub) ClearShardStore ¶
func (sd *ShardedDataStub) ClearShardStore(cacheID string)
ClearShardStore -
func (*ShardedDataStub) GetCounts ¶
func (sd *ShardedDataStub) GetCounts() counting.CountsWithSize
GetCounts -
func (*ShardedDataStub) ImmunizeSetOfDataAgainstEviction ¶
func (sd *ShardedDataStub) ImmunizeSetOfDataAgainstEviction(keys [][]byte, cacheID string)
ImmunizeSetOfDataAgainstEviction -
func (*ShardedDataStub) IsInterfaceNil ¶
func (sd *ShardedDataStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ShardedDataStub) MergeShardStores ¶
func (sd *ShardedDataStub) MergeShardStores(sourceCacheID, destCacheID string)
MergeShardStores -
func (*ShardedDataStub) RegisterOnAdded ¶
func (sd *ShardedDataStub) RegisterOnAdded(handler func(key []byte, value interface{}))
RegisterOnAdded -
func (*ShardedDataStub) RemoveData ¶
func (sd *ShardedDataStub) RemoveData(key []byte, cacheID string)
RemoveData -
func (*ShardedDataStub) RemoveDataFromAllShards ¶
func (sd *ShardedDataStub) RemoveDataFromAllShards(key []byte)
RemoveDataFromAllShards -
func (*ShardedDataStub) RemoveSetOfDataFromPool ¶
func (sd *ShardedDataStub) RemoveSetOfDataFromPool(keys [][]byte, cacheID string)
RemoveSetOfDataFromPool -
func (*ShardedDataStub) SearchFirstData ¶
func (sd *ShardedDataStub) SearchFirstData(key []byte) (value interface{}, ok bool)
SearchFirstData -
func (*ShardedDataStub) ShardDataStore ¶
func (sd *ShardedDataStub) ShardDataStore(cacheID string) storage.Cacher
ShardDataStore -
type ShardsCoordinatorMock ¶
type ShardsCoordinatorMock struct { NoShards uint32 CurrentShard uint32 ComputeIdCalled func(address []byte) uint32 SelfIDCalled func() uint32 }
ShardsCoordinatorMock -
func NewMultiShardsCoordinatorMock ¶
func NewMultiShardsCoordinatorMock(numShards uint32) *ShardsCoordinatorMock
NewMultiShardsCoordinatorMock -
func (*ShardsCoordinatorMock) CommunicationIdentifier ¶
func (scm *ShardsCoordinatorMock) CommunicationIdentifier(destShardID uint32) string
CommunicationIdentifier returns the identifier between current shard ID and destination shard ID identifier is generated such as the first shard from identifier is always smaller than the last
func (*ShardsCoordinatorMock) ComputeId ¶
func (scm *ShardsCoordinatorMock) ComputeId(address []byte) uint32
ComputeId -
func (*ShardsCoordinatorMock) IsInterfaceNil ¶
func (scm *ShardsCoordinatorMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ShardsCoordinatorMock) NumberOfShards ¶
func (scm *ShardsCoordinatorMock) NumberOfShards() uint32
NumberOfShards -
func (*ShardsCoordinatorMock) SameShard ¶
func (scm *ShardsCoordinatorMock) SameShard(_, _ []byte) bool
SameShard -
func (*ShardsCoordinatorMock) SetNoShards ¶
func (scm *ShardsCoordinatorMock) SetNoShards(noShards uint32)
SetNoShards -
func (*ShardsCoordinatorMock) SetSelfId ¶
func (scm *ShardsCoordinatorMock) SetSelfId(_ uint32) error
SetSelfId -
type SimpleNFTStorageHandlerStub ¶
type SimpleNFTStorageHandlerStub struct { GetESDTNFTTokenOnDestinationCalled func(accnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64) (*esdt.ESDigitalToken, bool, error) SaveNFTMetaDataToSystemAccountCalled func(tx data.TransactionHandler) error }
SimpleNFTStorageHandlerStub -
func (*SimpleNFTStorageHandlerStub) GetESDTNFTTokenOnDestination ¶
func (s *SimpleNFTStorageHandlerStub) GetESDTNFTTokenOnDestination(accnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64) (*esdt.ESDigitalToken, bool, error)
GetESDTNFTTokenOnDestination -
func (*SimpleNFTStorageHandlerStub) IsInterfaceNil ¶
func (s *SimpleNFTStorageHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*SimpleNFTStorageHandlerStub) SaveNFTMetaDataToSystemAccount ¶
func (s *SimpleNFTStorageHandlerStub) SaveNFTMetaDataToSystemAccount(tx data.TransactionHandler) error
SaveNFTMetaDataToSystemAccount -
type SizeSyncStatisticsHandlerStub ¶
type SizeSyncStatisticsHandlerStub struct { AddNumBytesReceivedCalled func(bytes uint64) AddProcessingTimeCalled func(duration time.Duration) IncrementIterationCalled func() ProcessingTimeCalled func() time.Duration ResetCalled func() AddNumProcessedCalled func(value int) AddNumLargeCalled func(value int) SetNumMissingCalled func(rootHash []byte, value int) NumBytesReceivedField uint64 NumTriesField int NumIterationsField int NumProcessedField int NumLargeField int NumMissingField int }
SizeSyncStatisticsHandlerStub -
func (*SizeSyncStatisticsHandlerStub) AddNumBytesReceived ¶
func (stub *SizeSyncStatisticsHandlerStub) AddNumBytesReceived(bytes uint64)
AddNumBytesReceived -
func (*SizeSyncStatisticsHandlerStub) AddNumLarge ¶
func (stub *SizeSyncStatisticsHandlerStub) AddNumLarge(value int)
AddNumLarge -
func (*SizeSyncStatisticsHandlerStub) AddNumProcessed ¶
func (stub *SizeSyncStatisticsHandlerStub) AddNumProcessed(value int)
AddNumProcessed -
func (*SizeSyncStatisticsHandlerStub) AddProcessingTime ¶
func (stub *SizeSyncStatisticsHandlerStub) AddProcessingTime(duration time.Duration)
AddProcessingTime -
func (*SizeSyncStatisticsHandlerStub) IncrementIteration ¶
func (stub *SizeSyncStatisticsHandlerStub) IncrementIteration()
IncrementIteration -
func (*SizeSyncStatisticsHandlerStub) IsInterfaceNil ¶
func (stub *SizeSyncStatisticsHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*SizeSyncStatisticsHandlerStub) NumBytesReceived ¶
func (stub *SizeSyncStatisticsHandlerStub) NumBytesReceived() uint64
NumBytesReceived -
func (*SizeSyncStatisticsHandlerStub) NumIterations ¶
func (stub *SizeSyncStatisticsHandlerStub) NumIterations() int
NumIterations -
func (*SizeSyncStatisticsHandlerStub) NumLarge ¶
func (stub *SizeSyncStatisticsHandlerStub) NumLarge() int
NumLarge -
func (*SizeSyncStatisticsHandlerStub) NumMissing ¶
func (stub *SizeSyncStatisticsHandlerStub) NumMissing() int
NumMissing -
func (*SizeSyncStatisticsHandlerStub) NumProcessed ¶
func (stub *SizeSyncStatisticsHandlerStub) NumProcessed() int
NumProcessed -
func (*SizeSyncStatisticsHandlerStub) NumTries ¶
func (stub *SizeSyncStatisticsHandlerStub) NumTries() int
NumTries -
func (*SizeSyncStatisticsHandlerStub) ProcessingTime ¶
func (stub *SizeSyncStatisticsHandlerStub) ProcessingTime() time.Duration
ProcessingTime -
func (*SizeSyncStatisticsHandlerStub) Reset ¶
func (stub *SizeSyncStatisticsHandlerStub) Reset()
Reset -
func (*SizeSyncStatisticsHandlerStub) SetNumMissing ¶
func (stub *SizeSyncStatisticsHandlerStub) SetNumMissing(rootHash []byte, value int)
SetNumMissing -
type SmartContractResultsProcessorMock ¶
type SmartContractResultsProcessorMock struct {
ProcessSmartContractResultCalled func(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)
}
SmartContractResultsProcessorMock -
func (*SmartContractResultsProcessorMock) IsInterfaceNil ¶
func (scrp *SmartContractResultsProcessorMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*SmartContractResultsProcessorMock) ProcessSmartContractResult ¶
func (scrp *SmartContractResultsProcessorMock) ProcessSmartContractResult(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)
ProcessSmartContractResult -
type SnapshotPruningStorerMock ¶
type SnapshotPruningStorerMock struct {
*MemDbMock
}
SnapshotPruningStorerMock -
func NewSnapshotPruningStorerMock ¶
func NewSnapshotPruningStorerMock() *SnapshotPruningStorerMock
NewSnapshotPruningStorerMock -
func (*SnapshotPruningStorerMock) GetFromCurrentEpoch ¶
func (spsm *SnapshotPruningStorerMock) GetFromCurrentEpoch(key []byte) ([]byte, error)
GetFromCurrentEpoch -
func (*SnapshotPruningStorerMock) GetFromEpoch ¶
func (spsm *SnapshotPruningStorerMock) GetFromEpoch(key []byte, _ uint32) ([]byte, error)
GetFromEpoch -
func (*SnapshotPruningStorerMock) GetFromLastEpoch ¶
func (spsm *SnapshotPruningStorerMock) GetFromLastEpoch(key []byte) ([]byte, error)
GetFromLastEpoch -
func (*SnapshotPruningStorerMock) GetFromOldEpochsWithoutAddingToCache ¶
func (spsm *SnapshotPruningStorerMock) GetFromOldEpochsWithoutAddingToCache(key []byte) ([]byte, core.OptionalUint32, error)
GetFromOldEpochsWithoutAddingToCache -
func (*SnapshotPruningStorerMock) GetLatestStorageEpoch ¶
func (spsm *SnapshotPruningStorerMock) GetLatestStorageEpoch() (uint32, error)
GetLatestStorageEpoch -
func (*SnapshotPruningStorerMock) PutInEpoch ¶
func (spsm *SnapshotPruningStorerMock) PutInEpoch(key []byte, data []byte, _ uint32) error
PutInEpoch -
func (*SnapshotPruningStorerMock) PutInEpochWithoutCache ¶
func (spsm *SnapshotPruningStorerMock) PutInEpochWithoutCache(key []byte, data []byte, _ uint32) error
PutInEpochWithoutCache -
func (*SnapshotPruningStorerMock) RemoveFromCurrentEpoch ¶
func (spsm *SnapshotPruningStorerMock) RemoveFromCurrentEpoch(key []byte) error
RemoveFromCurrentEpoch -
type StateComponentsMock ¶
type StateComponentsMock struct { PeersAcc state.AccountsAdapter Accounts state.AccountsAdapter AccountsAPI state.AccountsAdapter AccountsRepo state.AccountsRepository Tries common.TriesHolder StorageManagers map[string]common.StorageManager }
StateComponentsMock -
func (*StateComponentsMock) AccountsAdapter ¶
func (scm *StateComponentsMock) AccountsAdapter() state.AccountsAdapter
AccountsAdapter -
func (*StateComponentsMock) AccountsAdapterAPI ¶
func (scm *StateComponentsMock) AccountsAdapterAPI() state.AccountsAdapter
AccountsAdapterAPI -
func (*StateComponentsMock) AccountsRepository ¶
func (scm *StateComponentsMock) AccountsRepository() state.AccountsRepository
AccountsRepository -
func (*StateComponentsMock) CheckSubcomponents ¶
func (scm *StateComponentsMock) CheckSubcomponents() error
CheckSubcomponents -
func (*StateComponentsMock) IsInterfaceNil ¶
func (scm *StateComponentsMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*StateComponentsMock) PeerAccounts ¶
func (scm *StateComponentsMock) PeerAccounts() state.AccountsAdapter
PeerAccounts -
func (*StateComponentsMock) TrieStorageManagers ¶
func (scm *StateComponentsMock) TrieStorageManagers() map[string]common.StorageManager
TrieStorageManagers -
func (*StateComponentsMock) TriesContainer ¶
func (scm *StateComponentsMock) TriesContainer() common.TriesHolder
TriesContainer -
type StatusMetricsStub ¶
type StatusMetricsStub struct { StatusMetricsMapWithoutP2PCalled func() (map[string]interface{}, error) StatusP2pMetricsMapCalled func() (map[string]interface{}, error) ConfigMetricsCalled func() (map[string]interface{}, error) NetworkMetricsCalled func() (map[string]interface{}, error) EconomicsMetricsCalled func() (map[string]interface{}, error) EnableEpochsMetricsCalled func() (map[string]interface{}, error) RatingsMetricsCalled func() (map[string]interface{}, error) StatusMetricsWithoutP2PPrometheusStringCalled func() (string, error) BootstrapMetricsCalled func() (map[string]interface{}, error) }
StatusMetricsStub -
func (*StatusMetricsStub) BootstrapMetrics ¶ added in v1.4.3
func (sms *StatusMetricsStub) BootstrapMetrics() (map[string]interface{}, error)
BootstrapMetrics -
func (*StatusMetricsStub) ConfigMetrics ¶
func (sms *StatusMetricsStub) ConfigMetrics() (map[string]interface{}, error)
ConfigMetrics -
func (*StatusMetricsStub) EconomicsMetrics ¶
func (sms *StatusMetricsStub) EconomicsMetrics() (map[string]interface{}, error)
EconomicsMetrics -
func (*StatusMetricsStub) EnableEpochsMetrics ¶
func (sms *StatusMetricsStub) EnableEpochsMetrics() (map[string]interface{}, error)
EnableEpochsMetrics -
func (*StatusMetricsStub) IsInterfaceNil ¶
func (sms *StatusMetricsStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*StatusMetricsStub) NetworkMetrics ¶
func (sms *StatusMetricsStub) NetworkMetrics() (map[string]interface{}, error)
NetworkMetrics -
func (*StatusMetricsStub) RatingsMetrics ¶
func (sms *StatusMetricsStub) RatingsMetrics() (map[string]interface{}, error)
RatingsMetrics -
func (*StatusMetricsStub) StatusMetricsMapWithoutP2P ¶
func (sms *StatusMetricsStub) StatusMetricsMapWithoutP2P() (map[string]interface{}, error)
StatusMetricsMapWithoutP2P -
func (*StatusMetricsStub) StatusMetricsWithoutP2PPrometheusString ¶
func (sms *StatusMetricsStub) StatusMetricsWithoutP2PPrometheusString() (string, error)
StatusMetricsWithoutP2PPrometheusString -
func (*StatusMetricsStub) StatusP2pMetricsMap ¶
func (sms *StatusMetricsStub) StatusP2pMetricsMap() (map[string]interface{}, error)
StatusP2pMetricsMap -
type StorageManagerStub ¶
type StorageManagerStub struct { PutCalled func([]byte, []byte) error PutInEpochCalled func([]byte, []byte, uint32) error PutInEpochWithoutCacheCalled func([]byte, []byte, uint32) error GetCalled func([]byte) ([]byte, error) GetFromCurrentEpochCalled func([]byte) ([]byte, error) TakeSnapshotCalled func(string, []byte, []byte, *common.TrieIteratorChannels, chan []byte, common.SnapshotStatisticsHandler, uint32) SetCheckpointCalled func([]byte, []byte, *common.TrieIteratorChannels, chan []byte, common.SnapshotStatisticsHandler) GetDbThatContainsHashCalled func([]byte) common.DBWriteCacher IsPruningEnabledCalled func() bool IsPruningBlockedCalled func() bool EnterPruningBufferingModeCalled func() ExitPruningBufferingModeCalled func() AddDirtyCheckpointHashesCalled func([]byte, common.ModifiedHashes) bool RemoveFromCurrentEpochCalled func([]byte) error RemoveCalled func([]byte) error IsInterfaceNilCalled func() bool SetEpochForPutOperationCalled func(uint32) ShouldTakeSnapshotCalled func() bool GetLatestStorageEpochCalled func() (uint32, error) IsClosedCalled func() bool RemoveFromCheckpointHashesHolderCalled func([]byte) GetBaseTrieStorageManagerCalled func() common.StorageManager }
StorageManagerStub -
func (*StorageManagerStub) AddDirtyCheckpointHashes ¶
func (sms *StorageManagerStub) AddDirtyCheckpointHashes(rootHash []byte, hashes common.ModifiedHashes) bool
AddDirtyCheckpointHashes -
func (*StorageManagerStub) EnterPruningBufferingMode ¶
func (sms *StorageManagerStub) EnterPruningBufferingMode()
EnterPruningBufferingMode -
func (*StorageManagerStub) ExitPruningBufferingMode ¶
func (sms *StorageManagerStub) ExitPruningBufferingMode()
ExitPruningBufferingMode -
func (*StorageManagerStub) Get ¶
func (sms *StorageManagerStub) Get(key []byte) ([]byte, error)
Get -
func (*StorageManagerStub) GetBaseTrieStorageManager ¶
func (sms *StorageManagerStub) GetBaseTrieStorageManager() common.StorageManager
GetBaseTrieStorageManager -
func (*StorageManagerStub) GetFromCurrentEpoch ¶
func (sms *StorageManagerStub) GetFromCurrentEpoch(key []byte) ([]byte, error)
GetFromCurrentEpoch -
func (*StorageManagerStub) GetLatestStorageEpoch ¶
func (sms *StorageManagerStub) GetLatestStorageEpoch() (uint32, error)
GetLatestStorageEpoch -
func (*StorageManagerStub) IsInterfaceNil ¶
func (sms *StorageManagerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*StorageManagerStub) IsPruningBlocked ¶
func (sms *StorageManagerStub) IsPruningBlocked() bool
IsPruningBlocked -
func (*StorageManagerStub) IsPruningEnabled ¶
func (sms *StorageManagerStub) IsPruningEnabled() bool
IsPruningEnabled -
func (*StorageManagerStub) Put ¶
func (sms *StorageManagerStub) Put(key []byte, val []byte) error
Put -
func (*StorageManagerStub) PutInEpoch ¶
func (sms *StorageManagerStub) PutInEpoch(key []byte, val []byte, epoch uint32) error
PutInEpoch -
func (*StorageManagerStub) PutInEpochWithoutCache ¶
func (sms *StorageManagerStub) PutInEpochWithoutCache(key []byte, val []byte, epoch uint32) error
PutInEpochWithoutCache -
func (*StorageManagerStub) Remove ¶
func (sms *StorageManagerStub) Remove(hash []byte) error
Remove -
func (*StorageManagerStub) RemoveFromCheckpointHashesHolder ¶
func (sms *StorageManagerStub) RemoveFromCheckpointHashesHolder(hash []byte)
RemoveFromCheckpointHashesHolder -
func (*StorageManagerStub) RemoveFromCurrentEpoch ¶
func (sms *StorageManagerStub) RemoveFromCurrentEpoch(hash []byte) error
RemoveFromCurrentEpoch -
func (*StorageManagerStub) SetCheckpoint ¶
func (sms *StorageManagerStub) SetCheckpoint( rootHash []byte, mainTrieRootHash []byte, iteratorChannels *common.TrieIteratorChannels, missingNodesChan chan []byte, stats common.SnapshotStatisticsHandler, )
SetCheckpoint -
func (*StorageManagerStub) SetEpochForPutOperation ¶
func (sms *StorageManagerStub) SetEpochForPutOperation(epoch uint32)
SetEpochForPutOperation -
func (*StorageManagerStub) ShouldTakeSnapshot ¶
func (sms *StorageManagerStub) ShouldTakeSnapshot() bool
ShouldTakeSnapshot -
func (*StorageManagerStub) TakeSnapshot ¶
func (sms *StorageManagerStub) TakeSnapshot( address string, rootHash []byte, mainTrieRootHash []byte, iteratorChannels *common.TrieIteratorChannels, missingNodesChan chan []byte, stats common.SnapshotStatisticsHandler, epoch uint32, )
TakeSnapshot -
type SyncTimerStub ¶
type SyncTimerStub struct { }
SyncTimerStub -
func (*SyncTimerStub) ClockOffset ¶
func (sts *SyncTimerStub) ClockOffset() time.Duration
ClockOffset -
func (*SyncTimerStub) FormattedCurrentTime ¶
func (sts *SyncTimerStub) FormattedCurrentTime() string
FormattedCurrentTime -
func (*SyncTimerStub) IsInterfaceNil ¶
func (sts *SyncTimerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*SyncTimerStub) StartSyncingTime ¶
func (sts *SyncTimerStub) StartSyncingTime()
StartSyncingTime -
type TimeCacheStub ¶
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 ¶
func (tcs *TimeCacheStub) IsInterfaceNil() bool
IsInterfaceNil -
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) RestoreBlockDataFromStorageCalled func(body *block.Body) (int, error) RemoveBlockDataFromPoolCalled func(body *block.Body) error RemoveTxsFromPoolCalled func(body *block.Body) error ProcessBlockTransactionCalled func(header data.HeaderHandler, body *block.Body, haveTime func() time.Duration) error CreateBlockStartedCalled func() CreateMbsAndProcessCrossShardTransactionsDstMeCalled func(header data.HeaderHandler, processedMiniBlocksInfo map[string]*processedMb.ProcessedMiniBlockInfo, haveTime func() bool, haveAdditionalTime func() bool, scheduledMode bool) (block.MiniBlockSlice, uint32, bool, error) CreateMbsAndProcessTransactionsFromMeCalled func(haveTime func() bool) block.MiniBlockSlice CreateMarshalizedDataCalled func(body *block.Body) map[string][][]byte GetCreatedInShardMiniBlocksCalled func() []*block.MiniBlock GetAllCurrentUsedTxsCalled func(blockType block.Type) map[string]data.TransactionHandler VerifyCreatedBlockTransactionsCalled func(hdr data.HeaderHandler, body *block.Body) error CreatePostProcessMiniBlocksCalled func() block.MiniBlockSlice VerifyCreatedMiniBlocksCalled func(hdr data.HeaderHandler, body *block.Body) error AddIntermediateTransactionsCalled func(mapSCRs map[block.Type][]data.TransactionHandler) error GetAllIntermediateTxsCalled func() map[block.Type]map[string]data.TransactionHandler AddTxsFromMiniBlocksCalled func(miniBlocks block.MiniBlockSlice) AddTransactionsCalled func(txHandlers []data.TransactionHandler, blockType block.Type) }
TransactionCoordinatorMock -
func (*TransactionCoordinatorMock) AddIntermediateTransactions ¶
func (tcm *TransactionCoordinatorMock) AddIntermediateTransactions(mapSCRs map[block.Type][]data.TransactionHandler) error
AddIntermediateTransactions -
func (*TransactionCoordinatorMock) AddTransactions ¶
func (tcm *TransactionCoordinatorMock) AddTransactions(txHandlers []data.TransactionHandler, blockType block.Type)
AddTransactions -
func (*TransactionCoordinatorMock) AddTxsFromMiniBlocks ¶
func (tcm *TransactionCoordinatorMock) AddTxsFromMiniBlocks(miniBlocks block.MiniBlockSlice)
AddTxsFromMiniBlocks -
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) CreateMbsAndProcessCrossShardTransactionsDstMe ¶
func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessCrossShardTransactionsDstMe( header data.HeaderHandler, processedMiniBlocksInfo map[string]*processedMb.ProcessedMiniBlockInfo, haveTime func() bool, haveAdditionalTime func() bool, scheduledMode bool, ) (block.MiniBlockSlice, uint32, bool, error)
CreateMbsAndProcessCrossShardTransactionsDstMe -
func (*TransactionCoordinatorMock) CreateMbsAndProcessTransactionsFromMe ¶
func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessTransactionsFromMe(haveTime func() bool, _ []byte) block.MiniBlockSlice
CreateMbsAndProcessTransactionsFromMe -
func (*TransactionCoordinatorMock) CreatePostProcessMiniBlocks ¶
func (tcm *TransactionCoordinatorMock) CreatePostProcessMiniBlocks() block.MiniBlockSlice
CreatePostProcessMiniBlocks -
func (*TransactionCoordinatorMock) CreateReceiptsHash ¶
func (tcm *TransactionCoordinatorMock) CreateReceiptsHash() ([]byte, error)
CreateReceiptsHash -
func (*TransactionCoordinatorMock) GetAllCurrentLogs ¶
func (tcm *TransactionCoordinatorMock) GetAllCurrentLogs() []*data.LogData
GetAllCurrentLogs -
func (*TransactionCoordinatorMock) GetAllCurrentUsedTxs ¶
func (tcm *TransactionCoordinatorMock) GetAllCurrentUsedTxs(blockType block.Type) map[string]data.TransactionHandler
GetAllCurrentUsedTxs -
func (*TransactionCoordinatorMock) GetAllIntermediateTxs ¶
func (tcm *TransactionCoordinatorMock) GetAllIntermediateTxs() map[block.Type]map[string]data.TransactionHandler
GetAllIntermediateTxs -
func (*TransactionCoordinatorMock) GetCreatedInShardMiniBlocks ¶
func (tcm *TransactionCoordinatorMock) GetCreatedInShardMiniBlocks() []*block.MiniBlock
GetCreatedInShardMiniBlocks -
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(header data.HeaderHandler, body *block.Body, haveTime func() time.Duration) error
ProcessBlockTransaction -
func (*TransactionCoordinatorMock) RemoveBlockDataFromPool ¶
func (tcm *TransactionCoordinatorMock) RemoveBlockDataFromPool(body *block.Body) error
RemoveBlockDataFromPool -
func (*TransactionCoordinatorMock) RemoveTxsFromPool ¶
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 ¶
func (tcm *TransactionCoordinatorMock) SaveTxsToStorage(body *block.Body)
SaveTxsToStorage -
func (*TransactionCoordinatorMock) VerifyCreatedBlockTransactions ¶
func (tcm *TransactionCoordinatorMock) VerifyCreatedBlockTransactions(hdr data.HeaderHandler, body *block.Body) error
VerifyCreatedBlockTransactions -
func (*TransactionCoordinatorMock) VerifyCreatedMiniBlocks ¶
func (tcm *TransactionCoordinatorMock) VerifyCreatedMiniBlocks(hdr data.HeaderHandler, body *block.Body) error
VerifyCreatedMiniBlocks -
type TxProcessorMock ¶
type TxProcessorMock struct { ProcessTransactionCalled func(transaction *transaction.Transaction) (vmcommon.ReturnCode, error) VerifyTransactionCalled func(tx *transaction.Transaction) error SetBalancesToTrieCalled func(accBalance map[string]*big.Int) (rootHash []byte, err error) ProcessSmartContractResultCalled func(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error) }
TxProcessorMock -
func (*TxProcessorMock) IsInterfaceNil ¶
func (etm *TxProcessorMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*TxProcessorMock) ProcessSmartContractResult ¶
func (etm *TxProcessorMock) ProcessSmartContractResult(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)
ProcessSmartContractResult -
func (*TxProcessorMock) ProcessTransaction ¶
func (etm *TxProcessorMock) ProcessTransaction(transaction *transaction.Transaction) (vmcommon.ReturnCode, error)
ProcessTransaction -
func (*TxProcessorMock) SetBalancesToTrie ¶
func (etm *TxProcessorMock) SetBalancesToTrie(accBalance map[string]*big.Int) (rootHash []byte, err error)
SetBalancesToTrie -
func (*TxProcessorMock) VerifyTransaction ¶
func (etm *TxProcessorMock) VerifyTransaction(tx *transaction.Transaction) error
VerifyTransaction -
type TxProcessorStub ¶
type TxProcessorStub struct { ProcessTransactionCalled func(transaction *transaction.Transaction) (vmcommon.ReturnCode, error) VerifyTransactionCalled func(tx *transaction.Transaction) error }
TxProcessorStub -
func (*TxProcessorStub) IsInterfaceNil ¶
func (tps *TxProcessorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*TxProcessorStub) ProcessTransaction ¶
func (tps *TxProcessorStub) ProcessTransaction(transaction *transaction.Transaction) (vmcommon.ReturnCode, error)
ProcessTransaction -
func (*TxProcessorStub) VerifyTransaction ¶
func (tps *TxProcessorStub) VerifyTransaction(tx *transaction.Transaction) error
VerifyTransaction -
type TxTypeHandlerMock ¶
type TxTypeHandlerMock struct {
ComputeTransactionTypeCalled func(tx data.TransactionHandler) (process.TransactionType, process.TransactionType)
}
TxTypeHandlerMock -
func (*TxTypeHandlerMock) ComputeTransactionType ¶
func (th *TxTypeHandlerMock) ComputeTransactionType(tx data.TransactionHandler) (process.TransactionType, process.TransactionType)
ComputeTransactionType -
func (*TxTypeHandlerMock) IsInterfaceNil ¶
func (th *TxTypeHandlerMock) IsInterfaceNil() bool
IsInterfaceNil -
type TxVersionCheckerStub ¶ added in v1.5.0
type TxVersionCheckerStub struct { IsSignedWithHashCalled func(tx *transaction.Transaction) bool IsGuardedTransactionCalled func(tx *transaction.Transaction) bool CheckTxVersionCalled func(tx *transaction.Transaction) error }
TxVersionCheckerStub -
func (*TxVersionCheckerStub) CheckTxVersion ¶ added in v1.5.0
func (tvcs *TxVersionCheckerStub) CheckTxVersion(tx *transaction.Transaction) error
CheckTxVersion will check transaction version
func (*TxVersionCheckerStub) IsGuardedTransaction ¶ added in v1.5.0
func (tvcs *TxVersionCheckerStub) IsGuardedTransaction(tx *transaction.Transaction) bool
IsGuardedTransaction will return true if transaction also holds a guardian signature
func (*TxVersionCheckerStub) IsInterfaceNil ¶ added in v1.5.0
func (tvcs *TxVersionCheckerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*TxVersionCheckerStub) IsSignedWithHash ¶ added in v1.5.0
func (tvcs *TxVersionCheckerStub) IsSignedWithHash(tx *transaction.Transaction) bool
IsSignedWithHash will return true if transaction is signed with hash
type UnsignedTxHandlerStub ¶
type UnsignedTxHandlerStub struct { CleanProcessedUtxsCalled func() ProcessTransactionFeeCalled func(cost *big.Int, fee *big.Int, hash []byte) ProcessTransactionFeeRelayedUserTxCalled func(cost *big.Int, devFee *big.Int, userTxHash []byte, originalTxHash []byte) CreateAllUTxsCalled func() []data.TransactionHandler VerifyCreatedUTxsCalled func() error AddTxFeeFromBlockCalled func(tx data.TransactionHandler) GetAccumulatedFeesCalled func() *big.Int GetDeveloperFeesCalled func() *big.Int RevertFeesCalled func(txHashes [][]byte) }
UnsignedTxHandlerStub -
func (*UnsignedTxHandlerStub) AddRewardTxFromBlock ¶
func (ut *UnsignedTxHandlerStub) AddRewardTxFromBlock(tx data.TransactionHandler)
AddRewardTxFromBlock -
func (*UnsignedTxHandlerStub) CleanProcessedUTxs ¶
func (ut *UnsignedTxHandlerStub) CleanProcessedUTxs()
CleanProcessedUTxs -
func (*UnsignedTxHandlerStub) CreateAllUTxs ¶
func (ut *UnsignedTxHandlerStub) CreateAllUTxs() []data.TransactionHandler
CreateAllUTxs -
func (*UnsignedTxHandlerStub) CreateBlockStarted ¶
func (ut *UnsignedTxHandlerStub) CreateBlockStarted(_ scheduled.GasAndFees)
CreateBlockStarted -
func (*UnsignedTxHandlerStub) GetAccumulatedFees ¶
func (ut *UnsignedTxHandlerStub) GetAccumulatedFees() *big.Int
GetAccumulatedFees -
func (*UnsignedTxHandlerStub) GetDeveloperFees ¶
func (ut *UnsignedTxHandlerStub) GetDeveloperFees() *big.Int
GetDeveloperFees -
func (*UnsignedTxHandlerStub) IsInterfaceNil ¶
func (ut *UnsignedTxHandlerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*UnsignedTxHandlerStub) ProcessTransactionFee ¶
func (ut *UnsignedTxHandlerStub) ProcessTransactionFee(cost *big.Int, devFee *big.Int, txHash []byte)
ProcessTransactionFee -
func (*UnsignedTxHandlerStub) ProcessTransactionFeeRelayedUserTx ¶
func (ut *UnsignedTxHandlerStub) ProcessTransactionFeeRelayedUserTx(cost *big.Int, devFee *big.Int, userTxHash []byte, originalTxHash []byte)
ProcessTransactionFeeRelayedUserTx -
func (*UnsignedTxHandlerStub) RevertFees ¶
func (ut *UnsignedTxHandlerStub) RevertFees(txHashes [][]byte)
RevertFees -
func (*UnsignedTxHandlerStub) VerifyCreatedUTxs ¶
func (ut *UnsignedTxHandlerStub) VerifyCreatedUTxs() error
VerifyCreatedUTxs -
type VersionedHeaderFactoryStub ¶
type VersionedHeaderFactoryStub struct {
CreateCalled func(epoch uint32) data.HeaderHandler
}
VersionedHeaderFactoryStub -
func (*VersionedHeaderFactoryStub) Create ¶
func (vhfs *VersionedHeaderFactoryStub) Create(epoch uint32) data.HeaderHandler
Create -
func (*VersionedHeaderFactoryStub) IsInterfaceNil ¶
func (vhfs *VersionedHeaderFactoryStub) IsInterfaceNil() bool
IsInterfaceNil -
type WatchdogMock ¶
type WatchdogMock struct { }
WatchdogMock -
func (*WatchdogMock) Set ¶
func (w *WatchdogMock) Set(_ func(alarmID string), _ time.Duration, _ string)
Set -
func (*WatchdogMock) SetDefault ¶
func (w *WatchdogMock) SetDefault(_ time.Duration, _ string)
SetDefault -
type WhiteListHandlerStub ¶
type WhiteListHandlerStub struct { RemoveCalled func(keys [][]byte) AddCalled func(keys [][]byte) IsWhiteListedCalled func(interceptedData process.InterceptedData) bool IsWhiteListedAtLeastOneCalled func(identifiers [][]byte) bool IsForCurrentShardCalled func(interceptedData process.InterceptedData) bool }
WhiteListHandlerStub -
func (*WhiteListHandlerStub) IsForCurrentShard ¶
func (w *WhiteListHandlerStub) IsForCurrentShard(interceptedData process.InterceptedData) bool
IsForCurrentShard -
func (*WhiteListHandlerStub) IsInterfaceNil ¶
func (w *WhiteListHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*WhiteListHandlerStub) IsWhiteListed ¶
func (w *WhiteListHandlerStub) IsWhiteListed(interceptedData process.InterceptedData) bool
IsWhiteListed -
func (*WhiteListHandlerStub) IsWhiteListedAtLeastOne ¶
func (w *WhiteListHandlerStub) IsWhiteListedAtLeastOne(identifiers [][]byte) bool
IsWhiteListedAtLeastOne -
Source Files ¶
- TxVersionCheckerStub.go
- addresses.go
- alarmStub.go
- alteredAccountsProviderStub.go
- balanceComputationStub.go
- blockChainHookCounterStub.go
- blockChainHookStub.go
- blockInfoProviderStub.go
- blockProcessorStub.go
- blockSizeComputationStub.go
- builtInCostHandlerStub.go
- cacherMock.go
- cacherStub.go
- chainHandlerMock.go
- chainHandlerStub.go
- currentEpochProviderStub.go
- customDatabaseRemoverStub.go
- dataFieldParserStub.go
- economicsConfig.go
- enableEpochsHandlerStub.go
- enableRoundsHandlerStub.go
- epochStartTriggerStub.go
- errors.go
- esdtGlobalSettingsHandlerStub.go
- esdtStorageHandlerStub.go
- esdtTransferParserStub.go
- fallbackHeaderValidatorStub.go
- feeComputerStub.go
- gasHandlerStub.go
- gasScheduleNotifierMock.go
- generalConfig.go
- ginServerWithRawQuery.go
- hardforkTriggerStub.go
- hasherStub.go
- headerHandlerStub.go
- headerVersionHandlerStub.go
- importStartHandlerStub.go
- interceptedDataStub.go
- interceptorContainerStub.go
- interceptorStub.go
- keccakMock.go
- loggerStub.go
- logsFacadeStub.go
- marshalizerMock.go
- marshalizerStub.go
- memDbMock.go
- messageSigVerifierMock.go
- nodesSetupMock.go
- nonceHashConverterMock.go
- oldDataCleanerProviderStub.go
- panicDoubleTransactionsDetector.go
- pathHandlerStub.go
- peerAuthenticationPayloadValidatorStub.go
- peerHonestyHandlerStub.go
- preProcessorExecutionInfoHandlerMock.go
- processDebuggerStub.go
- processStatusHandlerStub.go
- processedMiniBlocksTrackerStub.go
- protoMarshalizerMock.go
- protobufMock.go
- pubkeyConverterMock.go
- raterMock.go
- ratingsInfoMock.go
- receiptsRepositoryStub.go
- requestHandlerStub.go
- requestedItemsHandlerStub.go
- rewardTxProcessorMock.go
- rounderMock.go
- scProcessorMock.go
- scheduledTxsExecutionStub.go
- shardCoordinator.go
- shardedDataCacheNotifierMock.go
- shardedDataStub.go
- simpleNFTStorageHandlerStub.go
- sizeSyncStatisticsHandlerStub.go
- smartContractResultProcessorMock.go
- snapshotPruningStorerMock.go
- stateComponentsMock.go
- statusMetricsStub.go
- storageManagerStub.go
- syncTimerMock.go
- timeCacherStub.go
- timeoutHandlerMock.go
- transactionCoordinatorMock.go
- txProcessorMock.go
- txProcessorStub.go
- txTypeHandlerMock.go
- unsignedTxHandlerStub.go
- utils.go
- versionedHeaderFactoryStub.go
- watchdogMock.go
- whiteListHandlerStub.go