Documentation ¶
Index ¶
- func NewOneShardCoordinatorMock() *oneShardCoordinatorMock
- type AccountsDBSyncerStub
- type AccountsDBSyncersStub
- func (a *AccountsDBSyncersStub) Add(key string, val update.AccountsDBSyncer) error
- func (a *AccountsDBSyncersStub) AddMultiple(keys []string, interceptors []update.AccountsDBSyncer) error
- func (a *AccountsDBSyncersStub) Get(key string) (update.AccountsDBSyncer, error)
- func (a *AccountsDBSyncersStub) IsInterfaceNil() bool
- func (a *AccountsDBSyncersStub) Len() int
- func (a *AccountsDBSyncersStub) Remove(key string)
- func (a *AccountsDBSyncersStub) Replace(key string, val update.AccountsDBSyncer) error
- type AccountsStub
- func (as *AccountsStub) AddJournalEntry(je state.JournalEntry)
- func (as *AccountsStub) CancelPrune(rootHash []byte, identifier data.TriePruningIdentifier)
- func (as *AccountsStub) Commit() ([]byte, error)
- func (as *AccountsStub) GetAllLeaves(rootHash []byte) (map[string][]byte, error)
- func (as *AccountsStub) GetExistingAccount(address []byte) (state.AccountHandler, error)
- func (as *AccountsStub) GetNumCheckpoints() uint32
- func (as *AccountsStub) IsInterfaceNil() bool
- func (as *AccountsStub) IsPruningEnabled() bool
- func (as *AccountsStub) JournalLen() int
- func (as *AccountsStub) LoadAccount(address []byte) (state.AccountHandler, error)
- func (as *AccountsStub) PruneTrie(rootHash []byte, identifier data.TriePruningIdentifier)
- func (as *AccountsStub) RecreateAllTries(rootHash []byte) (map[string]data.Trie, error)
- func (as *AccountsStub) RecreateTrie(rootHash []byte) error
- func (as *AccountsStub) RemoveAccount(address []byte) error
- func (as *AccountsStub) RevertToSnapshot(snapshot int) error
- func (as *AccountsStub) RootHash() ([]byte, error)
- func (as *AccountsStub) SaveAccount(account state.AccountHandler) error
- func (as *AccountsStub) SetStateCheckpoint(rootHash []byte)
- func (as *AccountsStub) SnapshotState(rootHash []byte)
- type AddressMock
- type ChainStorerMock
- func (bc *ChainStorerMock) AddStorer(key dataRetriever.UnitType, s storage.Storer)
- func (bc *ChainStorerMock) CloseAll() error
- func (bc *ChainStorerMock) Destroy() error
- func (bc *ChainStorerMock) Get(unitType dataRetriever.UnitType, key []byte) ([]byte, error)
- func (bc *ChainStorerMock) GetAll(unitType dataRetriever.UnitType, keys [][]byte) (map[string][]byte, error)
- func (bc *ChainStorerMock) GetStorer(unitType dataRetriever.UnitType) storage.Storer
- func (bc *ChainStorerMock) Has(unitType dataRetriever.UnitType, key []byte) error
- func (bc *ChainStorerMock) IsInterfaceNil() bool
- func (bc *ChainStorerMock) Put(unitType dataRetriever.UnitType, key []byte, value []byte) error
- func (bc *ChainStorerMock) SetEpochForPutOperation(epoch uint32)
- type CloserStub
- type CoordinatorStub
- func (coordinator *CoordinatorStub) CommunicationIdentifier(destShardID uint32) string
- func (coordinator *CoordinatorStub) ComputeId(address []byte) uint32
- func (coordinator *CoordinatorStub) IsInterfaceNil() bool
- func (coordinator *CoordinatorStub) NumberOfShards() uint32
- func (coordinator *CoordinatorStub) SameShard(firstAddress, secondAddress []byte) bool
- func (coordinator *CoordinatorStub) SelfId() uint32
- type EpochHandlerStub
- type EpochStartNotifierStub
- func (esnm *EpochStartNotifierStub) IsInterfaceNil() bool
- func (esnm *EpochStartNotifierStub) NotifyAll(hdr data.HeaderHandler)
- func (esnm *EpochStartNotifierStub) NotifyAllPrepare(metaHdr data.HeaderHandler, body data.BodyHandler)
- func (esnm *EpochStartNotifierStub) NotifyEpochChangeConfirmed(epoch uint32)
- func (esnm *EpochStartNotifierStub) RegisterForEpochChangeConfirmed(handler func(epoch uint32))
- func (esnm *EpochStartNotifierStub) RegisterHandler(handler epochStart.ActionHandler)
- func (esnm *EpochStartNotifierStub) UnregisterHandler(handler epochStart.ActionHandler)
- type EpochStartPendingMiniBlocksSyncHandlerMock
- func (ep *EpochStartPendingMiniBlocksSyncHandlerMock) GetMiniBlocks() (map[string]*block.MiniBlock, error)
- func (ep *EpochStartPendingMiniBlocksSyncHandlerMock) IsInterfaceNil() bool
- func (ep *EpochStartPendingMiniBlocksSyncHandlerMock) SyncPendingMiniBlocksFromMeta(epochStart *block.MetaBlock, unFinished map[string]*block.MetaBlock, ...) error
- type EpochStartTriesSyncHandlerMock
- type EpochStartTriggerStub
- 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) error
- func (e *EpochStartTriggerStub) GetRoundsPerEpoch() uint64
- func (e *EpochStartTriggerStub) IsEpochStart() bool
- func (e *EpochStartTriggerStub) IsInterfaceNil() bool
- func (e *EpochStartTriggerStub) NotifyAll(_ data.HeaderHandler)
- func (e *EpochStartTriggerStub) ReceivedHeader(header data.HeaderHandler)
- func (e *EpochStartTriggerStub) Revert()
- func (e *EpochStartTriggerStub) SetCurrentEpochStartRound(_ uint64)
- func (e *EpochStartTriggerStub) SetEpoch(_ uint32)
- func (e *EpochStartTriggerStub) SetFinalityAttestingRound(_ uint64)
- func (e *EpochStartTriggerStub) SetProcessed(header data.HeaderHandler)
- func (e *EpochStartTriggerStub) SetRoundsPerEpoch(_ uint64)
- func (e *EpochStartTriggerStub) SetTrigger(_ epochStart.TriggerHandler)
- func (e *EpochStartTriggerStub) Update(round uint64)
- type ExportFactoryHandlerStub
- type ExportHandlerStub
- type GenesisNodesSetupHandlerStub
- func (g *GenesisNodesSetupHandlerStub) GetAdaptivity() bool
- func (g *GenesisNodesSetupHandlerStub) GetChainId() string
- func (g *GenesisNodesSetupHandlerStub) GetHysteresis() float32
- func (g *GenesisNodesSetupHandlerStub) GetMetaConsensusGroupSize() uint32
- func (g *GenesisNodesSetupHandlerStub) GetMinTransactionVersion() uint32
- func (g *GenesisNodesSetupHandlerStub) GetRoundDuration() uint64
- func (g *GenesisNodesSetupHandlerStub) GetShardConsensusGroupSize() uint32
- func (g *GenesisNodesSetupHandlerStub) GetStartTime() int64
- func (g *GenesisNodesSetupHandlerStub) InitialNodesInfo() (map[uint32][]sharding.GenesisNodeInfoHandler, ...)
- func (g *GenesisNodesSetupHandlerStub) InitialNodesInfoForShard(shardId uint32) ([]sharding.GenesisNodeInfoHandler, []sharding.GenesisNodeInfoHandler, error)
- func (g *GenesisNodesSetupHandlerStub) IsInterfaceNil() bool
- func (g *GenesisNodesSetupHandlerStub) MinNumberOfMetaNodes() uint32
- func (g *GenesisNodesSetupHandlerStub) MinNumberOfNodes() uint32
- func (g *GenesisNodesSetupHandlerStub) MinNumberOfShardNodes() uint32
- func (g *GenesisNodesSetupHandlerStub) NumberOfShards() uint32
- type HardForkBlockProcessor
- type HardforkStorerStub
- func (hss *HardforkStorerStub) Close() error
- func (hss *HardforkStorerStub) FinishedIdentifier(identifier string) error
- func (hss *HardforkStorerStub) Get(identifier string, key []byte) ([]byte, error)
- func (hss *HardforkStorerStub) IsInterfaceNil() bool
- func (hss *HardforkStorerStub) RangeKeys(handler func(identifier string, keys [][]byte) bool)
- func (hss *HardforkStorerStub) Write(identifier string, key []byte, value []byte) error
- type HasherMock
- type HasherStub
- type HeaderSyncHandlerStub
- func (hsh *HeaderSyncHandlerStub) GetEpochStartMetaBlock() (*block.MetaBlock, error)
- func (hsh *HeaderSyncHandlerStub) GetUnfinishedMetaBlocks() (map[string]*block.MetaBlock, error)
- func (hsh *HeaderSyncHandlerStub) IsInterfaceNil() bool
- func (hsh *HeaderSyncHandlerStub) SyncUnFinishedMetaHeaders(epoch uint32) error
- type HeaderValidatorStub
- type HeadersCacherStub
- func (hcs *HeadersCacherStub) AddHeader(headerHash []byte, header data.HeaderHandler)
- func (hcs *HeadersCacherStub) Clear()
- func (hcs *HeadersCacherStub) GetHeaderByHash(hash []byte) (data.HeaderHandler, error)
- func (hcs *HeadersCacherStub) GetHeadersByNonceAndShardId(hdrNonce uint64, shardId uint32) ([]data.HeaderHandler, [][]byte, error)
- func (hcs *HeadersCacherStub) GetNumHeaders(shardId uint32) int
- func (hcs *HeadersCacherStub) IsInterfaceNil() bool
- func (hcs *HeadersCacherStub) Len() int
- func (hcs *HeadersCacherStub) MaxSize() int
- func (hcs *HeadersCacherStub) Nonces(shardId uint32) []uint64
- func (hcs *HeadersCacherStub) RegisterHandler(handler func(header data.HeaderHandler, shardHeaderHash []byte))
- func (hcs *HeadersCacherStub) RemoveHeaderByHash(headerHash []byte)
- func (hcs *HeadersCacherStub) RemoveHeaderByNonceAndShardId(hdrNonce uint64, shardId uint32)
- type ImportHandlerStub
- func (ihs *ImportHandlerStub) GetAccountsDBForShard(shardID uint32) state.AccountsAdapter
- func (ihs *ImportHandlerStub) GetHardForkMetaBlock() *block.MetaBlock
- func (ihs *ImportHandlerStub) GetMiniBlocks() map[string]*block.MiniBlock
- func (ihs *ImportHandlerStub) GetTransactions() map[string]data.TransactionHandler
- func (ihs *ImportHandlerStub) GetValidatorAccountsDB() state.AccountsAdapter
- func (ihs *ImportHandlerStub) ImportAll() error
- func (ihs *ImportHandlerStub) IsInterfaceNil() bool
- 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 MarshalizerFake
- type MarshalizerMock
- type PendingTransactionProcessorStub
- type PendingTransactionsSyncHandlerMock
- func (et *PendingTransactionsSyncHandlerMock) GetTransactions() (map[string]data.TransactionHandler, error)
- func (et *PendingTransactionsSyncHandlerMock) IsInterfaceNil() bool
- func (et *PendingTransactionsSyncHandlerMock) SyncPendingTransactionsFor(miniBlocks map[string]*block.MiniBlock, epoch uint32, ctx context.Context) error
- type PubkeyConverterStub
- type RequestHandlerStub
- 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(shardId uint32, miniblockHash []byte)
- func (rhs *RequestHandlerStub) RequestMiniBlocks(_ uint32, _ [][]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) RequestTrieNodes(_ uint32, _ [][]byte, _ string)
- func (rhs *RequestHandlerStub) RequestUnsignedTransactions(destShardID uint32, txHashes [][]byte)
- func (rhs *RequestHandlerStub) SetEpoch(_ uint32)
- func (rhs *RequestHandlerStub) SetNumPeersToQuery(key string, intra int, cross int) error
- type RewardTxProcessorMock
- type SCProcessorMock
- func (sc *SCProcessorMock) ComputeTransactionType(tx data.TransactionHandler) process.TransactionType
- func (sc *SCProcessorMock) DeploySmartContract(tx data.TransactionHandler, acntSrc 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) ProcessIfError(acntSnd state.UserAccountHandler, txHash []byte, tx data.TransactionHandler, ...) error
- func (sc *SCProcessorMock) ProcessSmartContractResult(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)
- type StorageManagerStub
- func (sms *StorageManagerStub) CancelPrune([]byte, data.TriePruningIdentifier)
- func (sms *StorageManagerStub) Database() data.DBWriteCacher
- func (sms *StorageManagerStub) EnterSnapshotMode()
- func (sms *StorageManagerStub) ExitSnapshotMode()
- func (sms *StorageManagerStub) GetSnapshotDbBatchDelay() int
- func (sms *StorageManagerStub) GetSnapshotThatContainsHash(d []byte) data.SnapshotDbHandler
- func (sms *StorageManagerStub) IsInterfaceNil() bool
- func (sms *StorageManagerStub) IsPruningEnabled() bool
- func (sms *StorageManagerStub) MarkForEviction(d []byte, m data.ModifiedHashes) error
- func (sms *StorageManagerStub) Prune([]byte, data.TriePruningIdentifier)
- func (sms *StorageManagerStub) SetCheckpoint([]byte)
- func (sms *StorageManagerStub) TakeSnapshot([]byte)
- type StorerMock
- func (sm *StorerMock) ClearCache()
- func (sm *StorerMock) Close() error
- func (sm *StorerMock) DestroyUnit() error
- func (sm *StorerMock) Get(key []byte) ([]byte, error)
- func (sm *StorerMock) GetBulkFromEpoch(keys [][]byte, _ uint32) (map[string][]byte, error)
- func (sm *StorerMock) GetFromEpoch(key []byte, _ uint32) ([]byte, error)
- func (sm *StorerMock) Has(_ []byte) error
- func (sm *StorerMock) HasInEpoch(key []byte, _ uint32) error
- func (sm *StorerMock) IsInterfaceNil() bool
- func (sm *StorerMock) Put(key, data []byte) error
- func (sm *StorerMock) RangeKeys(handler func(key []byte, val []byte) bool)
- func (sm *StorerMock) Remove(_ []byte) error
- func (sm *StorerMock) SearchFirst(_ []byte) ([]byte, error)
- type StorerStub
- func (ss *StorerStub) ClearCache()
- func (ss *StorerStub) Close() error
- func (ss *StorerStub) DestroyUnit() error
- func (ss *StorerStub) Get(key []byte) ([]byte, error)
- func (ss *StorerStub) GetBulkFromEpoch(keys [][]byte, epoch uint32) (map[string][]byte, error)
- func (ss *StorerStub) GetFromEpoch(key []byte, epoch uint32) ([]byte, error)
- func (ss *StorerStub) Has(key []byte) error
- func (ss *StorerStub) HasInEpoch(key []byte, epoch uint32) error
- func (ss *StorerStub) IsInterfaceNil() bool
- func (ss *StorerStub) Put(key, data []byte) error
- func (ss *StorerStub) RangeKeys(handler func(key []byte, val []byte) bool)
- func (ss *StorerStub) Remove(key []byte) error
- func (ss *StorerStub) SearchFirst(_ []byte) ([]byte, error)
- type SyncStateStub
- func (sss *SyncStateStub) GetAllMiniBlocks() (map[string]*block.MiniBlock, error)
- func (sss *SyncStateStub) GetAllTransactions() (map[string]data.TransactionHandler, error)
- func (sss *SyncStateStub) GetAllTries() (map[string]data.Trie, error)
- func (sss *SyncStateStub) GetEpochStartMetaBlock() (*block.MetaBlock, error)
- func (sss *SyncStateStub) GetUnfinishedMetaBlocks() (map[string]*block.MetaBlock, error)
- func (sss *SyncStateStub) IsInterfaceNil() bool
- func (sss *SyncStateStub) SyncAllState(epoch uint32) error
- type TransactionCoordinatorMock
- func (tcm *TransactionCoordinatorMock) ComputeTransactionType(tx data.TransactionHandler) (process.TransactionType, error)
- func (tcm *TransactionCoordinatorMock) CreateBlockStarted()
- func (tcm *TransactionCoordinatorMock) CreateMarshalizedData(body *block.Body) map[string][][]byte
- func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessCrossShardTransactionsDstMe(header data.HeaderHandler, processedMiniBlocksHashes map[string]struct{}, ...) (block.MiniBlockSlice, uint32, bool, error)
- func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessTransactionsFromMe(haveTime func() bool) block.MiniBlockSlice
- func (tcm *TransactionCoordinatorMock) CreatePostProcessMiniBlocks() block.MiniBlockSlice
- func (tcm *TransactionCoordinatorMock) CreateReceiptsHash() ([]byte, error)
- func (tcm *TransactionCoordinatorMock) GetAllCurrentUsedTxs(blockType block.Type) map[string]data.TransactionHandler
- func (tcm *TransactionCoordinatorMock) IsDataPreparedForProcessing(haveTime func() time.Duration) error
- func (tcm *TransactionCoordinatorMock) IsInterfaceNil() bool
- func (tcm *TransactionCoordinatorMock) ProcessBlockTransaction(body *block.Body, haveTime func() time.Duration) error
- func (tcm *TransactionCoordinatorMock) RemoveBlockDataFromPool(body *block.Body) error
- func (tcm *TransactionCoordinatorMock) RequestBlockTransactions(body *block.Body)
- func (tcm *TransactionCoordinatorMock) RequestMiniBlocks(header data.HeaderHandler)
- func (tcm *TransactionCoordinatorMock) RestoreBlockDataFromStorage(body *block.Body) (int, error)
- func (tcm *TransactionCoordinatorMock) SaveBlockDataToStorage(body *block.Body) error
- func (tcm *TransactionCoordinatorMock) VerifyCreatedBlockTransactions(hdr data.HeaderHandler, body *block.Body) error
- type TrieFactoryStub
- type TrieStub
- func (ts *TrieStub) AppendToOldHashes(hashes [][]byte)
- func (ts *TrieStub) CancelPrune(rootHash []byte, identifier data.TriePruningIdentifier)
- func (ts *TrieStub) ClosePersister() error
- func (ts *TrieStub) Commit() error
- func (ts *TrieStub) Database() data.DBWriteCacher
- func (ts *TrieStub) Delete(key []byte) error
- func (ts *TrieStub) EnterSnapshotMode()
- func (ts *TrieStub) ExitSnapshotMode()
- func (ts *TrieStub) Get(key []byte) ([]byte, error)
- func (ts *TrieStub) GetAllHashes() ([][]byte, error)
- func (ts *TrieStub) GetAllLeaves() (map[string][]byte, error)
- func (ts *TrieStub) GetAllLeavesOnChannel() chan core.KeyValueHolder
- func (ts *TrieStub) GetDirtyHashes() (data.ModifiedHashes, error)
- func (ts *TrieStub) GetSerializedNodes(hash []byte, maxBuffToSend uint64) ([][]byte, uint64, error)
- func (ts *TrieStub) GetSnapshotDbBatchDelay() int
- func (ts *TrieStub) IsInterfaceNil() bool
- func (ts *TrieStub) IsPruningEnabled() bool
- func (ts *TrieStub) Prune(rootHash []byte, identifier data.TriePruningIdentifier)
- func (ts *TrieStub) Recreate(root []byte) (data.Trie, error)
- func (ts *TrieStub) ResetOldHashes() [][]byte
- func (ts *TrieStub) Root() ([]byte, error)
- func (ts *TrieStub) SetCheckpoint(_ []byte)
- func (ts *TrieStub) SetNewHashes(_ data.ModifiedHashes)
- func (ts *TrieStub) Snapshot() error
- func (ts *TrieStub) String() string
- func (ts *TrieStub) TakeSnapshot(_ []byte)
- func (ts *TrieStub) Update(key, value []byte) error
- type TrieSyncersStub
- func (tss *TrieSyncersStub) Add(key string, val update.TrieSyncer) error
- func (tss *TrieSyncersStub) AddMultiple(keys []string, interceptors []update.TrieSyncer) error
- func (tss *TrieSyncersStub) Get(key string) (update.TrieSyncer, error)
- func (tss *TrieSyncersStub) IsInterfaceNil() bool
- func (tss *TrieSyncersStub) Len() int
- func (tss *TrieSyncersStub) Remove(key string)
- func (tss *TrieSyncersStub) Replace(key string, val update.TrieSyncer) error
- func (tss *TrieSyncersStub) StartSyncing(rootHash []byte, ctx context.Context) error
- func (tss *TrieSyncersStub) Trie() data.Trie
- type TriesHolderMock
- func (thm *TriesHolderMock) Get(key []byte) data.Trie
- func (thm *TriesHolderMock) GetAll() []data.Trie
- func (thm *TriesHolderMock) IsInterfaceNil() bool
- func (thm *TriesHolderMock) Put(key []byte, trie data.Trie)
- func (thm *TriesHolderMock) Replace(key []byte, trie data.Trie)
- func (thm *TriesHolderMock) Reset()
- 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)
- type Uint64ByteSliceConverterStub
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
func NewOneShardCoordinatorMock ¶
func NewOneShardCoordinatorMock() *oneShardCoordinatorMock
NewOneShardCoordinatorMock -
Types ¶
type AccountsDBSyncerStub ¶
type AccountsDBSyncerStub struct { GetSyncedTriesCalled func() map[string]data.Trie SyncAccountsCalled func(rootHash []byte) error }
AccountsDBSyncerStub -
func (*AccountsDBSyncerStub) GetSyncedTries ¶
func (a *AccountsDBSyncerStub) GetSyncedTries() map[string]data.Trie
GetSyncedTries -
func (*AccountsDBSyncerStub) IsInterfaceNil ¶
func (a *AccountsDBSyncerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*AccountsDBSyncerStub) SyncAccounts ¶
func (a *AccountsDBSyncerStub) SyncAccounts(rootHash []byte) error
SyncAccounts -
type AccountsDBSyncersStub ¶
type AccountsDBSyncersStub struct { GetCalled func(key string) (update.AccountsDBSyncer, error) AddCalled func(key string, val update.AccountsDBSyncer) error AddMultipleCalled func(keys []string, interceptors []update.AccountsDBSyncer) error ReplaceCalled func(key string, val update.AccountsDBSyncer) error RemoveCalled func(key string) LenCalled func() int StartSyncingCalled func(rootHash []byte) error TrieCalled func() data.Trie }
AccountsDBSyncersStub -
func (*AccountsDBSyncersStub) Add ¶
func (a *AccountsDBSyncersStub) Add(key string, val update.AccountsDBSyncer) error
Add -
func (*AccountsDBSyncersStub) AddMultiple ¶
func (a *AccountsDBSyncersStub) AddMultiple(keys []string, interceptors []update.AccountsDBSyncer) error
AddMultiple -
func (*AccountsDBSyncersStub) Get ¶
func (a *AccountsDBSyncersStub) Get(key string) (update.AccountsDBSyncer, error)
Get -
func (*AccountsDBSyncersStub) IsInterfaceNil ¶
func (a *AccountsDBSyncersStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*AccountsDBSyncersStub) Replace ¶
func (a *AccountsDBSyncersStub) Replace(key string, val update.AccountsDBSyncer) error
Replace -
type AccountsStub ¶
type AccountsStub struct { AddJournalEntryCalled func(je state.JournalEntry) GetExistingAccountCalled func(address []byte) (state.AccountHandler, error) LoadAccountCalled func(address []byte) (state.AccountHandler, error) SaveAccountCalled func(account state.AccountHandler) error RemoveAccountCalled func(address []byte) error CommitCalled func() ([]byte, error) JournalLenCalled func() int RevertToSnapshotCalled func(snapshot int) error RootHashCalled func() ([]byte, error) RecreateTrieCalled func(rootHash []byte) error PruneTrieCalled func(rootHash []byte, identifier data.TriePruningIdentifier) CancelPruneCalled func(rootHash []byte, identifier data.TriePruningIdentifier) SnapshotStateCalled func(rootHash []byte) SetStateCheckpointCalled func(rootHash []byte) IsPruningEnabledCalled func() bool GetAllLeavesCalled func(rootHash []byte) (map[string][]byte, error) RecreateAllTriesCalled func(rootHash []byte) (map[string]data.Trie, error) GetNumCheckpointsCalled func() uint32 }
AccountsStub -
func (*AccountsStub) AddJournalEntry ¶
func (as *AccountsStub) AddJournalEntry(je state.JournalEntry)
AddJournalEntry -
func (*AccountsStub) CancelPrune ¶
func (as *AccountsStub) CancelPrune(rootHash []byte, identifier data.TriePruningIdentifier)
CancelPrune -
func (*AccountsStub) GetAllLeaves ¶
func (as *AccountsStub) GetAllLeaves(rootHash []byte) (map[string][]byte, error)
GetAllLeaves -
func (*AccountsStub) GetExistingAccount ¶
func (as *AccountsStub) GetExistingAccount(address []byte) (state.AccountHandler, error)
GetExistingAccount -
func (*AccountsStub) GetNumCheckpoints ¶ added in v0.0.2
func (as *AccountsStub) GetNumCheckpoints() uint32
GetNumCheckpoints -
func (*AccountsStub) IsInterfaceNil ¶
func (as *AccountsStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*AccountsStub) IsPruningEnabled ¶
func (as *AccountsStub) IsPruningEnabled() bool
IsPruningEnabled -
func (*AccountsStub) LoadAccount ¶
func (as *AccountsStub) LoadAccount(address []byte) (state.AccountHandler, error)
LoadAccount -
func (*AccountsStub) PruneTrie ¶
func (as *AccountsStub) PruneTrie(rootHash []byte, identifier data.TriePruningIdentifier)
PruneTrie -
func (*AccountsStub) RecreateAllTries ¶
RecreateAllTries -
func (*AccountsStub) RecreateTrie ¶
func (as *AccountsStub) RecreateTrie(rootHash []byte) error
RecreateTrie -
func (*AccountsStub) RemoveAccount ¶
func (as *AccountsStub) RemoveAccount(address []byte) error
RemoveAccount -
func (*AccountsStub) RevertToSnapshot ¶
func (as *AccountsStub) RevertToSnapshot(snapshot int) error
RevertToSnapshot -
func (*AccountsStub) SaveAccount ¶
func (as *AccountsStub) SaveAccount(account state.AccountHandler) error
SaveAccount -
func (*AccountsStub) SetStateCheckpoint ¶
func (as *AccountsStub) SetStateCheckpoint(rootHash []byte)
SetStateCheckpoint -
func (*AccountsStub) SnapshotState ¶
func (as *AccountsStub) SnapshotState(rootHash []byte)
SnapshotState -
type AddressMock ¶
type AddressMock struct {
// contains filtered or unexported fields
}
AddressMock implements a mock address generator used in testing
func (*AddressMock) Bytes ¶
func (address *AddressMock) Bytes() []byte
Bytes returns the address' bytes
func (*AddressMock) IsInterfaceNil ¶
func (address *AddressMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type ChainStorerMock ¶
type ChainStorerMock struct { AddStorerCalled func(key dataRetriever.UnitType, s storage.Storer) GetStorerCalled func(unitType dataRetriever.UnitType) storage.Storer HasCalled func(unitType dataRetriever.UnitType, key []byte) error GetCalled func(unitType dataRetriever.UnitType, key []byte) ([]byte, error) PutCalled func(unitType dataRetriever.UnitType, key []byte, value []byte) error GetAllCalled func(unitType dataRetriever.UnitType, keys [][]byte) (map[string][]byte, error) DestroyCalled func() error }
ChainStorerMock is a mock implementation of the ChainStorer interface
func (*ChainStorerMock) AddStorer ¶
func (bc *ChainStorerMock) AddStorer(key dataRetriever.UnitType, s storage.Storer)
AddStorer will add a new storer to the chain map
func (*ChainStorerMock) Destroy ¶
func (bc *ChainStorerMock) Destroy() error
Destroy removes the underlying files/resources used by the storage service
func (*ChainStorerMock) Get ¶
func (bc *ChainStorerMock) Get(unitType dataRetriever.UnitType, key []byte) ([]byte, error)
Get returns the value for the given key if found in the selected storage unit, nil otherwise. It can return an error if the provided unit type is not supported or if the storage unit underlying implementation reports an error
func (*ChainStorerMock) GetAll ¶
func (bc *ChainStorerMock) GetAll(unitType dataRetriever.UnitType, keys [][]byte) (map[string][]byte, error)
GetAll gets all the elements with keys in the keys array, from the selected storage unit It can report an error if the provided unit type is not supported, if there is a missing key in the unit, or if the underlying implementation of the storage unit reports an error.
func (*ChainStorerMock) GetStorer ¶
func (bc *ChainStorerMock) GetStorer(unitType dataRetriever.UnitType) storage.Storer
GetStorer returns the storer from the chain map or nil if the storer was not found
func (*ChainStorerMock) Has ¶
func (bc *ChainStorerMock) Has(unitType dataRetriever.UnitType, key []byte) error
Has returns true if the key is found in the selected Unit or false otherwise It can return an error if the provided unit type is not supported or if the underlying implementation of the storage unit reports an error.
func (*ChainStorerMock) IsInterfaceNil ¶
func (bc *ChainStorerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ChainStorerMock) Put ¶
func (bc *ChainStorerMock) Put(unitType dataRetriever.UnitType, key []byte, value []byte) error
Put stores the key, value pair in the selected storage unit It can return an error if the provided unit type is not supported or if the storage unit underlying implementation reports an error
func (*ChainStorerMock) SetEpochForPutOperation ¶
func (bc *ChainStorerMock) SetEpochForPutOperation(epoch uint32)
SetEpochForPutOperation won't do anything
type CoordinatorStub ¶
type CoordinatorStub struct { NumberOfShardsCalled func() uint32 ComputeIdCalled func(address []byte) uint32 SelfIdCalled func() uint32 SameShardCalled func(firstAddress, secondAddress []byte) bool CommunicationIdentifierCalled func(destShardID uint32) string }
CoordinatorStub -
func (*CoordinatorStub) CommunicationIdentifier ¶
func (coordinator *CoordinatorStub) CommunicationIdentifier(destShardID uint32) string
CommunicationIdentifier -
func (*CoordinatorStub) ComputeId ¶
func (coordinator *CoordinatorStub) ComputeId(address []byte) uint32
ComputeId -
func (*CoordinatorStub) IsInterfaceNil ¶
func (coordinator *CoordinatorStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*CoordinatorStub) NumberOfShards ¶
func (coordinator *CoordinatorStub) NumberOfShards() uint32
NumberOfShards -
func (*CoordinatorStub) SameShard ¶
func (coordinator *CoordinatorStub) SameShard(firstAddress, secondAddress []byte) bool
SameShard -
type EpochHandlerStub ¶
type EpochHandlerStub struct {
MetaEpochCalled func() uint32
}
EpochHandlerStub -
func (*EpochHandlerStub) IsInterfaceNil ¶
func (ehs *EpochHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
type EpochStartNotifierStub ¶
type EpochStartNotifierStub struct { RegisterHandlerCalled func(handler epochStart.ActionHandler) UnregisterHandlerCalled func(handler epochStart.ActionHandler) NotifyAllCalled func(hdr data.HeaderHandler) NotifyAllPrepareCalled func(hdr data.HeaderHandler, body data.BodyHandler) NotifyEpochChangeConfirmedCalled func(epoch uint32) RegisterForEpochChangeConfirmedCalled func(handler func(epoch uint32)) // contains filtered or unexported fields }
EpochStartNotifierStub -
func (*EpochStartNotifierStub) IsInterfaceNil ¶
func (esnm *EpochStartNotifierStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EpochStartNotifierStub) NotifyAll ¶
func (esnm *EpochStartNotifierStub) NotifyAll(hdr data.HeaderHandler)
NotifyAll -
func (*EpochStartNotifierStub) NotifyAllPrepare ¶
func (esnm *EpochStartNotifierStub) NotifyAllPrepare(metaHdr data.HeaderHandler, body data.BodyHandler)
NotifyAllPrepare -
func (*EpochStartNotifierStub) NotifyEpochChangeConfirmed ¶
func (esnm *EpochStartNotifierStub) NotifyEpochChangeConfirmed(epoch uint32)
NotifyEpochChangeConfirmed -
func (*EpochStartNotifierStub) RegisterForEpochChangeConfirmed ¶
func (esnm *EpochStartNotifierStub) RegisterForEpochChangeConfirmed(handler func(epoch uint32))
RegisterForEpochChangeConfirmed -
func (*EpochStartNotifierStub) RegisterHandler ¶
func (esnm *EpochStartNotifierStub) RegisterHandler(handler epochStart.ActionHandler)
RegisterHandler -
func (*EpochStartNotifierStub) UnregisterHandler ¶
func (esnm *EpochStartNotifierStub) UnregisterHandler(handler epochStart.ActionHandler)
UnregisterHandler -
type EpochStartPendingMiniBlocksSyncHandlerMock ¶
type EpochStartPendingMiniBlocksSyncHandlerMock struct { SyncPendingMiniBlocksFromMetaCalled func(epochStart *block.MetaBlock, unFinished map[string]*block.MetaBlock, ctx context.Context) error GetMiniBlocksCalled func() (map[string]*block.MiniBlock, error) }
EpochStartPendingMiniBlocksSyncHandlerMock -
func (*EpochStartPendingMiniBlocksSyncHandlerMock) GetMiniBlocks ¶
func (ep *EpochStartPendingMiniBlocksSyncHandlerMock) GetMiniBlocks() (map[string]*block.MiniBlock, error)
GetMiniBlocks -
func (*EpochStartPendingMiniBlocksSyncHandlerMock) IsInterfaceNil ¶
func (ep *EpochStartPendingMiniBlocksSyncHandlerMock) IsInterfaceNil() bool
IsInterfaceNil -
type EpochStartTriesSyncHandlerMock ¶
type EpochStartTriesSyncHandlerMock struct { SyncTriesFromCalled func(meta *block.MetaBlock, waitTime time.Duration) error GetTriesCalled func() (map[string]data.Trie, error) }
EpochStartTriesSyncHandlerMock -
func (*EpochStartTriesSyncHandlerMock) GetTries ¶
func (es *EpochStartTriesSyncHandlerMock) GetTries() (map[string]data.Trie, error)
GetTries -
func (*EpochStartTriesSyncHandlerMock) IsInterfaceNil ¶
func (es *EpochStartTriesSyncHandlerMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*EpochStartTriesSyncHandlerMock) SyncTriesFrom ¶
func (es *EpochStartTriesSyncHandlerMock) SyncTriesFrom(meta *block.MetaBlock, waitTime time.Duration) error
SyncTriesFrom -
type EpochStartTriggerStub ¶
type EpochStartTriggerStub struct { ForceEpochStartCalled func(round uint64) error IsEpochStartCalled func() bool EpochCalled func() uint32 ReceivedHeaderCalled func(handler data.HeaderHandler) UpdateCalled func(round uint64) ProcessedCalled func(header data.HeaderHandler) EpochStartRoundCalled 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) error
ForceEpochStart -
func (*EpochStartTriggerStub) GetRoundsPerEpoch ¶
func (e *EpochStartTriggerStub) GetRoundsPerEpoch() uint64
GetRoundsPerEpoch -
func (*EpochStartTriggerStub) IsEpochStart ¶
func (e *EpochStartTriggerStub) IsEpochStart() bool
IsEpochStart -
func (*EpochStartTriggerStub) IsInterfaceNil ¶
func (e *EpochStartTriggerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*EpochStartTriggerStub) NotifyAll ¶
func (e *EpochStartTriggerStub) NotifyAll(_ data.HeaderHandler)
NotifyAll -
func (*EpochStartTriggerStub) ReceivedHeader ¶
func (e *EpochStartTriggerStub) ReceivedHeader(header data.HeaderHandler)
ReceivedHeader -
func (*EpochStartTriggerStub) SetCurrentEpochStartRound ¶
func (e *EpochStartTriggerStub) SetCurrentEpochStartRound(_ uint64)
SetCurrentEpochStartRound -
func (*EpochStartTriggerStub) SetEpoch ¶ added in v0.0.2
func (e *EpochStartTriggerStub) SetEpoch(_ uint32)
SetEpoch -
func (*EpochStartTriggerStub) SetFinalityAttestingRound ¶
func (e *EpochStartTriggerStub) SetFinalityAttestingRound(_ uint64)
SetFinalityAttestingRound -
func (*EpochStartTriggerStub) SetProcessed ¶
func (e *EpochStartTriggerStub) SetProcessed(header data.HeaderHandler)
SetProcessed -
func (*EpochStartTriggerStub) SetRoundsPerEpoch ¶
func (e *EpochStartTriggerStub) SetRoundsPerEpoch(_ uint64)
SetRoundsPerEpoch -
func (*EpochStartTriggerStub) SetTrigger ¶
func (e *EpochStartTriggerStub) SetTrigger(_ epochStart.TriggerHandler)
SetTrigger -
func (*EpochStartTriggerStub) Update ¶
func (e *EpochStartTriggerStub) Update(round uint64)
Update -
type ExportFactoryHandlerStub ¶
type ExportFactoryHandlerStub struct {
CreateCalled func() (update.ExportHandler, error)
}
ExportFactoryHandlerStub -
func (*ExportFactoryHandlerStub) Create ¶
func (e *ExportFactoryHandlerStub) Create() (update.ExportHandler, error)
Create -
func (*ExportFactoryHandlerStub) IsInterfaceNil ¶
func (e *ExportFactoryHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
type ExportHandlerStub ¶
ExportHandlerStub -
func (*ExportHandlerStub) ExportAll ¶
func (e *ExportHandlerStub) ExportAll(epoch uint32) error
ExportAll -
func (*ExportHandlerStub) IsInterfaceNil ¶
func (e *ExportHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
type GenesisNodesSetupHandlerStub ¶ added in v0.0.2
type GenesisNodesSetupHandlerStub struct { InitialNodesInfoForShardCalled func(shardId uint32) ([]sharding.GenesisNodeInfoHandler, []sharding.GenesisNodeInfoHandler, error) InitialNodesInfoCalled func() (map[uint32][]sharding.GenesisNodeInfoHandler, map[uint32][]sharding.GenesisNodeInfoHandler) GetStartTimeCalled func() int64 GetRoundDurationCalled func() uint64 GetChainIdCalled func() string GetMinTransactionVersionCalled func() uint32 GetShardConsensusGroupSizeCalled func() uint32 GetMetaConsensusGroupSizeCalled func() uint32 MinNumberOfShardNodesCalled func() uint32 MinNumberOfMetaNodesCalled func() uint32 GetHysteresisCalled func() float32 GetAdaptivityCalled func() bool NumberOfShardsCalled func() uint32 MinNumberOfNodesCalled func() uint32 }
GenesisNodesSetupHandlerStub -
func (*GenesisNodesSetupHandlerStub) GetAdaptivity ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) GetAdaptivity() bool
GetAdaptivity -
func (*GenesisNodesSetupHandlerStub) GetChainId ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) GetChainId() string
GetChainId -
func (*GenesisNodesSetupHandlerStub) GetHysteresis ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) GetHysteresis() float32
GetHysteresis -
func (*GenesisNodesSetupHandlerStub) GetMetaConsensusGroupSize ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) GetMetaConsensusGroupSize() uint32
GetMetaConsensusGroupSize -
func (*GenesisNodesSetupHandlerStub) GetMinTransactionVersion ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) GetMinTransactionVersion() uint32
GetMinTransactionVersion -
func (*GenesisNodesSetupHandlerStub) GetRoundDuration ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) GetRoundDuration() uint64
GetRoundDuration -
func (*GenesisNodesSetupHandlerStub) GetShardConsensusGroupSize ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) GetShardConsensusGroupSize() uint32
GetShardConsensusGroupSize -
func (*GenesisNodesSetupHandlerStub) GetStartTime ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) GetStartTime() int64
GetStartTime -
func (*GenesisNodesSetupHandlerStub) InitialNodesInfo ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) InitialNodesInfo() (map[uint32][]sharding.GenesisNodeInfoHandler, map[uint32][]sharding.GenesisNodeInfoHandler)
InitialNodesInfo -
func (*GenesisNodesSetupHandlerStub) InitialNodesInfoForShard ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) InitialNodesInfoForShard(shardId uint32) ([]sharding.GenesisNodeInfoHandler, []sharding.GenesisNodeInfoHandler, error)
InitialNodesInfoForShard -
func (*GenesisNodesSetupHandlerStub) IsInterfaceNil ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*GenesisNodesSetupHandlerStub) MinNumberOfMetaNodes ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) MinNumberOfMetaNodes() uint32
MinNumberOfMetaNodes -
func (*GenesisNodesSetupHandlerStub) MinNumberOfNodes ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) MinNumberOfNodes() uint32
MinNumberOfNodes -
func (*GenesisNodesSetupHandlerStub) MinNumberOfShardNodes ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) MinNumberOfShardNodes() uint32
MinNumberOfShardNodes -
func (*GenesisNodesSetupHandlerStub) NumberOfShards ¶ added in v0.0.2
func (g *GenesisNodesSetupHandlerStub) NumberOfShards() uint32
NumberOfShards -
type HardForkBlockProcessor ¶
type HardForkBlockProcessor struct { CreateNewBlockCalled func( chainID string, round uint64, nonce uint64, epoch uint32, ) (data.HeaderHandler, data.BodyHandler, error) }
HardForkBlockProcessor --
func (*HardForkBlockProcessor) CreateNewBlock ¶
func (hfbp *HardForkBlockProcessor) CreateNewBlock(chainID string, round uint64, nonce uint64, epoch uint32) (data.HeaderHandler, data.BodyHandler, error)
CreateNewBlock --
func (*HardForkBlockProcessor) IsInterfaceNil ¶
func (hfbp *HardForkBlockProcessor) IsInterfaceNil() bool
IsInterfaceNil returns true if underlying object is nil
type HardforkStorerStub ¶ added in v0.0.2
type HardforkStorerStub struct { WriteCalled func(identifier string, key []byte, value []byte) error FinishedIdentifierCalled func(identifier string) error RangeKeysCalled func(handler func(identifier string, keys [][]byte) bool) GetCalled func(identifier string, key []byte) ([]byte, error) CloseCalled func() error }
HardforkStorerStub -
func (*HardforkStorerStub) Close ¶ added in v0.0.2
func (hss *HardforkStorerStub) Close() error
Close -
func (*HardforkStorerStub) FinishedIdentifier ¶ added in v0.0.2
func (hss *HardforkStorerStub) FinishedIdentifier(identifier string) error
FinishedIdentifier -
func (*HardforkStorerStub) Get ¶ added in v0.0.2
func (hss *HardforkStorerStub) Get(identifier string, key []byte) ([]byte, error)
Get -
func (*HardforkStorerStub) IsInterfaceNil ¶ added in v0.0.2
func (hss *HardforkStorerStub) IsInterfaceNil() bool
IsInterfaceNil -
type HasherMock ¶
type HasherMock struct { }
HasherMock that will be used for testing
func (HasherMock) Compute ¶
func (sha HasherMock) Compute(s string) []byte
Compute will output the SHA's equivalent of the input string
func (HasherMock) EmptyHash ¶
func (sha HasherMock) EmptyHash() []byte
EmptyHash will return the equivalent of empty string SHA's
func (HasherMock) IsInterfaceNil ¶
func (sha HasherMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type HasherStub ¶
HasherStub -
func (*HasherStub) IsInterfaceNil ¶
func (hash *HasherStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type HeaderSyncHandlerStub ¶
type HeaderSyncHandlerStub struct { SyncUnFinishedMetaHeadersCalled func(epoch uint32) error GetEpochStartMetaBlockCalled func() (*block.MetaBlock, error) GetUnfinishedMetaBlocksCalled func() (map[string]*block.MetaBlock, error) }
HeaderSyncHandlerStub -
func (*HeaderSyncHandlerStub) GetEpochStartMetaBlock ¶
func (hsh *HeaderSyncHandlerStub) GetEpochStartMetaBlock() (*block.MetaBlock, error)
GetEpochStartMetaBlock -
func (*HeaderSyncHandlerStub) GetUnfinishedMetaBlocks ¶
func (hsh *HeaderSyncHandlerStub) GetUnfinishedMetaBlocks() (map[string]*block.MetaBlock, error)
GetUnfinishedMetaBlocks -
func (*HeaderSyncHandlerStub) IsInterfaceNil ¶
func (hsh *HeaderSyncHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HeaderSyncHandlerStub) SyncUnFinishedMetaHeaders ¶
func (hsh *HeaderSyncHandlerStub) SyncUnFinishedMetaHeaders(epoch uint32) error
SyncUnFinishedMetaHeaders -
type HeaderValidatorStub ¶
type HeaderValidatorStub struct {
IsHeaderConstructionValidCalled func(currHdr, prevHdr data.HeaderHandler) error
}
HeaderValidatorStub -
func (*HeaderValidatorStub) IsHeaderConstructionValid ¶
func (hvs *HeaderValidatorStub) IsHeaderConstructionValid(currHdr, prevHdr data.HeaderHandler) error
IsHeaderConstructionValid -
func (*HeaderValidatorStub) IsInterfaceNil ¶
func (hvs *HeaderValidatorStub) IsInterfaceNil() bool
IsInterfaceNil returns if underlying object is true
type HeadersCacherStub ¶
type HeadersCacherStub struct { AddCalled func(headerHash []byte, header data.HeaderHandler) RemoveHeaderByHashCalled func(headerHash []byte) RemoveHeaderByNonceAndShardIdCalled func(hdrNonce uint64, shardId uint32) GetHeaderByNonceAndShardIdCalled func(hdrNonce uint64, shardId uint32) ([]data.HeaderHandler, [][]byte, error) GetHeaderByHashCalled func(hash []byte) (data.HeaderHandler, error) ClearCalled func() RegisterHandlerCalled func(handler func(header data.HeaderHandler, shardHeaderHash []byte)) NoncesCalled func(shardId uint32) []uint64 LenCalled func() int MaxSizeCalled func() int GetNumHeadersCalled func(shardId uint32) int }
HeadersCacherStub -
func (*HeadersCacherStub) AddHeader ¶
func (hcs *HeadersCacherStub) AddHeader(headerHash []byte, header data.HeaderHandler)
AddHeader -
func (*HeadersCacherStub) GetHeaderByHash ¶
func (hcs *HeadersCacherStub) GetHeaderByHash(hash []byte) (data.HeaderHandler, error)
GetHeaderByHash -
func (*HeadersCacherStub) GetHeadersByNonceAndShardId ¶
func (hcs *HeadersCacherStub) GetHeadersByNonceAndShardId(hdrNonce uint64, shardId uint32) ([]data.HeaderHandler, [][]byte, error)
GetHeadersByNonceAndShardId -
func (*HeadersCacherStub) GetNumHeaders ¶
func (hcs *HeadersCacherStub) GetNumHeaders(shardId uint32) int
GetNumHeaders -
func (*HeadersCacherStub) IsInterfaceNil ¶
func (hcs *HeadersCacherStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*HeadersCacherStub) Nonces ¶
func (hcs *HeadersCacherStub) Nonces(shardId uint32) []uint64
Nonces -
func (*HeadersCacherStub) RegisterHandler ¶
func (hcs *HeadersCacherStub) RegisterHandler(handler func(header data.HeaderHandler, shardHeaderHash []byte))
RegisterHandler -
func (*HeadersCacherStub) RemoveHeaderByHash ¶
func (hcs *HeadersCacherStub) RemoveHeaderByHash(headerHash []byte)
RemoveHeaderByHash -
func (*HeadersCacherStub) RemoveHeaderByNonceAndShardId ¶
func (hcs *HeadersCacherStub) RemoveHeaderByNonceAndShardId(hdrNonce uint64, shardId uint32)
RemoveHeaderByNonceAndShardId -
type ImportHandlerStub ¶
type ImportHandlerStub struct { ImportAllCalled func() error GetValidatorAccountsDBCalled func() state.AccountsAdapter GetMiniBlocksCalled func() map[string]*block.MiniBlock GetHardForkMetaBlockCalled func() *block.MetaBlock GetTransactionsCalled func() map[string]data.TransactionHandler GetAccountsDBForShardCalled func(shardID uint32) state.AccountsAdapter }
ImportHandlerStub -
func (*ImportHandlerStub) GetAccountsDBForShard ¶
func (ihs *ImportHandlerStub) GetAccountsDBForShard(shardID uint32) state.AccountsAdapter
GetAccountsDBForShard -
func (*ImportHandlerStub) GetHardForkMetaBlock ¶
func (ihs *ImportHandlerStub) GetHardForkMetaBlock() *block.MetaBlock
GetHardForkMetaBlock -
func (*ImportHandlerStub) GetMiniBlocks ¶
func (ihs *ImportHandlerStub) GetMiniBlocks() map[string]*block.MiniBlock
GetMiniBlocks -
func (*ImportHandlerStub) GetTransactions ¶
func (ihs *ImportHandlerStub) GetTransactions() map[string]data.TransactionHandler
GetTransactions -
func (*ImportHandlerStub) GetValidatorAccountsDB ¶
func (ihs *ImportHandlerStub) GetValidatorAccountsDB() state.AccountsAdapter
GetValidatorAccountsDB -
func (*ImportHandlerStub) IsInterfaceNil ¶
func (ihs *ImportHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
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 MarshalizerFake ¶
type MarshalizerFake struct {
Fail bool
}
MarshalizerFake that will be used for testing
func (*MarshalizerFake) IsInterfaceNil ¶
func (mm *MarshalizerFake) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*MarshalizerFake) Marshal ¶
func (mm *MarshalizerFake) Marshal(obj interface{}) ([]byte, error)
Marshal converts the input object in a slice of bytes
func (*MarshalizerFake) Unmarshal ¶
func (mm *MarshalizerFake) Unmarshal(obj interface{}, buff []byte) error
Unmarshal applies the serialized values over an instantiated object
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 PendingTransactionProcessorStub ¶
type PendingTransactionProcessorStub struct { ProcessTransactionsDstMeCalled func(mapTxs map[string]data.TransactionHandler) (block.MiniBlockSlice, error) RootHashCalled func() ([]byte, error) }
PendingTransactionProcessorStub -
func (*PendingTransactionProcessorStub) IsInterfaceNil ¶
func (ptps *PendingTransactionProcessorStub) IsInterfaceNil() bool
IsInterfaceNil --
func (*PendingTransactionProcessorStub) ProcessTransactionsDstMe ¶
func (ptps *PendingTransactionProcessorStub) ProcessTransactionsDstMe(mapTxs map[string]data.TransactionHandler) (block.MiniBlockSlice, error)
ProcessTransactionsDstMe -
func (*PendingTransactionProcessorStub) RootHash ¶
func (ptps *PendingTransactionProcessorStub) RootHash() ([]byte, error)
RootHash --
type PendingTransactionsSyncHandlerMock ¶
type PendingTransactionsSyncHandlerMock struct { SyncPendingTransactionsForCalled func(miniBlocks map[string]*block.MiniBlock, epoch uint32, ctx context.Context) error GetTransactionsCalled func() (map[string]data.TransactionHandler, error) }
PendingTransactionsSyncHandlerMock -
func (*PendingTransactionsSyncHandlerMock) GetTransactions ¶
func (et *PendingTransactionsSyncHandlerMock) GetTransactions() (map[string]data.TransactionHandler, error)
GetTransactions -
func (*PendingTransactionsSyncHandlerMock) IsInterfaceNil ¶
func (et *PendingTransactionsSyncHandlerMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*PendingTransactionsSyncHandlerMock) SyncPendingTransactionsFor ¶
func (et *PendingTransactionsSyncHandlerMock) SyncPendingTransactionsFor(miniBlocks map[string]*block.MiniBlock, epoch uint32, ctx context.Context) error
SyncPendingTransactionsFor -
type PubkeyConverterStub ¶
type PubkeyConverterStub struct { LenCalled func() int DecodeCalled func(humanReadable string) ([]byte, error) EncodeCalled func(pkBytes []byte) string }
PubkeyConverterStub -
func (*PubkeyConverterStub) Decode ¶
func (pcs *PubkeyConverterStub) Decode(humanReadable string) ([]byte, error)
Decode -
func (*PubkeyConverterStub) Encode ¶
func (pcs *PubkeyConverterStub) Encode(pkBytes []byte) string
Encode -
func (*PubkeyConverterStub) IsInterfaceNil ¶
func (pcs *PubkeyConverterStub) IsInterfaceNil() bool
IsInterfaceNil -
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) RequestTrieNodesCalled func(shardId uint32, hash []byte) RequestStartOfEpochMetaBlockCalled func(epoch uint32) SetNumPeersToQueryCalled func(key string, intra int, cross int) error GetNumPeersToQueryCalled func(key string) (int, int, error) }
RequestHandlerStub -
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(shardId uint32, miniblockHash []byte)
RequestMiniBlock -
func (*RequestHandlerStub) RequestMiniBlocks ¶
func (rhs *RequestHandlerStub) RequestMiniBlocks(_ uint32, _ [][]byte)
RequestMiniBlocks -
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) RequestTrieNodes ¶
func (rhs *RequestHandlerStub) RequestTrieNodes(_ uint32, _ [][]byte, _ string)
RequestTrieNodes -
func (*RequestHandlerStub) RequestUnsignedTransactions ¶
func (rhs *RequestHandlerStub) RequestUnsignedTransactions(destShardID uint32, txHashes [][]byte)
RequestUnsignedTransactions -
func (*RequestHandlerStub) SetNumPeersToQuery ¶
func (rhs *RequestHandlerStub) SetNumPeersToQuery(key string, intra int, cross int) error
SetNumPeersToQuery -
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 SCProcessorMock ¶
type SCProcessorMock struct { ComputeTransactionTypeCalled func(tx data.TransactionHandler) process.TransactionType ExecuteSmartContractTransactionCalled 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) error }
SCProcessorMock -
func (*SCProcessorMock) ComputeTransactionType ¶
func (sc *SCProcessorMock) ComputeTransactionType(tx data.TransactionHandler) process.TransactionType
ComputeTransactionType -
func (*SCProcessorMock) DeploySmartContract ¶
func (sc *SCProcessorMock) DeploySmartContract(tx data.TransactionHandler, acntSrc state.UserAccountHandler) (vmcommon.ReturnCode, error)
DeploySmartContract -
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) ProcessIfError ¶
func (sc *SCProcessorMock) ProcessIfError( acntSnd state.UserAccountHandler, txHash []byte, tx data.TransactionHandler, returnCode string, returnMessage []byte, snapshot int, ) error
ProcessIfError -
func (*SCProcessorMock) ProcessSmartContractResult ¶
func (sc *SCProcessorMock) ProcessSmartContractResult(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)
ProcessSmartContractResult -
type StorageManagerStub ¶
type StorageManagerStub struct { DatabaseCalled func() data.DBWriteCacher TakeSnapshotCalled func([]byte) SetCheckpointCalled func([]byte) PruneCalled func([]byte) CancelPruneCalled func([]byte) MarkForEvictionCalled func([]byte, data.ModifiedHashes) error GetDbThatContainsHashCalled func([]byte) data.DBWriteCacher GetSnapshotThatContainsHashCalled func(rootHash []byte) data.SnapshotDbHandler IsPruningEnabledCalled func() bool EnterSnapshotModeCalled func() ExitSnapshotModeCalled func() IsInterfaceNilCalled func() bool }
StorageManagerStub --
func (*StorageManagerStub) CancelPrune ¶
func (sms *StorageManagerStub) CancelPrune([]byte, data.TriePruningIdentifier)
CancelPrune --
func (*StorageManagerStub) Database ¶
func (sms *StorageManagerStub) Database() data.DBWriteCacher
Database --
func (*StorageManagerStub) EnterSnapshotMode ¶
func (sms *StorageManagerStub) EnterSnapshotMode()
EnterSnapshotMode --
func (*StorageManagerStub) ExitSnapshotMode ¶
func (sms *StorageManagerStub) ExitSnapshotMode()
ExitSnapshotMode --
func (*StorageManagerStub) GetSnapshotDbBatchDelay ¶ added in v0.0.2
func (sms *StorageManagerStub) GetSnapshotDbBatchDelay() int
GetSnapshotDbBatchDelay -
func (*StorageManagerStub) GetSnapshotThatContainsHash ¶
func (sms *StorageManagerStub) GetSnapshotThatContainsHash(d []byte) data.SnapshotDbHandler
GetSnapshotThatContainsHash --
func (*StorageManagerStub) IsInterfaceNil ¶
func (sms *StorageManagerStub) IsInterfaceNil() bool
IsInterfaceNil --
func (*StorageManagerStub) IsPruningEnabled ¶
func (sms *StorageManagerStub) IsPruningEnabled() bool
IsPruningEnabled --
func (*StorageManagerStub) MarkForEviction ¶
func (sms *StorageManagerStub) MarkForEviction(d []byte, m data.ModifiedHashes) error
MarkForEviction --
func (*StorageManagerStub) Prune ¶
func (sms *StorageManagerStub) Prune([]byte, data.TriePruningIdentifier)
Prune --
func (*StorageManagerStub) SetCheckpoint ¶
func (sms *StorageManagerStub) SetCheckpoint([]byte)
SetCheckpoint --
func (*StorageManagerStub) TakeSnapshot ¶
func (sms *StorageManagerStub) TakeSnapshot([]byte)
TakeSnapshot --
type StorerMock ¶
type StorerMock struct {
// contains filtered or unexported fields
}
StorerMock -
func (*StorerMock) GetBulkFromEpoch ¶ added in v0.0.2
GetBulkFromEpoch -
func (*StorerMock) GetFromEpoch ¶
func (sm *StorerMock) GetFromEpoch(key []byte, _ uint32) ([]byte, error)
GetFromEpoch -
func (*StorerMock) HasInEpoch ¶
func (sm *StorerMock) HasInEpoch(key []byte, _ uint32) error
HasInEpoch -
func (*StorerMock) IsInterfaceNil ¶
func (sm *StorerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*StorerMock) RangeKeys ¶ added in v0.0.2
func (sm *StorerMock) RangeKeys(handler func(key []byte, val []byte) bool)
RangeKeys -
func (*StorerMock) SearchFirst ¶
func (sm *StorerMock) SearchFirst(_ []byte) ([]byte, error)
SearchFirst -
type StorerStub ¶
type StorerStub struct { PutCalled func(key, data []byte) error GetCalled func(key []byte) ([]byte, error) HasCalled func(key []byte) error RemoveCalled func(key []byte) error GetFromEpochCalled func(key []byte, epoch uint32) ([]byte, error) HasInEpochCalled func(key []byte, epoch uint32) error ClearCacheCalled func() DestroyUnitCalled func() error RangeKeysCalled func(handler func(key []byte, val []byte) bool) CloseCalled func() error GetBulkFromEpochCalled func(keys [][]byte, epoch uint32) (map[string][]byte, error) }
StorerStub -
func (*StorerStub) GetBulkFromEpoch ¶ added in v0.0.2
GetBulkFromEpoch -
func (*StorerStub) GetFromEpoch ¶
func (ss *StorerStub) GetFromEpoch(key []byte, epoch uint32) ([]byte, error)
GetFromEpoch -
func (*StorerStub) HasInEpoch ¶
func (ss *StorerStub) HasInEpoch(key []byte, epoch uint32) error
HasInEpoch -
func (*StorerStub) IsInterfaceNil ¶
func (ss *StorerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*StorerStub) RangeKeys ¶ added in v0.0.2
func (ss *StorerStub) RangeKeys(handler func(key []byte, val []byte) bool)
RangeKeys -
func (*StorerStub) SearchFirst ¶
func (ss *StorerStub) SearchFirst(_ []byte) ([]byte, error)
SearchFirst -
type SyncStateStub ¶
type SyncStateStub struct { GetEpochStartMetaBlockCalled func() (*block.MetaBlock, error) GetUnfinishedMetaBlocksCalled func() (map[string]*block.MetaBlock, error) SyncAllStateCalled func(epoch uint32) error GetAllTriesCalled func() (map[string]data.Trie, error) GetAllTransactionsCalled func() (map[string]data.TransactionHandler, error) GetAllMiniBlocksCalled func() (map[string]*block.MiniBlock, error) }
SyncStateStub -
func (*SyncStateStub) GetAllMiniBlocks ¶
func (sss *SyncStateStub) GetAllMiniBlocks() (map[string]*block.MiniBlock, error)
GetAllMiniBlocks -
func (*SyncStateStub) GetAllTransactions ¶
func (sss *SyncStateStub) GetAllTransactions() (map[string]data.TransactionHandler, error)
GetAllTransactions -
func (*SyncStateStub) GetAllTries ¶
func (sss *SyncStateStub) GetAllTries() (map[string]data.Trie, error)
GetAllTries -
func (*SyncStateStub) GetEpochStartMetaBlock ¶
func (sss *SyncStateStub) GetEpochStartMetaBlock() (*block.MetaBlock, error)
GetEpochStartMetaBlock -
func (*SyncStateStub) GetUnfinishedMetaBlocks ¶
func (sss *SyncStateStub) GetUnfinishedMetaBlocks() (map[string]*block.MetaBlock, error)
GetUnfinishedMetaBlocks -
func (*SyncStateStub) IsInterfaceNil ¶
func (sss *SyncStateStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*SyncStateStub) SyncAllState ¶
func (sss *SyncStateStub) SyncAllState(epoch uint32) error
SyncAllState -
type TransactionCoordinatorMock ¶
type TransactionCoordinatorMock struct { ComputeTransactionTypeCalled func(tx data.TransactionHandler) (process.TransactionType, error) RequestMiniBlocksCalled func(header data.HeaderHandler) RequestBlockTransactionsCalled func(body *block.Body) IsDataPreparedForProcessingCalled func(haveTime func() time.Duration) error SaveBlockDataToStorageCalled func(body *block.Body) error RestoreBlockDataFromStorageCalled func(body *block.Body) (int, error) RemoveBlockDataFromPoolCalled func(body *block.Body) error ProcessBlockTransactionCalled func(body *block.Body, haveTime func() time.Duration) error CreateBlockStartedCalled func() CreateMbsAndProcessCrossShardTransactionsDstMeCalled func(header data.HeaderHandler, processedMiniBlocksHashes map[string]struct{}, haveTime func() bool, ) (block.MiniBlockSlice, uint32, bool, error) CreateMbsAndProcessTransactionsFromMeCalled func(haveTime func() bool) block.MiniBlockSlice CreateMarshalizedDataCalled func(body *block.Body) map[string][][]byte GetAllCurrentUsedTxsCalled func(blockType block.Type) map[string]data.TransactionHandler VerifyCreatedBlockTransactionsCalled func(hdr data.HeaderHandler, body *block.Body) error CreatePostProcessMiniBlocksCalled func() block.MiniBlockSlice }
TransactionCoordinatorMock -
func (*TransactionCoordinatorMock) ComputeTransactionType ¶
func (tcm *TransactionCoordinatorMock) ComputeTransactionType(tx data.TransactionHandler) (process.TransactionType, error)
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, processedMiniBlocksHashes map[string]struct{}, haveTime func() bool, ) (block.MiniBlockSlice, uint32, bool, error)
CreateMbsAndProcessCrossShardTransactionsDstMe -
func (*TransactionCoordinatorMock) CreateMbsAndProcessTransactionsFromMe ¶
func (tcm *TransactionCoordinatorMock) CreateMbsAndProcessTransactionsFromMe(haveTime func() bool) block.MiniBlockSlice
CreateMbsAndProcessTransactionsFromMe -
func (*TransactionCoordinatorMock) CreatePostProcessMiniBlocks ¶
func (tcm *TransactionCoordinatorMock) CreatePostProcessMiniBlocks() block.MiniBlockSlice
CreatePostProcessMiniBlocks -
func (*TransactionCoordinatorMock) CreateReceiptsHash ¶
func (tcm *TransactionCoordinatorMock) CreateReceiptsHash() ([]byte, error)
CreateReceiptsHash -
func (*TransactionCoordinatorMock) GetAllCurrentUsedTxs ¶
func (tcm *TransactionCoordinatorMock) GetAllCurrentUsedTxs(blockType block.Type) map[string]data.TransactionHandler
GetAllCurrentUsedTxs -
func (*TransactionCoordinatorMock) IsDataPreparedForProcessing ¶
func (tcm *TransactionCoordinatorMock) IsDataPreparedForProcessing(haveTime func() time.Duration) error
IsDataPreparedForProcessing -
func (*TransactionCoordinatorMock) IsInterfaceNil ¶
func (tcm *TransactionCoordinatorMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*TransactionCoordinatorMock) ProcessBlockTransaction ¶
func (tcm *TransactionCoordinatorMock) ProcessBlockTransaction(body *block.Body, haveTime func() time.Duration) error
ProcessBlockTransaction -
func (*TransactionCoordinatorMock) RemoveBlockDataFromPool ¶
func (tcm *TransactionCoordinatorMock) RemoveBlockDataFromPool(body *block.Body) error
RemoveBlockDataFromPool -
func (*TransactionCoordinatorMock) 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) SaveBlockDataToStorage ¶
func (tcm *TransactionCoordinatorMock) SaveBlockDataToStorage(body *block.Body) error
SaveBlockDataToStorage -
func (*TransactionCoordinatorMock) VerifyCreatedBlockTransactions ¶
func (tcm *TransactionCoordinatorMock) VerifyCreatedBlockTransactions(hdr data.HeaderHandler, body *block.Body) error
VerifyCreatedBlockTransactions -
type TrieFactoryStub ¶
type TrieFactoryStub struct {
CreateCalled func(config config.StorageConfig, s string, b bool) (data.StorageManager, data.Trie, error)
}
TrieFactoryStub -
func (*TrieFactoryStub) Create ¶
func (t *TrieFactoryStub) Create(config config.StorageConfig, s string, b bool) (data.StorageManager, data.Trie, error)
Create -
func (*TrieFactoryStub) IsInterfaceNil ¶
func (t *TrieFactoryStub) IsInterfaceNil() bool
IsInterfaceNil -
type TrieStub ¶
type TrieStub struct { GetCalled func(key []byte) ([]byte, error) UpdateCalled func(key, value []byte) error DeleteCalled func(key []byte) error RootCalled func() ([]byte, error) CommitCalled func() error RecreateCalled func(root []byte) (data.Trie, error) CancelPruneCalled func(rootHash []byte, identifier data.TriePruningIdentifier) PruneCalled func(rootHash []byte, identifier data.TriePruningIdentifier) ResetOldHashesCalled func() [][]byte AppendToOldHashesCalled func([][]byte) SnapshotCalled func() error GetSerializedNodesCalled func([]byte, uint64) ([][]byte, uint64, error) GetAllHashesCalled func() ([][]byte, error) DatabaseCalled func() data.DBWriteCacher GetAllLeavesOnChannelCalled func() chan core.KeyValueHolder GetAllLeavesCalled func() (map[string][]byte, error) }
TrieStub -
func (*TrieStub) AppendToOldHashes ¶
AppendToOldHashes appends the given hashes to the trie's oldHashes variable
func (*TrieStub) CancelPrune ¶
func (ts *TrieStub) CancelPrune(rootHash []byte, identifier data.TriePruningIdentifier)
CancelPrune invalidates the hashes that correspond to the given root hash from the eviction waiting list
func (*TrieStub) GetAllLeaves ¶
GetAllLeaves -
func (*TrieStub) GetAllLeavesOnChannel ¶
func (ts *TrieStub) GetAllLeavesOnChannel() chan core.KeyValueHolder
GetAllLeavesOnChannel -
func (*TrieStub) GetDirtyHashes ¶
func (ts *TrieStub) GetDirtyHashes() (data.ModifiedHashes, error)
GetDirtyHashes -
func (*TrieStub) GetSerializedNodes ¶
GetSerializedNodes -
func (*TrieStub) GetSnapshotDbBatchDelay ¶ added in v0.0.2
GetSnapshotDbBatchDelay -
func (*TrieStub) IsInterfaceNil ¶
IsInterfaceNil returns true if there is no value under the interface
func (*TrieStub) Prune ¶
func (ts *TrieStub) Prune(rootHash []byte, identifier data.TriePruningIdentifier)
Prune removes from the database all the old hashes that correspond to the given root hash
func (*TrieStub) ResetOldHashes ¶
ResetOldHashes resets the oldHashes and oldRoot variables and returns the old hashes
func (*TrieStub) SetNewHashes ¶
func (ts *TrieStub) SetNewHashes(_ data.ModifiedHashes)
SetNewHashes -
type TrieSyncersStub ¶
type TrieSyncersStub struct { GetCalled func(key string) (update.TrieSyncer, error) AddCalled func(key string, val update.TrieSyncer) error AddMultipleCalled func(keys []string, interceptors []update.TrieSyncer) error ReplaceCalled func(key string, val update.TrieSyncer) error RemoveCalled func(key string) LenCalled func() int StartSyncingCalled func(rootHash []byte, ctx context.Context) error TrieCalled func() data.Trie }
TrieSyncersStub -
func (*TrieSyncersStub) Add ¶
func (tss *TrieSyncersStub) Add(key string, val update.TrieSyncer) error
Add -
func (*TrieSyncersStub) AddMultiple ¶
func (tss *TrieSyncersStub) AddMultiple(keys []string, interceptors []update.TrieSyncer) error
AddMultiple -
func (*TrieSyncersStub) Get ¶
func (tss *TrieSyncersStub) Get(key string) (update.TrieSyncer, error)
Get -
func (*TrieSyncersStub) IsInterfaceNil ¶
func (tss *TrieSyncersStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*TrieSyncersStub) Replace ¶
func (tss *TrieSyncersStub) Replace(key string, val update.TrieSyncer) error
Replace -
func (*TrieSyncersStub) StartSyncing ¶
func (tss *TrieSyncersStub) StartSyncing(rootHash []byte, ctx context.Context) error
StartSyncing -
type TriesHolderMock ¶
type TriesHolderMock struct { PutCalled func([]byte, data.Trie) RemoveCalled func([]byte, data.Trie) GetCalled func([]byte) data.Trie GetAllCalled func() []data.Trie ResetCalled func() }
TriesHolderMock -
func (*TriesHolderMock) IsInterfaceNil ¶
func (thm *TriesHolderMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type TxProcessorMock ¶
type TxProcessorMock struct { ProcessTransactionCalled func(transaction *transaction.Transaction) (vmcommon.ReturnCode, 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 -
type Uint64ByteSliceConverterStub ¶
type Uint64ByteSliceConverterStub struct { ToByteSliceCalled func(uint64) []byte ToUint64Called func([]byte) (uint64, error) }
Uint64ByteSliceConverterStub converts byte slice to/from uint64
func (*Uint64ByteSliceConverterStub) IsInterfaceNil ¶
func (u *Uint64ByteSliceConverterStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*Uint64ByteSliceConverterStub) ToByteSlice ¶
func (u *Uint64ByteSliceConverterStub) ToByteSlice(p uint64) []byte
ToByteSlice is a mock implementation for Uint64ByteSliceConverter
Source Files ¶
- accountsDBSyncerStub.go
- accountsDBSyncersStub.go
- accountsStub.go
- addressMock.go
- chainStorerMock.go
- closerStub.go
- coordinatorStub.go
- endOfEpochTriggerStub.go
- epochHandlerStub.go
- epochMiniBlocksSyncHandlerMock.go
- epochStartNotifierStub.go
- epochStartTriesSyncHandlerMock.go
- exportFactoryHandlerStub.go
- exportHandlerStub.go
- hardForkBlockProcessor.go
- hardforkStorerStub.go
- hasherMock.go
- hasherStub.go
- headerSyncHandlerStub.go
- headerValidatorStub.go
- headersCacherStub.go
- importHandlerStub.go
- importStartHandlerStub.go
- marshalizerFake.go
- marshalizerMock.go
- nodesSetupHandlerStub.go
- oneShardCoordinatorMock.go
- pendingTransactionProcessorStub.go
- pendingTransactionsSyncHandlerMock.go
- pubkeyConverterStub.go
- requestHandlerStub.go
- rewardTxProcessorMock.go
- scProcessorMock.go
- storageManagerStub.go
- storerMock.go
- storerStub.go
- syncStateStub.go
- transactionCoordinatorMock.go
- trieFactoryStub.go
- trieStub.go
- trieSyncersStub.go
- triesHolderMock.go
- txProcessorMock.go
- uint64ByteSliceConverterStub.go