Documentation ¶
Index ¶
- type Accounts
- func (a *Accounts) CancelPrune(_ []byte, _ state.TriePruningIdentifier)
- func (a *Accounts) Close() error
- func (a *Accounts) Commit() ([]byte, error)
- func (a *Accounts) CommitInEpoch(uint32, uint32) ([]byte, error)
- func (a *Accounts) GetAccountFromBytes(_ []byte, _ []byte) (vmcommon.AccountHandler, error)
- func (a *Accounts) GetAllLeaves(_ *common.TrieIteratorChannels, _ context.Context, _ []byte, ...) error
- func (a *Accounts) GetCode(_ []byte) []byte
- func (a *Accounts) GetExistingAccount(_ []byte) (vmcommon.AccountHandler, error)
- func (a *Accounts) GetNumCheckpoints() uint32
- func (a *Accounts) GetStackDebugFirstEntry() []byte
- func (a *Accounts) GetTrie(_ []byte) (common.Trie, error)
- func (a *Accounts) IsInterfaceNil() bool
- func (a *Accounts) IsPruningEnabled() bool
- func (a *Accounts) JournalLen() int
- func (a *Accounts) LoadAccount(_ []byte) (vmcommon.AccountHandler, error)
- func (a *Accounts) PruneTrie(_ []byte, _ state.TriePruningIdentifier, _ state.PruningHandler)
- func (a *Accounts) RecreateAllTries(_ []byte) (map[string]common.Trie, error)
- func (a *Accounts) RecreateTrie(_ []byte) error
- func (a *Accounts) RecreateTrieFromEpoch(_ common.RootHashHolder) error
- func (a *Accounts) RemoveAccount(_ []byte) error
- func (a *Accounts) RevertToSnapshot(_ int) error
- func (a *Accounts) RootHash() ([]byte, error)
- func (a *Accounts) SaveAccount(_ vmcommon.AccountHandler) error
- func (a *Accounts) SetStateCheckpoint(_ []byte)
- func (a *Accounts) SetSyncer(_ state.AccountsDBSyncer) error
- func (a *Accounts) SnapshotState(_ []byte, _ uint32)
- func (a *Accounts) StartSnapshotIfNeeded() error
- type BlockChainHookCounter
- func (bhc *BlockChainHookCounter) GetCounterValues() map[string]uint64
- func (bhc *BlockChainHookCounter) IsInterfaceNil() bool
- func (bhc *BlockChainHookCounter) ProcessCrtNumberOfTrieReadsCounter() error
- func (bhc *BlockChainHookCounter) ProcessMaxBuiltInCounters(_ *vmcommon.ContractCallInput) error
- func (bhc *BlockChainHookCounter) ResetCounters()
- func (bhc *BlockChainHookCounter) SetMaximumValues(_ map[string]uint64)
- type Blockchain
- func (b *Blockchain) CreateNewHeader() data.HeaderHandler
- func (b *Blockchain) GetCurrentBlockHeader() data.HeaderHandler
- func (b *Blockchain) GetCurrentBlockHeaderHash() []byte
- func (b *Blockchain) GetCurrentBlockRootHash() []byte
- func (b *Blockchain) GetFinalBlockInfo() (uint64, []byte, []byte)
- func (b *Blockchain) GetGenesisHeader() data.HeaderHandler
- func (b *Blockchain) GetGenesisHeaderHash() []byte
- func (b *Blockchain) IsInterfaceNil() bool
- func (b *Blockchain) SetCurrentBlockHeader(_ data.HeaderHandler) error
- func (b *Blockchain) SetCurrentBlockHeaderAndRootHash(_ data.HeaderHandler, _ []byte) error
- func (b *Blockchain) SetCurrentBlockHeaderHash(_ []byte)
- func (b *Blockchain) SetFinalBlockInfo(_ uint64, _ []byte, _ []byte)
- func (b *Blockchain) SetGenesisHeader(_ data.HeaderHandler) error
- func (b *Blockchain) SetGenesisHeaderHash(_ []byte)
- type BuiltInFunctionContainer
- func (bifc *BuiltInFunctionContainer) Add(_ string, _ vmcommon.BuiltinFunction) error
- func (bifc *BuiltInFunctionContainer) Get(_ string) (vmcommon.BuiltinFunction, error)
- func (bifc *BuiltInFunctionContainer) IsInterfaceNil() bool
- func (bifc *BuiltInFunctionContainer) Keys() map[string]struct{}
- func (bifc *BuiltInFunctionContainer) Len() int
- func (bifc *BuiltInFunctionContainer) Remove(_ string)
- func (bifc *BuiltInFunctionContainer) Replace(_ string, _ vmcommon.BuiltinFunction) error
- type Cache
- type DataPool
- func (dp *DataPool) Close() error
- func (dp *DataPool) CurrentBlockTxs() dataRetriever.TransactionCacher
- func (dp *DataPool) CurrentEpochValidatorInfo() dataRetriever.ValidatorInfoCacher
- func (dp *DataPool) Headers() dataRetriever.HeadersPool
- func (dp *DataPool) Heartbeats() storage.Cacher
- func (dp *DataPool) IsInterfaceNil() bool
- func (dp *DataPool) MiniBlocks() storage.Cacher
- func (dp *DataPool) PeerAuthentications() storage.Cacher
- func (dp *DataPool) PeerChangesBlocks() storage.Cacher
- func (dp *DataPool) RewardTransactions() dataRetriever.ShardedDataCacherNotifier
- func (dp *DataPool) SmartContracts() storage.Cacher
- func (dp *DataPool) Transactions() dataRetriever.ShardedDataCacherNotifier
- func (dp *DataPool) TrieNodes() storage.Cacher
- func (dp *DataPool) TrieNodesChunks() storage.Cacher
- func (dp *DataPool) UnsignedTransactions() dataRetriever.ShardedDataCacherNotifier
- func (dp *DataPool) ValidatorsInfo() dataRetriever.ShardedDataCacherNotifier
- type EnableEpochsHandler
- func (eeh *EnableEpochsHandler) BalanceWaitingListsEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) BlockGasAndFeesReCheckEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) CheckExecuteReadOnlyEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) CreateNFTThroughExecByCallerEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) DisableExecByCallerEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) FixDelegationChangeOwnerOnAccountEnabled() bool
- func (eeh *EnableEpochsHandler) FixFailExecutionOnErrorEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) FixOOGReturnCodeEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) IsAddFailedRelayedTxToInvalidMBsFlag() bool
- func (eeh *EnableEpochsHandler) IsAddTokensToDelegationFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsAheadOfTimeGasUsageFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsAlwaysSaveTokenMetaDataEnabled() bool
- func (eeh *EnableEpochsHandler) IsAutoBalanceDataTriesEnabled() bool
- func (eeh *EnableEpochsHandler) IsBackwardCompSaveKeyValueFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsBalanceWaitingListsFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsBelowSignedThresholdFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsBuiltInFunctionOnMetaFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsBuiltInFunctionsFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsChangeDelegationOwnerFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsChangeUsernameEnabled() bool
- func (eeh *EnableEpochsHandler) IsCheckCorrectTokenIDForTransferRoleFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsCheckExecuteOnReadOnlyFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsCheckFrozenCollectionFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsCheckFunctionArgumentFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsCheckTransferFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsCleanUpInformativeSCRsFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsComputeRewardCheckpointFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsConsistentTokensValuesLengthCheckEnabled() bool
- func (eeh *EnableEpochsHandler) IsCorrectFirstQueuedFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsCorrectJailedNotUnStakedEmptyQueueFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsCorrectLastUnJailedFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsCorrectLastUnJailedFlagEnabledForCurrentEpoch() bool
- func (eeh *EnableEpochsHandler) IsCreateNFTThroughExecByCallerFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsDelegationManagerFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsDelegationSmartContractFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsDelegationSmartContractFlagEnabledForCurrentEpoch() bool
- func (eeh *EnableEpochsHandler) IsDeleteDelegatorAfterClaimRewardsFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsDeterministicSortOnValidatorsInfoFixEnabled() bool
- func (eeh *EnableEpochsHandler) IsDisableExecByCallerFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsDoNotReturnOldBlockInBlockchainHookFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsDoubleKeyProtectionFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsDynamicGasCostForDataTrieStorageLoadEnabled() bool
- func (eeh *EnableEpochsHandler) IsESDTFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsESDTFlagEnabledForCurrentEpoch() bool
- func (eeh *EnableEpochsHandler) IsESDTMetadataContinuousCleanupFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsESDTMultiTransferFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsESDTNFTCreateOnMultiShardFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsESDTNFTImprovementV1FlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsESDTRegisterAndSetAllRolesFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsESDTTransferRoleFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsFailExecutionOnEveryAPIErrorFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsFixAsyncCallBackArgsListFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsFixAsyncCallbackCheckFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsFixOOGReturnCodeFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsFixOldTokenLiquidityEnabled() bool
- func (eeh *EnableEpochsHandler) IsFrontRunningProtectionFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsGasPriceModifierFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsGlobalMintBurnFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsGovernanceFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsGovernanceFlagEnabledForCurrentEpoch() bool
- func (eeh *EnableEpochsHandler) IsIncrementSCRNonceInMultiTransferFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsInterfaceNil() bool
- func (eeh *EnableEpochsHandler) IsKeepExecOrderOnCreatedSCRsEnabled() bool
- func (eeh *EnableEpochsHandler) IsManagedCryptoAPIsFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsMaxBlockchainHookCountersFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsMetaESDTSetFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsMetaProtectionFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsMiniBlockPartialExecutionFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsMultiClaimOnDelegationEnabled() bool
- func (eeh *EnableEpochsHandler) IsMultiESDTTransferFixOnCallBackFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsOptimizeGasUsedInCrossMiniBlocksFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsOptimizeNFTStoreFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsPayableBySCFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsPenalizedTooMuchGasFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsReDelegateBelowMinCheckFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsRefactorContextFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsRefactorPeersMiniBlocksFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsRelayedNonceFixEnabled() bool
- func (eeh *EnableEpochsHandler) IsRelayedTransactionsFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsRelayedTransactionsV2FlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsRemoveNonUpdatedStorageFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsRepairCallbackFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsReturnDataToLastTransferFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsRuntimeCodeSizeFixEnabled() bool
- func (eeh *EnableEpochsHandler) IsRuntimeMemStoreLimitEnabled() bool
- func (eeh *EnableEpochsHandler) IsSCDeployFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsSCProcessorV2FlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsSCRSizeInvariantCheckFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsSCRSizeInvariantOnBuiltInResultFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsSaveJailedAlwaysFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsSaveToSystemAccountFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsScToScEventLogEnabled() bool
- func (eeh *EnableEpochsHandler) IsScheduledMiniBlocksFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsSendAlwaysFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsSenderInOutTransferFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsSetGuardianEnabled() bool
- func (eeh *EnableEpochsHandler) IsSetSenderInEeiOutputTransferFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsStakeFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsStakingV2FlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsStakingV2FlagEnabledForActivationEpochCompleted() bool
- func (eeh *EnableEpochsHandler) IsStakingV2OwnerFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsStopDecreasingValidatorRatingWhenStuckFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsStorageAPICostOptimizationFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsSwitchHysteresisForMinNodesFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsSwitchHysteresisForMinNodesFlagEnabledForCurrentEpoch() bool
- func (eeh *EnableEpochsHandler) IsSwitchJailWaitingFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsTransactionSignedWithTxHashFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsTransferToMetaFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsUnBondTokensV2FlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsValidatorToDelegationFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsValueLengthCheckFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsWaitingListFixFlagEnabled() bool
- func (eeh *EnableEpochsHandler) IsWipeSingleNFTLiquidityDecreaseEnabled() bool
- func (eeh *EnableEpochsHandler) ManagedCryptoAPIEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) MiniBlockPartialExecutionEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) MultiESDTTransferAsyncCallBackEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) RefactorContextEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) RefactorPeersMiniBlocksEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) RemoveNonUpdatedStorageEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) ResetPenalizedTooMuchGasFlag()
- func (eeh *EnableEpochsHandler) ScheduledMiniBlocksEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) StakingV2EnableEpoch() uint32
- func (eeh *EnableEpochsHandler) StorageAPICostOptimizationEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) SwitchJailWaitingEnableEpoch() uint32
- func (eeh *EnableEpochsHandler) WaitingListFixEnableEpoch() uint32
- type EpochNotifier
- type EpochStartNotifier
- type FallBackHeaderValidator
- type GasScheduleNotifier
- func (gsn *GasScheduleNotifier) ChangeGasSchedule(_ map[string]map[string]uint64)
- func (gsn *GasScheduleNotifier) IsInterfaceNil() bool
- func (gsn *GasScheduleNotifier) LatestGasSchedule() map[string]map[string]uint64
- func (gsn *GasScheduleNotifier) RegisterNotifyHandler(_ core.GasScheduleSubscribeHandler)
- func (gsn *GasScheduleNotifier) UnRegisterAll()
- type GlobalSettingsHandler
- type MissingTrieNodesNotifier
- type NodeTypeProvider
- type ShardCoordinator
- func (sc *ShardCoordinator) CommunicationIdentifier(_ uint32) string
- func (sc *ShardCoordinator) ComputeId(_ []byte) uint32
- func (sc *ShardCoordinator) IsInterfaceNil() bool
- func (sc *ShardCoordinator) NumberOfShards() uint32
- func (sc *ShardCoordinator) SameShard(_, _ []byte) bool
- func (sc *ShardCoordinator) SelfId() uint32
- type ShuffledOutHandler
- type SimpleESDTNFTStorageHandler
- func (sns *SimpleESDTNFTStorageHandler) GetESDTNFTTokenOnDestination(_ vmcommon.UserAccountHandler, _ []byte, _ uint64) (*esdt.ESDigitalToken, bool, error)
- func (sns *SimpleESDTNFTStorageHandler) IsInterfaceNil() bool
- func (sns *SimpleESDTNFTStorageHandler) SaveNFTMetaDataToSystemAccount(_ data.TransactionHandler) error
- type StorageService
- func (ss *StorageService) AddStorer(_ dataRetriever.UnitType, _ storage.Storer)
- func (ss *StorageService) CloseAll() error
- func (ss *StorageService) Destroy() error
- func (ss *StorageService) Get(_ dataRetriever.UnitType, _ []byte) ([]byte, error)
- func (ss *StorageService) GetAll(_ dataRetriever.UnitType, _ [][]byte) (map[string][]byte, error)
- func (ss *StorageService) GetAllStorers() map[dataRetriever.UnitType]storage.Storer
- func (ss *StorageService) GetStorer(_ dataRetriever.UnitType) (storage.Storer, error)
- func (ss *StorageService) Has(_ dataRetriever.UnitType, _ []byte) error
- func (ss *StorageService) IsInterfaceNil() bool
- func (ss *StorageService) Put(_ dataRetriever.UnitType, _ []byte, _ []byte) error
- func (ss *StorageService) SetEpochForPutOperation(_ uint32)
- type Storer
- func (s *Storer) ClearCache()
- func (s *Storer) Close() error
- func (s *Storer) DestroyUnit() error
- func (s *Storer) Get(_ []byte) ([]byte, error)
- func (s *Storer) GetBulkFromEpoch(_ [][]byte, _ uint32) ([]storage.KeyValuePair, error)
- func (s *Storer) GetFromEpoch(_ []byte, _ uint32) ([]byte, error)
- func (s *Storer) GetOldestEpoch() (uint32, error)
- func (s *Storer) Has(_ []byte) error
- func (s *Storer) IsInterfaceNil() bool
- func (s *Storer) Put(_, _ []byte) error
- func (s *Storer) PutInEpoch(_, _ []byte, _ uint32) error
- func (s *Storer) RangeKeys(_ func(_ []byte, _ []byte) bool)
- func (s *Storer) Remove(_ []byte) error
- func (s *Storer) RemoveFromCurrentEpoch(_ []byte) error
- func (s *Storer) SearchFirst(_ []byte) ([]byte, error)
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
This section is empty.
Types ¶
type Accounts ¶
type Accounts struct { }
Accounts is a disabled implementation of the AccountAdapter interface
func (*Accounts) CancelPrune ¶
func (a *Accounts) CancelPrune(_ []byte, _ state.TriePruningIdentifier)
CancelPrune does nothing
func (*Accounts) CommitInEpoch ¶
CommitInEpoch returns nil byte slice and nil
func (*Accounts) GetAccountFromBytes ¶
GetAccountFromBytes returns a nil account and nil error
func (*Accounts) GetAllLeaves ¶
func (a *Accounts) GetAllLeaves(_ *common.TrieIteratorChannels, _ context.Context, _ []byte, _ common.TrieLeafParser) error
GetAllLeaves returns nil
func (*Accounts) GetExistingAccount ¶
func (a *Accounts) GetExistingAccount(_ []byte) (vmcommon.AccountHandler, error)
GetExistingAccount returns nil account handler and nil error
func (*Accounts) GetNumCheckpoints ¶
GetNumCheckpoints returns 0
func (*Accounts) GetStackDebugFirstEntry ¶
GetStackDebugFirstEntry return nil
func (*Accounts) IsInterfaceNil ¶
IsInterfaceNil returns true if there is no value under the interface
func (*Accounts) IsPruningEnabled ¶
IsPruningEnabled returns false
func (*Accounts) LoadAccount ¶
func (a *Accounts) LoadAccount(_ []byte) (vmcommon.AccountHandler, error)
LoadAccount returns a nil account and nil error
func (*Accounts) PruneTrie ¶
func (a *Accounts) PruneTrie(_ []byte, _ state.TriePruningIdentifier, _ state.PruningHandler)
PruneTrie does nothing
func (*Accounts) RecreateAllTries ¶
RecreateAllTries return a nil map and nil error
func (*Accounts) RecreateTrie ¶
RecreateTrie returns nil
func (*Accounts) RecreateTrieFromEpoch ¶
func (a *Accounts) RecreateTrieFromEpoch(_ common.RootHashHolder) error
RecreateTrieFromEpoch returns nil
func (*Accounts) RemoveAccount ¶
RemoveAccount returns nil
func (*Accounts) RevertToSnapshot ¶
RevertToSnapshot returns nil
func (*Accounts) SaveAccount ¶
func (a *Accounts) SaveAccount(_ vmcommon.AccountHandler) error
SaveAccount returns nil
func (*Accounts) SetStateCheckpoint ¶
SetStateCheckpoint does nothing
func (*Accounts) SetSyncer ¶
func (a *Accounts) SetSyncer(_ state.AccountsDBSyncer) error
SetSyncer returns nil
func (*Accounts) SnapshotState ¶
SnapshotState does nothing
func (*Accounts) StartSnapshotIfNeeded ¶
StartSnapshotIfNeeded returns nil
type BlockChainHookCounter ¶
type BlockChainHookCounter struct { }
BlockChainHookCounter is a disabled implementation of BlockChainHookCounter interface
func (*BlockChainHookCounter) GetCounterValues ¶
func (bhc *BlockChainHookCounter) GetCounterValues() map[string]uint64
GetCounterValues -
func (*BlockChainHookCounter) IsInterfaceNil ¶
func (bhc *BlockChainHookCounter) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*BlockChainHookCounter) ProcessCrtNumberOfTrieReadsCounter ¶
func (bhc *BlockChainHookCounter) ProcessCrtNumberOfTrieReadsCounter() error
ProcessCrtNumberOfTrieReadsCounter returns nil
func (*BlockChainHookCounter) ProcessMaxBuiltInCounters ¶
func (bhc *BlockChainHookCounter) ProcessMaxBuiltInCounters(_ *vmcommon.ContractCallInput) error
ProcessMaxBuiltInCounters returns nil
func (*BlockChainHookCounter) ResetCounters ¶
func (bhc *BlockChainHookCounter) ResetCounters()
ResetCounters does nothing
func (*BlockChainHookCounter) SetMaximumValues ¶
func (bhc *BlockChainHookCounter) SetMaximumValues(_ map[string]uint64)
SetMaximumValues does nothing
type Blockchain ¶
type Blockchain struct { }
Blockchain is a disabled implementation of the ChainHandler interface
func (*Blockchain) CreateNewHeader ¶
func (b *Blockchain) CreateNewHeader() data.HeaderHandler
CreateNewHeader returns nil
func (*Blockchain) GetCurrentBlockHeader ¶
func (b *Blockchain) GetCurrentBlockHeader() data.HeaderHandler
GetCurrentBlockHeader returns nil
func (*Blockchain) GetCurrentBlockHeaderHash ¶
func (b *Blockchain) GetCurrentBlockHeaderHash() []byte
GetCurrentBlockHeaderHash returns nil
func (*Blockchain) GetCurrentBlockRootHash ¶
func (b *Blockchain) GetCurrentBlockRootHash() []byte
GetCurrentBlockRootHash returns nil
func (*Blockchain) GetFinalBlockInfo ¶
func (b *Blockchain) GetFinalBlockInfo() (uint64, []byte, []byte)
GetFinalBlockInfo return 0 and empty slices
func (*Blockchain) GetGenesisHeader ¶
func (b *Blockchain) GetGenesisHeader() data.HeaderHandler
GetGenesisHeader returns nil
func (*Blockchain) GetGenesisHeaderHash ¶
func (b *Blockchain) GetGenesisHeaderHash() []byte
GetGenesisHeaderHash returns nil
func (*Blockchain) IsInterfaceNil ¶
func (b *Blockchain) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*Blockchain) SetCurrentBlockHeader ¶
func (b *Blockchain) SetCurrentBlockHeader(_ data.HeaderHandler) error
SetCurrentBlockHeader returns nil
func (*Blockchain) SetCurrentBlockHeaderAndRootHash ¶
func (b *Blockchain) SetCurrentBlockHeaderAndRootHash(_ data.HeaderHandler, _ []byte) error
SetCurrentBlockHeaderAndRootHash return nil
func (*Blockchain) SetCurrentBlockHeaderHash ¶
func (b *Blockchain) SetCurrentBlockHeaderHash(_ []byte)
SetCurrentBlockHeaderHash does nothing
func (*Blockchain) SetFinalBlockInfo ¶
func (b *Blockchain) SetFinalBlockInfo(_ uint64, _ []byte, _ []byte)
SetFinalBlockInfo does nothing
func (*Blockchain) SetGenesisHeader ¶
func (b *Blockchain) SetGenesisHeader(_ data.HeaderHandler) error
SetGenesisHeader returns nil
func (*Blockchain) SetGenesisHeaderHash ¶
func (b *Blockchain) SetGenesisHeaderHash(_ []byte)
SetGenesisHeaderHash does nothing
type BuiltInFunctionContainer ¶
type BuiltInFunctionContainer struct { }
BuiltInFunctionContainer is a disabled implementation of the vmcommon.BuiltInFunctionContainer interface
func (*BuiltInFunctionContainer) Add ¶
func (bifc *BuiltInFunctionContainer) Add(_ string, _ vmcommon.BuiltinFunction) error
Add does nothing and returns nil error
func (*BuiltInFunctionContainer) Get ¶
func (bifc *BuiltInFunctionContainer) Get(_ string) (vmcommon.BuiltinFunction, error)
Get returns nil and error
func (*BuiltInFunctionContainer) IsInterfaceNil ¶
func (bifc *BuiltInFunctionContainer) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*BuiltInFunctionContainer) Keys ¶
func (bifc *BuiltInFunctionContainer) Keys() map[string]struct{}
Keys returns an empty map
func (*BuiltInFunctionContainer) Len ¶
func (bifc *BuiltInFunctionContainer) Len() int
Len returns 0
func (*BuiltInFunctionContainer) Remove ¶
func (bifc *BuiltInFunctionContainer) Remove(_ string)
Remove does nothing
func (*BuiltInFunctionContainer) Replace ¶
func (bifc *BuiltInFunctionContainer) Replace(_ string, _ vmcommon.BuiltinFunction) error
Replace does nothing and returns nil error
type DataPool ¶
type DataPool struct { }
DataPool is the disabled implementation of a PoolsHolder interface
func (*DataPool) CurrentBlockTxs ¶
func (dp *DataPool) CurrentBlockTxs() dataRetriever.TransactionCacher
CurrentBlockTxs returns nil
func (*DataPool) CurrentEpochValidatorInfo ¶
func (dp *DataPool) CurrentEpochValidatorInfo() dataRetriever.ValidatorInfoCacher
CurrentEpochValidatorInfo returns nil
func (*DataPool) Headers ¶
func (dp *DataPool) Headers() dataRetriever.HeadersPool
Headers returns nil
func (*DataPool) Heartbeats ¶
Heartbeats returns nil
func (*DataPool) IsInterfaceNil ¶
IsInterfaceNil returns true if there is no value under the interface
func (*DataPool) MiniBlocks ¶
MiniBlocks returns nil
func (*DataPool) PeerAuthentications ¶
PeerAuthentications returns nil
func (*DataPool) PeerChangesBlocks ¶
PeerChangesBlocks returns nil
func (*DataPool) RewardTransactions ¶
func (dp *DataPool) RewardTransactions() dataRetriever.ShardedDataCacherNotifier
RewardTransactions returns nil
func (*DataPool) SmartContracts ¶
SmartContracts returns nil
func (*DataPool) Transactions ¶
func (dp *DataPool) Transactions() dataRetriever.ShardedDataCacherNotifier
Transactions returns nil
func (*DataPool) TrieNodesChunks ¶
TrieNodesChunks returns nil
func (*DataPool) UnsignedTransactions ¶
func (dp *DataPool) UnsignedTransactions() dataRetriever.ShardedDataCacherNotifier
UnsignedTransactions returns nil
func (*DataPool) ValidatorsInfo ¶
func (dp *DataPool) ValidatorsInfo() dataRetriever.ShardedDataCacherNotifier
ValidatorsInfo returns nil
type EnableEpochsHandler ¶
type EnableEpochsHandler struct { }
EnableEpochsHandler is a disabled implementation of EnableEpochsHandler interface
func (*EnableEpochsHandler) BalanceWaitingListsEnableEpoch ¶
func (eeh *EnableEpochsHandler) BalanceWaitingListsEnableEpoch() uint32
BalanceWaitingListsEnableEpoch returns WaitingListFixEnableEpochField
func (*EnableEpochsHandler) BlockGasAndFeesReCheckEnableEpoch ¶
func (eeh *EnableEpochsHandler) BlockGasAndFeesReCheckEnableEpoch() uint32
BlockGasAndFeesReCheckEnableEpoch returns 0
func (*EnableEpochsHandler) CheckExecuteReadOnlyEnableEpoch ¶
func (eeh *EnableEpochsHandler) CheckExecuteReadOnlyEnableEpoch() uint32
CheckExecuteReadOnlyEnableEpoch returns 0
func (*EnableEpochsHandler) CreateNFTThroughExecByCallerEnableEpoch ¶
func (eeh *EnableEpochsHandler) CreateNFTThroughExecByCallerEnableEpoch() uint32
CreateNFTThroughExecByCallerEnableEpoch returns 0
func (*EnableEpochsHandler) DisableExecByCallerEnableEpoch ¶
func (eeh *EnableEpochsHandler) DisableExecByCallerEnableEpoch() uint32
DisableExecByCallerEnableEpoch returns 0
func (*EnableEpochsHandler) FixDelegationChangeOwnerOnAccountEnabled ¶ added in v1.3.7
func (eeh *EnableEpochsHandler) FixDelegationChangeOwnerOnAccountEnabled() bool
FixDelegationChangeOwnerOnAccountEnabled -
func (*EnableEpochsHandler) FixFailExecutionOnErrorEnableEpoch ¶
func (eeh *EnableEpochsHandler) FixFailExecutionOnErrorEnableEpoch() uint32
FixFailExecutionOnErrorEnableEpoch returns 0
func (*EnableEpochsHandler) FixOOGReturnCodeEnableEpoch ¶
func (eeh *EnableEpochsHandler) FixOOGReturnCodeEnableEpoch() uint32
FixOOGReturnCodeEnableEpoch returns 0
func (*EnableEpochsHandler) IsAddFailedRelayedTxToInvalidMBsFlag ¶
func (eeh *EnableEpochsHandler) IsAddFailedRelayedTxToInvalidMBsFlag() bool
IsAddFailedRelayedTxToInvalidMBsFlag returns false
func (*EnableEpochsHandler) IsAddTokensToDelegationFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsAddTokensToDelegationFlagEnabled() bool
IsAddTokensToDelegationFlagEnabled returns false
func (*EnableEpochsHandler) IsAheadOfTimeGasUsageFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsAheadOfTimeGasUsageFlagEnabled() bool
IsAheadOfTimeGasUsageFlagEnabled returns false
func (*EnableEpochsHandler) IsAlwaysSaveTokenMetaDataEnabled ¶
func (eeh *EnableEpochsHandler) IsAlwaysSaveTokenMetaDataEnabled() bool
IsAlwaysSaveTokenMetaDataEnabled -
func (*EnableEpochsHandler) IsAutoBalanceDataTriesEnabled ¶ added in v1.3.7
func (eeh *EnableEpochsHandler) IsAutoBalanceDataTriesEnabled() bool
IsAutoBalanceDataTriesEnabled returns false
func (*EnableEpochsHandler) IsBackwardCompSaveKeyValueFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsBackwardCompSaveKeyValueFlagEnabled() bool
IsBackwardCompSaveKeyValueFlagEnabled returns false
func (*EnableEpochsHandler) IsBalanceWaitingListsFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsBalanceWaitingListsFlagEnabled() bool
IsBalanceWaitingListsFlagEnabled returns false
func (*EnableEpochsHandler) IsBelowSignedThresholdFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsBelowSignedThresholdFlagEnabled() bool
IsBelowSignedThresholdFlagEnabled returns false
func (*EnableEpochsHandler) IsBuiltInFunctionOnMetaFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsBuiltInFunctionOnMetaFlagEnabled() bool
IsBuiltInFunctionOnMetaFlagEnabled returns false
func (*EnableEpochsHandler) IsBuiltInFunctionsFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsBuiltInFunctionsFlagEnabled() bool
IsBuiltInFunctionsFlagEnabled returns false
func (*EnableEpochsHandler) IsChangeDelegationOwnerFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsChangeDelegationOwnerFlagEnabled() bool
IsChangeDelegationOwnerFlagEnabled -
func (*EnableEpochsHandler) IsChangeUsernameEnabled ¶ added in v1.3.7
func (eeh *EnableEpochsHandler) IsChangeUsernameEnabled() bool
IsChangeUsernameEnabled returns false
func (*EnableEpochsHandler) IsCheckCorrectTokenIDForTransferRoleFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsCheckCorrectTokenIDForTransferRoleFlagEnabled() bool
IsCheckCorrectTokenIDForTransferRoleFlagEnabled returns false
func (*EnableEpochsHandler) IsCheckExecuteOnReadOnlyFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsCheckExecuteOnReadOnlyFlagEnabled() bool
IsCheckExecuteOnReadOnlyFlagEnabled returns false
func (*EnableEpochsHandler) IsCheckFrozenCollectionFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsCheckFrozenCollectionFlagEnabled() bool
IsCheckFrozenCollectionFlagEnabled returns false
func (*EnableEpochsHandler) IsCheckFunctionArgumentFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsCheckFunctionArgumentFlagEnabled() bool
IsCheckFunctionArgumentFlagEnabled returns false
func (*EnableEpochsHandler) IsCheckTransferFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsCheckTransferFlagEnabled() bool
IsCheckTransferFlagEnabled returns false
func (*EnableEpochsHandler) IsCleanUpInformativeSCRsFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsCleanUpInformativeSCRsFlagEnabled() bool
IsCleanUpInformativeSCRsFlagEnabled returns false
func (*EnableEpochsHandler) IsComputeRewardCheckpointFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsComputeRewardCheckpointFlagEnabled() bool
IsComputeRewardCheckpointFlagEnabled returns false
func (*EnableEpochsHandler) IsConsistentTokensValuesLengthCheckEnabled ¶ added in v1.3.7
func (eeh *EnableEpochsHandler) IsConsistentTokensValuesLengthCheckEnabled() bool
IsConsistentTokensValuesLengthCheckEnabled returns false
func (*EnableEpochsHandler) IsCorrectFirstQueuedFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsCorrectFirstQueuedFlagEnabled() bool
IsCorrectFirstQueuedFlagEnabled returns false
func (*EnableEpochsHandler) IsCorrectJailedNotUnStakedEmptyQueueFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsCorrectJailedNotUnStakedEmptyQueueFlagEnabled() bool
IsCorrectJailedNotUnStakedEmptyQueueFlagEnabled returns false
func (*EnableEpochsHandler) IsCorrectLastUnJailedFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsCorrectLastUnJailedFlagEnabled() bool
IsCorrectLastUnJailedFlagEnabled returns false
func (*EnableEpochsHandler) IsCorrectLastUnJailedFlagEnabledForCurrentEpoch ¶
func (eeh *EnableEpochsHandler) IsCorrectLastUnJailedFlagEnabledForCurrentEpoch() bool
IsCorrectLastUnJailedFlagEnabledForCurrentEpoch returns false
func (*EnableEpochsHandler) IsCreateNFTThroughExecByCallerFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsCreateNFTThroughExecByCallerFlagEnabled() bool
IsCreateNFTThroughExecByCallerFlagEnabled returns false
func (*EnableEpochsHandler) IsDelegationManagerFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsDelegationManagerFlagEnabled() bool
IsDelegationManagerFlagEnabled returns false
func (*EnableEpochsHandler) IsDelegationSmartContractFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsDelegationSmartContractFlagEnabled() bool
IsDelegationSmartContractFlagEnabled returns false
func (*EnableEpochsHandler) IsDelegationSmartContractFlagEnabledForCurrentEpoch ¶
func (eeh *EnableEpochsHandler) IsDelegationSmartContractFlagEnabledForCurrentEpoch() bool
IsDelegationSmartContractFlagEnabledForCurrentEpoch returns false
func (*EnableEpochsHandler) IsDeleteDelegatorAfterClaimRewardsFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsDeleteDelegatorAfterClaimRewardsFlagEnabled() bool
IsDeleteDelegatorAfterClaimRewardsFlagEnabled returns false
func (*EnableEpochsHandler) IsDeterministicSortOnValidatorsInfoFixEnabled ¶ added in v1.3.6
func (eeh *EnableEpochsHandler) IsDeterministicSortOnValidatorsInfoFixEnabled() bool
IsDeterministicSortOnValidatorsInfoFixEnabled -
func (*EnableEpochsHandler) IsDisableExecByCallerFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsDisableExecByCallerFlagEnabled() bool
IsDisableExecByCallerFlagEnabled returns false
func (*EnableEpochsHandler) IsDoNotReturnOldBlockInBlockchainHookFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsDoNotReturnOldBlockInBlockchainHookFlagEnabled() bool
IsDoNotReturnOldBlockInBlockchainHookFlagEnabled returns false
func (*EnableEpochsHandler) IsDoubleKeyProtectionFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsDoubleKeyProtectionFlagEnabled() bool
IsDoubleKeyProtectionFlagEnabled returns false
func (*EnableEpochsHandler) IsDynamicGasCostForDataTrieStorageLoadEnabled ¶ added in v1.3.7
func (eeh *EnableEpochsHandler) IsDynamicGasCostForDataTrieStorageLoadEnabled() bool
IsDynamicGasCostForDataTrieStorageLoadEnabled returns false
func (*EnableEpochsHandler) IsESDTFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsESDTFlagEnabled() bool
IsESDTFlagEnabled returns false
func (*EnableEpochsHandler) IsESDTFlagEnabledForCurrentEpoch ¶
func (eeh *EnableEpochsHandler) IsESDTFlagEnabledForCurrentEpoch() bool
IsESDTFlagEnabledForCurrentEpoch returns false
func (*EnableEpochsHandler) IsESDTMetadataContinuousCleanupFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsESDTMetadataContinuousCleanupFlagEnabled() bool
IsESDTMetadataContinuousCleanupFlagEnabled returns false
func (*EnableEpochsHandler) IsESDTMultiTransferFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsESDTMultiTransferFlagEnabled() bool
IsESDTMultiTransferFlagEnabled returns false
func (*EnableEpochsHandler) IsESDTNFTCreateOnMultiShardFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsESDTNFTCreateOnMultiShardFlagEnabled() bool
IsESDTNFTCreateOnMultiShardFlagEnabled returns false
func (*EnableEpochsHandler) IsESDTNFTImprovementV1FlagEnabled ¶
func (eeh *EnableEpochsHandler) IsESDTNFTImprovementV1FlagEnabled() bool
IsESDTNFTImprovementV1FlagEnabled returns false
func (*EnableEpochsHandler) IsESDTRegisterAndSetAllRolesFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsESDTRegisterAndSetAllRolesFlagEnabled() bool
IsESDTRegisterAndSetAllRolesFlagEnabled returns false
func (*EnableEpochsHandler) IsESDTTransferRoleFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsESDTTransferRoleFlagEnabled() bool
IsESDTTransferRoleFlagEnabled returns false
func (*EnableEpochsHandler) IsFailExecutionOnEveryAPIErrorFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsFailExecutionOnEveryAPIErrorFlagEnabled() bool
IsFailExecutionOnEveryAPIErrorFlagEnabled returns false
func (*EnableEpochsHandler) IsFixAsyncCallBackArgsListFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsFixAsyncCallBackArgsListFlagEnabled() bool
IsFixAsyncCallBackArgsListFlagEnabled -
func (*EnableEpochsHandler) IsFixAsyncCallbackCheckFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsFixAsyncCallbackCheckFlagEnabled() bool
IsFixAsyncCallbackCheckFlagEnabled returns false
func (*EnableEpochsHandler) IsFixOOGReturnCodeFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsFixOOGReturnCodeFlagEnabled() bool
IsFixOOGReturnCodeFlagEnabled returns false
func (*EnableEpochsHandler) IsFixOldTokenLiquidityEnabled ¶
func (eeh *EnableEpochsHandler) IsFixOldTokenLiquidityEnabled() bool
IsFixOldTokenLiquidityEnabled -
func (*EnableEpochsHandler) IsFrontRunningProtectionFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsFrontRunningProtectionFlagEnabled() bool
IsFrontRunningProtectionFlagEnabled returns false
func (*EnableEpochsHandler) IsGasPriceModifierFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsGasPriceModifierFlagEnabled() bool
IsGasPriceModifierFlagEnabled returns false
func (*EnableEpochsHandler) IsGlobalMintBurnFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsGlobalMintBurnFlagEnabled() bool
IsGlobalMintBurnFlagEnabled returns false
func (*EnableEpochsHandler) IsGovernanceFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsGovernanceFlagEnabled() bool
IsGovernanceFlagEnabled returns false
func (*EnableEpochsHandler) IsGovernanceFlagEnabledForCurrentEpoch ¶
func (eeh *EnableEpochsHandler) IsGovernanceFlagEnabledForCurrentEpoch() bool
IsGovernanceFlagEnabledForCurrentEpoch returns false
func (*EnableEpochsHandler) IsIncrementSCRNonceInMultiTransferFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsIncrementSCRNonceInMultiTransferFlagEnabled() bool
IsIncrementSCRNonceInMultiTransferFlagEnabled returns false
func (*EnableEpochsHandler) IsInterfaceNil ¶
func (eeh *EnableEpochsHandler) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*EnableEpochsHandler) IsKeepExecOrderOnCreatedSCRsEnabled ¶ added in v1.3.7
func (eeh *EnableEpochsHandler) IsKeepExecOrderOnCreatedSCRsEnabled() bool
IsKeepExecOrderOnCreatedSCRsEnabled returns false
func (*EnableEpochsHandler) IsManagedCryptoAPIsFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsManagedCryptoAPIsFlagEnabled() bool
IsManagedCryptoAPIsFlagEnabled returns false
func (*EnableEpochsHandler) IsMaxBlockchainHookCountersFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsMaxBlockchainHookCountersFlagEnabled() bool
IsMaxBlockchainHookCountersFlagEnabled -
func (*EnableEpochsHandler) IsMetaESDTSetFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsMetaESDTSetFlagEnabled() bool
IsMetaESDTSetFlagEnabled returns false
func (*EnableEpochsHandler) IsMetaProtectionFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsMetaProtectionFlagEnabled() bool
IsMetaProtectionFlagEnabled returns false
func (*EnableEpochsHandler) IsMiniBlockPartialExecutionFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsMiniBlockPartialExecutionFlagEnabled() bool
IsMiniBlockPartialExecutionFlagEnabled returns false
func (*EnableEpochsHandler) IsMultiClaimOnDelegationEnabled ¶ added in v1.3.7
func (eeh *EnableEpochsHandler) IsMultiClaimOnDelegationEnabled() bool
IsMultiClaimOnDelegationEnabled returns false
func (*EnableEpochsHandler) IsMultiESDTTransferFixOnCallBackFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsMultiESDTTransferFixOnCallBackFlagEnabled() bool
IsMultiESDTTransferFixOnCallBackFlagEnabled returns false
func (*EnableEpochsHandler) IsOptimizeGasUsedInCrossMiniBlocksFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsOptimizeGasUsedInCrossMiniBlocksFlagEnabled() bool
IsOptimizeGasUsedInCrossMiniBlocksFlagEnabled returns false
func (*EnableEpochsHandler) IsOptimizeNFTStoreFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsOptimizeNFTStoreFlagEnabled() bool
IsOptimizeNFTStoreFlagEnabled returns false
func (*EnableEpochsHandler) IsPayableBySCFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsPayableBySCFlagEnabled() bool
IsPayableBySCFlagEnabled returns false
func (*EnableEpochsHandler) IsPenalizedTooMuchGasFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsPenalizedTooMuchGasFlagEnabled() bool
IsPenalizedTooMuchGasFlagEnabled returns false
func (*EnableEpochsHandler) IsReDelegateBelowMinCheckFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsReDelegateBelowMinCheckFlagEnabled() bool
IsReDelegateBelowMinCheckFlagEnabled returns false
func (*EnableEpochsHandler) IsRefactorContextFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsRefactorContextFlagEnabled() bool
IsRefactorContextFlagEnabled returns false
func (*EnableEpochsHandler) IsRefactorPeersMiniBlocksFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsRefactorPeersMiniBlocksFlagEnabled() bool
IsRefactorPeersMiniBlocksFlagEnabled returns false
func (*EnableEpochsHandler) IsRelayedNonceFixEnabled ¶ added in v1.3.3
func (eeh *EnableEpochsHandler) IsRelayedNonceFixEnabled() bool
IsRelayedNonceFixEnabled -
func (*EnableEpochsHandler) IsRelayedTransactionsFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsRelayedTransactionsFlagEnabled() bool
IsRelayedTransactionsFlagEnabled returns false
func (*EnableEpochsHandler) IsRelayedTransactionsV2FlagEnabled ¶
func (eeh *EnableEpochsHandler) IsRelayedTransactionsV2FlagEnabled() bool
IsRelayedTransactionsV2FlagEnabled returns false
func (*EnableEpochsHandler) IsRemoveNonUpdatedStorageFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsRemoveNonUpdatedStorageFlagEnabled() bool
IsRemoveNonUpdatedStorageFlagEnabled returns false
func (*EnableEpochsHandler) IsRepairCallbackFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsRepairCallbackFlagEnabled() bool
IsRepairCallbackFlagEnabled returns false
func (*EnableEpochsHandler) IsReturnDataToLastTransferFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsReturnDataToLastTransferFlagEnabled() bool
IsReturnDataToLastTransferFlagEnabled returns false
func (*EnableEpochsHandler) IsRuntimeCodeSizeFixEnabled ¶ added in v1.2.7
func (eeh *EnableEpochsHandler) IsRuntimeCodeSizeFixEnabled() bool
IsRuntimeCodeSizeFixEnabled -
func (*EnableEpochsHandler) IsRuntimeMemStoreLimitEnabled ¶
func (eeh *EnableEpochsHandler) IsRuntimeMemStoreLimitEnabled() bool
IsRuntimeMemStoreLimitEnabled -
func (*EnableEpochsHandler) IsSCDeployFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsSCDeployFlagEnabled() bool
IsSCDeployFlagEnabled returns false
func (*EnableEpochsHandler) IsSCProcessorV2FlagEnabled ¶ added in v1.3.7
func (eeh *EnableEpochsHandler) IsSCProcessorV2FlagEnabled() bool
IsSCProcessorV2FlagEnabled returns false
func (*EnableEpochsHandler) IsSCRSizeInvariantCheckFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsSCRSizeInvariantCheckFlagEnabled() bool
IsSCRSizeInvariantCheckFlagEnabled returns false
func (*EnableEpochsHandler) IsSCRSizeInvariantOnBuiltInResultFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsSCRSizeInvariantOnBuiltInResultFlagEnabled() bool
IsSCRSizeInvariantOnBuiltInResultFlagEnabled returns false
func (*EnableEpochsHandler) IsSaveJailedAlwaysFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsSaveJailedAlwaysFlagEnabled() bool
IsSaveJailedAlwaysFlagEnabled returns false
func (*EnableEpochsHandler) IsSaveToSystemAccountFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsSaveToSystemAccountFlagEnabled() bool
IsSaveToSystemAccountFlagEnabled returns false
func (*EnableEpochsHandler) IsScToScEventLogEnabled ¶ added in v1.3.7
func (eeh *EnableEpochsHandler) IsScToScEventLogEnabled() bool
IsScToScEventLogEnabled returns false
func (*EnableEpochsHandler) IsScheduledMiniBlocksFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsScheduledMiniBlocksFlagEnabled() bool
IsScheduledMiniBlocksFlagEnabled returns false
func (*EnableEpochsHandler) IsSendAlwaysFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsSendAlwaysFlagEnabled() bool
IsSendAlwaysFlagEnabled returns false
func (*EnableEpochsHandler) IsSenderInOutTransferFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsSenderInOutTransferFlagEnabled() bool
IsSenderInOutTransferFlagEnabled returns false
func (*EnableEpochsHandler) IsSetGuardianEnabled ¶ added in v1.3.3
func (eeh *EnableEpochsHandler) IsSetGuardianEnabled() bool
IsSetGuardianEnabled -
func (*EnableEpochsHandler) IsSetSenderInEeiOutputTransferFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsSetSenderInEeiOutputTransferFlagEnabled() bool
IsSetSenderInEeiOutputTransferFlagEnabled -
func (*EnableEpochsHandler) IsStakeFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsStakeFlagEnabled() bool
IsStakeFlagEnabled returns false
func (*EnableEpochsHandler) IsStakingV2FlagEnabled ¶
func (eeh *EnableEpochsHandler) IsStakingV2FlagEnabled() bool
IsStakingV2FlagEnabled returns false
func (*EnableEpochsHandler) IsStakingV2FlagEnabledForActivationEpochCompleted ¶
func (eeh *EnableEpochsHandler) IsStakingV2FlagEnabledForActivationEpochCompleted() bool
IsStakingV2FlagEnabledForActivationEpochCompleted returns false
func (*EnableEpochsHandler) IsStakingV2OwnerFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsStakingV2OwnerFlagEnabled() bool
IsStakingV2OwnerFlagEnabled returns false
func (*EnableEpochsHandler) IsStopDecreasingValidatorRatingWhenStuckFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsStopDecreasingValidatorRatingWhenStuckFlagEnabled() bool
IsStopDecreasingValidatorRatingWhenStuckFlagEnabled returns false
func (*EnableEpochsHandler) IsStorageAPICostOptimizationFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsStorageAPICostOptimizationFlagEnabled() bool
IsStorageAPICostOptimizationFlagEnabled returns false
func (*EnableEpochsHandler) IsSwitchHysteresisForMinNodesFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsSwitchHysteresisForMinNodesFlagEnabled() bool
IsSwitchHysteresisForMinNodesFlagEnabled returns false
func (*EnableEpochsHandler) IsSwitchHysteresisForMinNodesFlagEnabledForCurrentEpoch ¶
func (eeh *EnableEpochsHandler) IsSwitchHysteresisForMinNodesFlagEnabledForCurrentEpoch() bool
IsSwitchHysteresisForMinNodesFlagEnabledForCurrentEpoch returns false
func (*EnableEpochsHandler) IsSwitchJailWaitingFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsSwitchJailWaitingFlagEnabled() bool
IsSwitchJailWaitingFlagEnabled returns false
func (*EnableEpochsHandler) IsTransactionSignedWithTxHashFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsTransactionSignedWithTxHashFlagEnabled() bool
IsTransactionSignedWithTxHashFlagEnabled returns false
func (*EnableEpochsHandler) IsTransferToMetaFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsTransferToMetaFlagEnabled() bool
IsTransferToMetaFlagEnabled returns false
func (*EnableEpochsHandler) IsUnBondTokensV2FlagEnabled ¶
func (eeh *EnableEpochsHandler) IsUnBondTokensV2FlagEnabled() bool
IsUnBondTokensV2FlagEnabled returns false
func (*EnableEpochsHandler) IsValidatorToDelegationFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsValidatorToDelegationFlagEnabled() bool
IsValidatorToDelegationFlagEnabled returns false
func (*EnableEpochsHandler) IsValueLengthCheckFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsValueLengthCheckFlagEnabled() bool
IsValueLengthCheckFlagEnabled returns false
func (*EnableEpochsHandler) IsWaitingListFixFlagEnabled ¶
func (eeh *EnableEpochsHandler) IsWaitingListFixFlagEnabled() bool
IsWaitingListFixFlagEnabled returns false
func (*EnableEpochsHandler) IsWipeSingleNFTLiquidityDecreaseEnabled ¶
func (eeh *EnableEpochsHandler) IsWipeSingleNFTLiquidityDecreaseEnabled() bool
IsWipeSingleNFTLiquidityDecreaseEnabled -
func (*EnableEpochsHandler) ManagedCryptoAPIEnableEpoch ¶
func (eeh *EnableEpochsHandler) ManagedCryptoAPIEnableEpoch() uint32
ManagedCryptoAPIEnableEpoch returns 0
func (*EnableEpochsHandler) MiniBlockPartialExecutionEnableEpoch ¶
func (eeh *EnableEpochsHandler) MiniBlockPartialExecutionEnableEpoch() uint32
MiniBlockPartialExecutionEnableEpoch returns 0
func (*EnableEpochsHandler) MultiESDTTransferAsyncCallBackEnableEpoch ¶
func (eeh *EnableEpochsHandler) MultiESDTTransferAsyncCallBackEnableEpoch() uint32
MultiESDTTransferAsyncCallBackEnableEpoch returns 0
func (*EnableEpochsHandler) RefactorContextEnableEpoch ¶
func (eeh *EnableEpochsHandler) RefactorContextEnableEpoch() uint32
RefactorContextEnableEpoch returns 0
func (*EnableEpochsHandler) RefactorPeersMiniBlocksEnableEpoch ¶
func (eeh *EnableEpochsHandler) RefactorPeersMiniBlocksEnableEpoch() uint32
RefactorPeersMiniBlocksEnableEpoch returns 0
func (*EnableEpochsHandler) RemoveNonUpdatedStorageEnableEpoch ¶
func (eeh *EnableEpochsHandler) RemoveNonUpdatedStorageEnableEpoch() uint32
RemoveNonUpdatedStorageEnableEpoch returns 0
func (*EnableEpochsHandler) ResetPenalizedTooMuchGasFlag ¶
func (eeh *EnableEpochsHandler) ResetPenalizedTooMuchGasFlag()
ResetPenalizedTooMuchGasFlag does nothing
func (*EnableEpochsHandler) ScheduledMiniBlocksEnableEpoch ¶
func (eeh *EnableEpochsHandler) ScheduledMiniBlocksEnableEpoch() uint32
ScheduledMiniBlocksEnableEpoch returns 0
func (*EnableEpochsHandler) StakingV2EnableEpoch ¶
func (eeh *EnableEpochsHandler) StakingV2EnableEpoch() uint32
StakingV2EnableEpoch returns 0
func (*EnableEpochsHandler) StorageAPICostOptimizationEnableEpoch ¶
func (eeh *EnableEpochsHandler) StorageAPICostOptimizationEnableEpoch() uint32
StorageAPICostOptimizationEnableEpoch returns 0
func (*EnableEpochsHandler) SwitchJailWaitingEnableEpoch ¶
func (eeh *EnableEpochsHandler) SwitchJailWaitingEnableEpoch() uint32
SwitchJailWaitingEnableEpoch returns 0
func (*EnableEpochsHandler) WaitingListFixEnableEpoch ¶
func (eeh *EnableEpochsHandler) WaitingListFixEnableEpoch() uint32
WaitingListFixEnableEpoch returns WaitingListFixEnableEpochField
type EpochNotifier ¶
type EpochNotifier struct { }
EpochNotifier is a disabled implementation of EpochNotifier interface
func (*EpochNotifier) CheckEpoch ¶
func (en *EpochNotifier) CheckEpoch(_ data.HeaderHandler)
CheckEpoch does nothing
func (*EpochNotifier) CurrentEpoch ¶
func (en *EpochNotifier) CurrentEpoch() uint32
CurrentEpoch returns 0
func (*EpochNotifier) IsInterfaceNil ¶
func (en *EpochNotifier) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*EpochNotifier) RegisterNotifyHandler ¶
func (en *EpochNotifier) RegisterNotifyHandler(_ vmcommon.EpochSubscriberHandler)
RegisterNotifyHandler does nothing
type EpochStartNotifier ¶
type EpochStartNotifier struct { }
EpochStartNotifier is a disabled implementation of EpochStartEventNotifier interface
func (*EpochStartNotifier) IsInterfaceNil ¶
func (esn *EpochStartNotifier) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*EpochStartNotifier) RegisterHandler ¶
func (esn *EpochStartNotifier) RegisterHandler(_ epochStart.ActionHandler)
RegisterHandler does nothing
func (*EpochStartNotifier) UnregisterHandler ¶
func (esn *EpochStartNotifier) UnregisterHandler(_ epochStart.ActionHandler)
UnregisterHandler does nothing
type FallBackHeaderValidator ¶
type FallBackHeaderValidator struct { }
FallBackHeaderValidator is a disabled implementation of FallBackHeaderValidator interface
func (*FallBackHeaderValidator) IsInterfaceNil ¶
func (fhvs *FallBackHeaderValidator) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*FallBackHeaderValidator) ShouldApplyFallbackValidation ¶
func (fhvs *FallBackHeaderValidator) ShouldApplyFallbackValidation(_ data.HeaderHandler) bool
ShouldApplyFallbackValidation returns false
type GasScheduleNotifier ¶
type GasScheduleNotifier struct { }
GasScheduleNotifier -
func (*GasScheduleNotifier) ChangeGasSchedule ¶
func (gsn *GasScheduleNotifier) ChangeGasSchedule(_ map[string]map[string]uint64)
ChangeGasSchedule does nothing
func (*GasScheduleNotifier) IsInterfaceNil ¶
func (gsn *GasScheduleNotifier) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*GasScheduleNotifier) LatestGasSchedule ¶
func (gsn *GasScheduleNotifier) LatestGasSchedule() map[string]map[string]uint64
LatestGasSchedule returns an empty map
func (*GasScheduleNotifier) RegisterNotifyHandler ¶
func (gsn *GasScheduleNotifier) RegisterNotifyHandler(_ core.GasScheduleSubscribeHandler)
RegisterNotifyHandler does nothing
func (*GasScheduleNotifier) UnRegisterAll ¶
func (gsn *GasScheduleNotifier) UnRegisterAll()
UnRegisterAll does nothing
type GlobalSettingsHandler ¶
type GlobalSettingsHandler struct { }
GlobalSettingsHandler implements a disabled vmcommon.ESDTGlobalSettingsHandler
func (*GlobalSettingsHandler) IsInterfaceNil ¶
func (handler *GlobalSettingsHandler) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*GlobalSettingsHandler) IsLimitedTransfer ¶
func (handler *GlobalSettingsHandler) IsLimitedTransfer(_ []byte) bool
IsLimitedTransfer returns false
func (*GlobalSettingsHandler) IsPaused ¶
func (handler *GlobalSettingsHandler) IsPaused(_ []byte) bool
IsPaused returns false
type MissingTrieNodesNotifier ¶ added in v1.3.7
type MissingTrieNodesNotifier struct { }
MissingTrieNodesNotifier is a disabled implementation of MissingTrieNodesNotifier interface
func (*MissingTrieNodesNotifier) AsyncNotifyMissingTrieNode ¶ added in v1.3.7
func (m *MissingTrieNodesNotifier) AsyncNotifyMissingTrieNode(_ []byte)
AsyncNotifyMissingTrieNode does nothing
func (*MissingTrieNodesNotifier) IsInterfaceNil ¶ added in v1.3.7
func (m *MissingTrieNodesNotifier) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*MissingTrieNodesNotifier) RegisterHandler ¶ added in v1.3.7
func (m *MissingTrieNodesNotifier) RegisterHandler(_ common.StateSyncNotifierSubscriber) error
RegisterHandler returns nil
type NodeTypeProvider ¶
type NodeTypeProvider struct { }
NodeTypeProvider is a disabled implementation of NodeTypeProviderHandler interface
func (*NodeTypeProvider) GetType ¶
func (n *NodeTypeProvider) GetType() core.NodeType
GetType returns empty string
func (*NodeTypeProvider) IsInterfaceNil ¶
func (n *NodeTypeProvider) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*NodeTypeProvider) SetType ¶
func (n *NodeTypeProvider) SetType(_ core.NodeType)
SetType does nothing
type ShardCoordinator ¶
type ShardCoordinator struct { }
ShardCoordinator is the disabled shard coordinator instance that satisfies the mx-chain-go.sharding.Coordinator interface
func (*ShardCoordinator) CommunicationIdentifier ¶
func (sc *ShardCoordinator) CommunicationIdentifier(_ uint32) string
CommunicationIdentifier returns empty string
func (*ShardCoordinator) ComputeId ¶
func (sc *ShardCoordinator) ComputeId(_ []byte) uint32
ComputeId returns 0
func (*ShardCoordinator) IsInterfaceNil ¶
func (sc *ShardCoordinator) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ShardCoordinator) NumberOfShards ¶
func (sc *ShardCoordinator) NumberOfShards() uint32
NumberOfShards returns 0
func (*ShardCoordinator) SameShard ¶
func (sc *ShardCoordinator) SameShard(_, _ []byte) bool
SameShard returns false
type ShuffledOutHandler ¶
type ShuffledOutHandler struct { }
ShuffledOutHandler is a disabled implementation of ShuffledOutHandler interface
func (*ShuffledOutHandler) CurrentShardID ¶
func (s *ShuffledOutHandler) CurrentShardID() uint32
CurrentShardID return zero
func (*ShuffledOutHandler) IsInterfaceNil ¶
func (s *ShuffledOutHandler) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ShuffledOutHandler) Process ¶
func (s *ShuffledOutHandler) Process(_ uint32) error
Process returns nil
func (*ShuffledOutHandler) RegisterHandler ¶
func (s *ShuffledOutHandler) RegisterHandler(_ func(uint32))
RegisterHandler does nothing
type SimpleESDTNFTStorageHandler ¶
type SimpleESDTNFTStorageHandler struct { }
SimpleESDTNFTStorageHandler is a disabled implementation of SimpleESDTNFTStorageHandler interface
func (*SimpleESDTNFTStorageHandler) GetESDTNFTTokenOnDestination ¶
func (sns *SimpleESDTNFTStorageHandler) GetESDTNFTTokenOnDestination(_ vmcommon.UserAccountHandler, _ []byte, _ uint64) (*esdt.ESDigitalToken, bool, error)
GetESDTNFTTokenOnDestination returns nil
func (*SimpleESDTNFTStorageHandler) IsInterfaceNil ¶
func (sns *SimpleESDTNFTStorageHandler) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*SimpleESDTNFTStorageHandler) SaveNFTMetaDataToSystemAccount ¶
func (sns *SimpleESDTNFTStorageHandler) SaveNFTMetaDataToSystemAccount(_ data.TransactionHandler) error
SaveNFTMetaDataToSystemAccount returns nil
type StorageService ¶
type StorageService struct { }
StorageService is a disabled implementation of the StorageService interface
func (*StorageService) AddStorer ¶
func (ss *StorageService) AddStorer(_ dataRetriever.UnitType, _ storage.Storer)
AddStorer does nothing
func (*StorageService) Get ¶
func (ss *StorageService) Get(_ dataRetriever.UnitType, _ []byte) ([]byte, error)
Get returns nil byte slice and nil error
func (*StorageService) GetAll ¶
func (ss *StorageService) GetAll(_ dataRetriever.UnitType, _ [][]byte) (map[string][]byte, error)
GetAll returns nil map and nil error
func (*StorageService) GetAllStorers ¶
func (ss *StorageService) GetAllStorers() map[dataRetriever.UnitType]storage.Storer
GetAllStorers returns an empty map
func (*StorageService) GetStorer ¶
func (ss *StorageService) GetStorer(_ dataRetriever.UnitType) (storage.Storer, error)
GetStorer returns nil
func (*StorageService) Has ¶
func (ss *StorageService) Has(_ dataRetriever.UnitType, _ []byte) error
Has returns nil
func (*StorageService) IsInterfaceNil ¶
func (ss *StorageService) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*StorageService) Put ¶
func (ss *StorageService) Put(_ dataRetriever.UnitType, _ []byte, _ []byte) error
Put returns nil
func (*StorageService) SetEpochForPutOperation ¶
func (ss *StorageService) SetEpochForPutOperation(_ uint32)
SetEpochForPutOperation does nothing
type Storer ¶
type Storer struct { }
Storer is a disabled implementation of Storer interface
func (*Storer) GetBulkFromEpoch ¶
GetBulkFromEpoch returns nil
func (*Storer) GetFromEpoch ¶
GetFromEpoch returns nil
func (*Storer) GetOldestEpoch ¶
GetOldestEpoch return nil
func (*Storer) IsInterfaceNil ¶
IsInterfaceNil returns true if there is no value under the interface
func (*Storer) PutInEpoch ¶
PutInEpoch returns nil
func (*Storer) RemoveFromCurrentEpoch ¶
RemoveFromCurrentEpoch returns nil
Source Files ¶
- accounts.go
- blockchain.go
- blockchainHookCounter.go
- builtInFunctionContainer.go
- cache.go
- datapool.go
- enableEpochsHandler.go
- epochNotifier.go
- epochStartNotifier.go
- fallbackHeaderValidator.go
- gasScheduleNotifier.go
- globalSettingsHandler.go
- missingTrieNodesNotifier.go
- nodeTypeProvider.go
- shardCoordinator.go
- shuffleOutHandler.go
- simpleESDTNFTStorageHandler.go
- storageService.go
- storer.go