Documentation ¶
Index ¶
- Variables
- type AccountWrapMock
- func (awm *AccountWrapMock) AddToBalance(_ *big.Int) error
- func (awm *AccountWrapMock) AddToDeveloperReward(*big.Int)
- func (awm *AccountWrapMock) AddressBytes() []byte
- func (awm *AccountWrapMock) ChangeOwnerAddress([]byte, []byte) error
- func (awm *AccountWrapMock) ClaimDeveloperRewards([]byte) (*big.Int, error)
- func (awm *AccountWrapMock) DataTrie() data.Trie
- func (awm *AccountWrapMock) DataTrieTracker() state.DataTrieTracker
- func (awm *AccountWrapMock) GetBalance() *big.Int
- func (awm *AccountWrapMock) GetCode() []byte
- func (awm *AccountWrapMock) GetCodeHash() []byte
- func (awm *AccountWrapMock) GetCodeMetadata() []byte
- func (awm *AccountWrapMock) GetDeveloperReward() *big.Int
- func (awm *AccountWrapMock) GetNonce() uint64
- func (awm *AccountWrapMock) GetOwnerAddress() []byte
- func (awm *AccountWrapMock) GetRootHash() []byte
- func (awm *AccountWrapMock) GetUserName() []byte
- func (awm *AccountWrapMock) IncreaseNonce(val uint64)
- func (awm *AccountWrapMock) IsInterfaceNil() bool
- func (awm *AccountWrapMock) SetCode(code []byte)
- func (awm *AccountWrapMock) SetCodeHash(codeHash []byte)
- func (awm *AccountWrapMock) SetCodeMetadata(codeMetadata []byte)
- func (awm *AccountWrapMock) SetDataTrie(trie data.Trie)
- func (awm *AccountWrapMock) SetOwnerAddress([]byte)
- func (awm *AccountWrapMock) SetRootHash(rootHash []byte)
- func (awm *AccountWrapMock) SetUserName(_ []byte)
- func (awm *AccountWrapMock) SubFromBalance(_ *big.Int) error
- type AccountWrapMockData
- func (*AccountWrapMockData) Descriptor() ([]byte, []int)
- func (this *AccountWrapMockData) Equal(that interface{}) bool
- func (m *AccountWrapMockData) GetMockValue() int64
- func (this *AccountWrapMockData) GoString() string
- func (m *AccountWrapMockData) Marshal() (dAtA []byte, err error)
- func (m *AccountWrapMockData) MarshalTo(dAtA []byte) (int, error)
- func (m *AccountWrapMockData) MarshalToSizedBuffer(dAtA []byte) (int, error)
- func (*AccountWrapMockData) ProtoMessage()
- func (m *AccountWrapMockData) Reset()
- func (m *AccountWrapMockData) Size() (n int)
- func (this *AccountWrapMockData) String() string
- func (m *AccountWrapMockData) Unmarshal(dAtA []byte) error
- func (m *AccountWrapMockData) XXX_DiscardUnknown()
- func (m *AccountWrapMockData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
- func (m *AccountWrapMockData) XXX_Merge(src proto.Message)
- func (m *AccountWrapMockData) XXX_Size() int
- func (m *AccountWrapMockData) XXX_Unmarshal(b []byte) error
- type AccountsFactoryStub
- type AppStatusHandlerStub
- func (ashs *AppStatusHandlerStub) AddUint64(key string, value uint64)
- func (ashs *AppStatusHandlerStub) Close()
- func (ashs *AppStatusHandlerStub) Decrement(key string)
- func (ashs *AppStatusHandlerStub) Increment(key string)
- func (ashs *AppStatusHandlerStub) IsInterfaceNil() bool
- func (ashs *AppStatusHandlerStub) SetInt64Value(key string, value int64)
- func (ashs *AppStatusHandlerStub) SetStringValue(key string, value string)
- func (ashs *AppStatusHandlerStub) SetUInt64Value(key string, value uint64)
- type DataTrieTrackerStub
- func (dtts *DataTrieTrackerStub) ClearDataCaches()
- func (dtts *DataTrieTrackerStub) DataTrie() data.Trie
- func (dtts *DataTrieTrackerStub) DirtyData() map[string][]byte
- func (dtts *DataTrieTrackerStub) IsInterfaceNil() bool
- func (dtts *DataTrieTrackerStub) RetrieveValue(key []byte) ([]byte, error)
- func (dtts *DataTrieTrackerStub) SaveKeyValue(key []byte, value []byte) error
- func (dtts *DataTrieTrackerStub) SetDataTrie(tr data.Trie)
- type EvictionWaitingList
- func (ewl *EvictionWaitingList) Evict(rootHash []byte) (data.ModifiedHashes, error)
- func (ewl *EvictionWaitingList) IsInterfaceNil() bool
- func (ewl *EvictionWaitingList) Put(rootHash []byte, hashes data.ModifiedHashes) error
- func (ewl *EvictionWaitingList) ShouldKeepHash(hash string, identifier data.TriePruningIdentifier) (bool, error)
- type HasherMock
- type HasherMock127
- type KeccakMock
- type MarshalizerMock
- type MarshalizerStub
- type MemDbMock
- func (s *MemDbMock) Close() error
- func (s *MemDbMock) Destroy() error
- func (s *MemDbMock) DestroyClosed() error
- func (s *MemDbMock) Get(key []byte) ([]byte, error)
- func (s *MemDbMock) Has(key []byte) error
- func (s *MemDbMock) Init() error
- func (s *MemDbMock) IsInterfaceNil() bool
- func (s *MemDbMock) Put(key, val []byte) error
- func (s *MemDbMock) RangeKeys(handler func(key []byte, value []byte) bool)
- func (s *MemDbMock) Remove(key []byte) error
- type MultipleShardsCoordinatorMock
- func (scm *MultipleShardsCoordinatorMock) CommunicationIdentifier(destShardID uint32) string
- func (scm *MultipleShardsCoordinatorMock) ComputeId(address []byte) uint32
- func (scm *MultipleShardsCoordinatorMock) IsInterfaceNil() bool
- func (scm *MultipleShardsCoordinatorMock) NumberOfShards() uint32
- func (scm *MultipleShardsCoordinatorMock) SameShard(_, _ []byte) bool
- func (scm *MultipleShardsCoordinatorMock) SelfId() uint32
- func (scm *MultipleShardsCoordinatorMock) SetNoShards(noShards uint32)
- func (scm *MultipleShardsCoordinatorMock) SetSelfId(_ uint32) error
- type PathManagerStub
- type ProtobufMarshalizerMock
- type PubkeyConverterStub
- type RequestHandlerStub
- func (rhs *RequestHandlerStub) IsInterfaceNil() bool
- func (rhs *RequestHandlerStub) RequestInterval() time.Duration
- func (rhs *RequestHandlerStub) RequestMetaHeader(hash []byte)
- func (rhs *RequestHandlerStub) RequestMetaHeaderByNonce(nonce uint64)
- func (rhs *RequestHandlerStub) RequestMiniBlock(destShardID uint32, miniblockHash []byte)
- func (rhs *RequestHandlerStub) RequestMiniBlocks(destShardID uint32, miniblocksHashes [][]byte)
- func (rhs *RequestHandlerStub) 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(destShardID uint32, hashes [][]byte, topic string)
- func (rhs *RequestHandlerStub) RequestUnsignedTransactions(destShardID uint32, txHashes [][]byte)
- func (rhs *RequestHandlerStub) SetEpoch(_ uint32)
- type ShardCoordinatorMock
- func (scm ShardCoordinatorMock) CommunicationIdentifier(destShardID uint32) string
- func (scm ShardCoordinatorMock) ComputeId(_ []byte) uint32
- func (scm *ShardCoordinatorMock) IsInterfaceNil() bool
- func (scm ShardCoordinatorMock) NumberOfShards() uint32
- func (scm ShardCoordinatorMock) SameShard(_, _ []byte) bool
- func (scm ShardCoordinatorMock) SelfId() uint32
- func (scm ShardCoordinatorMock) SetSelfId(_ uint32) 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 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) PutInEpoch(key, data []byte, epoch uint32) error
- func (ss *StorerStub) RangeKeys(handler func(key []byte, val []byte) bool)
- func (ss *StorerStub) Remove(key []byte) error
- func (ss *StorerStub) SearchFirst(key []byte) ([]byte, error)
- type TrieNodesResolverStub
- 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(rootHash []byte)
- func (ts *TrieStub) SetNewHashes(_ data.ModifiedHashes)
- func (ts *TrieStub) String() string
- func (ts *TrieStub) TakeSnapshot(rootHash []byte)
- func (ts *TrieStub) Update(key, value []byte) error
- type UnsignedTxHandlerMock
- func (ut *UnsignedTxHandlerMock) AddRewardTxFromBlock(tx data.TransactionHandler)
- func (ut *UnsignedTxHandlerMock) CleanProcessedUTxs()
- func (ut *UnsignedTxHandlerMock) CreateAllUTxs() []data.TransactionHandler
- func (ut *UnsignedTxHandlerMock) ProcessTransactionFee(cost *big.Int, hash []byte)
- func (ut *UnsignedTxHandlerMock) VerifyCreatedUTxs() error
- type UpdaterStub
Constants ¶
This section is empty.
Variables ¶
Functions ¶
This section is empty.
Types ¶
type AccountWrapMock ¶
type AccountWrapMock struct { AccountWrapMockData CodeHash []byte CodeMetadata []byte RootHash []byte SetNonceWithJournalCalled func(nonce uint64) error `json:"-"` SetCodeHashWithJournalCalled func(codeHash []byte) error `json:"-"` SetCodeWithJournalCalled func([]byte) error `json:"-"` // contains filtered or unexported fields }
AccountWrapMock -
func (*AccountWrapMock) AddToBalance ¶
func (awm *AccountWrapMock) AddToBalance(_ *big.Int) error
AddToBalance -
func (*AccountWrapMock) AddToDeveloperReward ¶
func (awm *AccountWrapMock) AddToDeveloperReward(*big.Int)
AddToDeveloperReward -
func (*AccountWrapMock) AddressBytes ¶ added in v1.0.113
func (awm *AccountWrapMock) AddressBytes() []byte
AddressBytes -
func (*AccountWrapMock) ChangeOwnerAddress ¶
func (awm *AccountWrapMock) ChangeOwnerAddress([]byte, []byte) error
ChangeOwnerAddress -
func (*AccountWrapMock) ClaimDeveloperRewards ¶
func (awm *AccountWrapMock) ClaimDeveloperRewards([]byte) (*big.Int, error)
ClaimDeveloperRewards -
func (*AccountWrapMock) DataTrieTracker ¶
func (awm *AccountWrapMock) DataTrieTracker() state.DataTrieTracker
DataTrieTracker -
func (*AccountWrapMock) GetCodeHash ¶
func (awm *AccountWrapMock) GetCodeHash() []byte
GetCodeHash -
func (*AccountWrapMock) GetCodeMetadata ¶ added in v1.0.103
func (awm *AccountWrapMock) GetCodeMetadata() []byte
GetCodeMetadata -
func (*AccountWrapMock) GetDeveloperReward ¶
func (awm *AccountWrapMock) GetDeveloperReward() *big.Int
GetDeveloperReward -
func (*AccountWrapMock) GetNonce ¶
func (awm *AccountWrapMock) GetNonce() uint64
GetNonce gets the nonce of the account
func (*AccountWrapMock) GetOwnerAddress ¶
func (awm *AccountWrapMock) GetOwnerAddress() []byte
GetOwnerAddress -
func (*AccountWrapMock) GetRootHash ¶
func (awm *AccountWrapMock) GetRootHash() []byte
GetRootHash -
func (*AccountWrapMock) GetUserName ¶ added in v1.0.103
func (awm *AccountWrapMock) GetUserName() []byte
GetUserName -
func (*AccountWrapMock) IncreaseNonce ¶
func (awm *AccountWrapMock) IncreaseNonce(val uint64)
IncreaseNonce adds the given value to the current nonce
func (*AccountWrapMock) IsInterfaceNil ¶
func (awm *AccountWrapMock) IsInterfaceNil() bool
IsInterfaceNil -
func (*AccountWrapMock) SetCodeHash ¶
func (awm *AccountWrapMock) SetCodeHash(codeHash []byte)
SetCodeHash -
func (*AccountWrapMock) SetCodeMetadata ¶ added in v1.0.103
func (awm *AccountWrapMock) SetCodeMetadata(codeMetadata []byte)
SetCodeMetadata -
func (*AccountWrapMock) SetDataTrie ¶
func (awm *AccountWrapMock) SetDataTrie(trie data.Trie)
SetDataTrie -
func (*AccountWrapMock) SetOwnerAddress ¶
func (awm *AccountWrapMock) SetOwnerAddress([]byte)
SetOwnerAddress -
func (*AccountWrapMock) SetRootHash ¶
func (awm *AccountWrapMock) SetRootHash(rootHash []byte)
SetRootHash -
func (*AccountWrapMock) SetUserName ¶ added in v1.0.103
func (awm *AccountWrapMock) SetUserName(_ []byte)
SetUserName -
func (*AccountWrapMock) SubFromBalance ¶
func (awm *AccountWrapMock) SubFromBalance(_ *big.Int) error
SubFromBalance -
type AccountWrapMockData ¶
type AccountWrapMockData struct {
MockValue int64 `protobuf:"varint,1,opt,name=MockValue,proto3" json:"MockValue,omitempty"`
}
func (*AccountWrapMockData) Descriptor ¶
func (*AccountWrapMockData) Descriptor() ([]byte, []int)
func (*AccountWrapMockData) Equal ¶
func (this *AccountWrapMockData) Equal(that interface{}) bool
func (*AccountWrapMockData) GetMockValue ¶
func (m *AccountWrapMockData) GetMockValue() int64
func (*AccountWrapMockData) GoString ¶
func (this *AccountWrapMockData) GoString() string
func (*AccountWrapMockData) Marshal ¶
func (m *AccountWrapMockData) Marshal() (dAtA []byte, err error)
func (*AccountWrapMockData) MarshalTo ¶
func (m *AccountWrapMockData) MarshalTo(dAtA []byte) (int, error)
func (*AccountWrapMockData) MarshalToSizedBuffer ¶
func (m *AccountWrapMockData) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*AccountWrapMockData) ProtoMessage ¶
func (*AccountWrapMockData) ProtoMessage()
func (*AccountWrapMockData) Reset ¶
func (m *AccountWrapMockData) Reset()
func (*AccountWrapMockData) Size ¶
func (m *AccountWrapMockData) Size() (n int)
func (*AccountWrapMockData) String ¶
func (this *AccountWrapMockData) String() string
func (*AccountWrapMockData) Unmarshal ¶
func (m *AccountWrapMockData) Unmarshal(dAtA []byte) error
func (*AccountWrapMockData) XXX_DiscardUnknown ¶
func (m *AccountWrapMockData) XXX_DiscardUnknown()
func (*AccountWrapMockData) XXX_Marshal ¶
func (m *AccountWrapMockData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
func (*AccountWrapMockData) XXX_Merge ¶
func (m *AccountWrapMockData) XXX_Merge(src proto.Message)
func (*AccountWrapMockData) XXX_Size ¶
func (m *AccountWrapMockData) XXX_Size() int
func (*AccountWrapMockData) XXX_Unmarshal ¶
func (m *AccountWrapMockData) XXX_Unmarshal(b []byte) error
type AccountsFactoryStub ¶
type AccountsFactoryStub struct {
CreateAccountCalled func(address []byte) (state.AccountHandler, error)
}
AccountsFactoryStub -
func (*AccountsFactoryStub) CreateAccount ¶
func (afs *AccountsFactoryStub) CreateAccount(address []byte) (state.AccountHandler, error)
CreateAccount -
func (*AccountsFactoryStub) IsInterfaceNil ¶
func (afs *AccountsFactoryStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type AppStatusHandlerStub ¶
type AppStatusHandlerStub struct { AddUint64Handler func(key string, value uint64) IncrementHandler func(key string) DecrementHandler func(key string) SetUInt64ValueHandler func(key string, value uint64) SetInt64ValueHandler func(key string, value int64) SetStringValueHandler func(key string, value string) CloseHandler func() }
AppStatusHandlerStub is a stub implementation of AppStatusHandler
func (*AppStatusHandlerStub) AddUint64 ¶
func (ashs *AppStatusHandlerStub) AddUint64(key string, value uint64)
AddUint64 will call the handler of the stub for incrementing
func (*AppStatusHandlerStub) Close ¶
func (ashs *AppStatusHandlerStub) Close()
Close will call the handler of the stub for closing
func (*AppStatusHandlerStub) Decrement ¶
func (ashs *AppStatusHandlerStub) Decrement(key string)
Decrement will call the handler of the stub for decrementing
func (*AppStatusHandlerStub) Increment ¶
func (ashs *AppStatusHandlerStub) Increment(key string)
Increment will call the handler of the stub for incrementing
func (*AppStatusHandlerStub) IsInterfaceNil ¶
func (ashs *AppStatusHandlerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*AppStatusHandlerStub) SetInt64Value ¶
func (ashs *AppStatusHandlerStub) SetInt64Value(key string, value int64)
SetInt64Value will call the handler of the stub for setting an int64 value
func (*AppStatusHandlerStub) SetStringValue ¶
func (ashs *AppStatusHandlerStub) SetStringValue(key string, value string)
SetStringValue will call the handler of the stub for setting an string value
func (*AppStatusHandlerStub) SetUInt64Value ¶
func (ashs *AppStatusHandlerStub) SetUInt64Value(key string, value uint64)
SetUInt64Value will call the handler of the stub for setting an uint64 value
type DataTrieTrackerStub ¶
type DataTrieTrackerStub struct { ClearDataCachesCalled func() DirtyDataCalled func() map[string][]byte RetrieveValueCalled func(key []byte) ([]byte, error) SaveKeyValueCalled func(key []byte, value []byte) error SetDataTrieCalled func(tr data.Trie) DataTrieCalled func() data.Trie }
DataTrieTrackerStub -
func (*DataTrieTrackerStub) ClearDataCaches ¶
func (dtts *DataTrieTrackerStub) ClearDataCaches()
ClearDataCaches -
func (*DataTrieTrackerStub) DataTrie ¶
func (dtts *DataTrieTrackerStub) DataTrie() data.Trie
DataTrie -
func (*DataTrieTrackerStub) DirtyData ¶
func (dtts *DataTrieTrackerStub) DirtyData() map[string][]byte
DirtyData -
func (*DataTrieTrackerStub) IsInterfaceNil ¶
func (dtts *DataTrieTrackerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*DataTrieTrackerStub) RetrieveValue ¶
func (dtts *DataTrieTrackerStub) RetrieveValue(key []byte) ([]byte, error)
RetrieveValue -
func (*DataTrieTrackerStub) SaveKeyValue ¶
func (dtts *DataTrieTrackerStub) SaveKeyValue(key []byte, value []byte) error
SaveKeyValue -
func (*DataTrieTrackerStub) SetDataTrie ¶
func (dtts *DataTrieTrackerStub) SetDataTrie(tr data.Trie)
SetDataTrie -
type EvictionWaitingList ¶
type EvictionWaitingList struct { Cache map[string]data.ModifiedHashes CacheSize uint Db storage.Persister Marshalizer marshal.Marshalizer OpMutex sync.RWMutex }
EvictionWaitingList is a structure that caches keys that need to be removed from a certain database. If the cache is full, the keys will be stored in the underlying database. Writing at the same key in cacher and db will overwrite the previous values.
func NewEvictionWaitingList ¶
func NewEvictionWaitingList(size uint, db storage.Persister, marshalizer marshal.Marshalizer) (*EvictionWaitingList, error)
NewEvictionWaitingList creates a new instance of evictionWaitingList
func (*EvictionWaitingList) Evict ¶
func (ewl *EvictionWaitingList) Evict(rootHash []byte) (data.ModifiedHashes, error)
Evict returns and removes from the waiting list all the hashes from the position given by the root hash
func (*EvictionWaitingList) IsInterfaceNil ¶
func (ewl *EvictionWaitingList) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*EvictionWaitingList) Put ¶
func (ewl *EvictionWaitingList) Put(rootHash []byte, hashes data.ModifiedHashes) error
Put stores the given hashes in the eviction waiting list, in the position given by the root hash
func (*EvictionWaitingList) ShouldKeepHash ¶ added in v1.0.114
func (ewl *EvictionWaitingList) ShouldKeepHash(hash string, identifier data.TriePruningIdentifier) (bool, error)
ShouldKeepHash --
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 HasherMock127 ¶
type HasherMock127 struct { }
HasherMock127 -
func (*HasherMock127) IsInterfaceNil ¶
func (hash *HasherMock127) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type KeccakMock ¶
type KeccakMock struct { }
KeccakMock is a sha3-Keccak implementation of the hasher interface.
func (KeccakMock) Compute ¶
func (k KeccakMock) Compute(s string) []byte
Compute takes a string, and returns the sha3-Keccak hash of that string
func (KeccakMock) EmptyHash ¶
func (k KeccakMock) EmptyHash() []byte
EmptyHash returns the sha3-Keccak hash of the empty string
func (*KeccakMock) IsInterfaceNil ¶
func (k *KeccakMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (KeccakMock) Size ¶
func (KeccakMock) Size() int
Size returns the size, in number of bytes, of a sha3-Keccak hash
type 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
func (*MarshalizerMock) Version ¶
func (*MarshalizerMock) Version() string
Version is deprecated and will be removed
type MarshalizerStub ¶ added in v1.0.104
type MarshalizerStub struct { MarshalCalled func(obj interface{}) ([]byte, error) UnmarshalCalled func(obj interface{}, buff []byte) error }
MarshalizerStub -
func (*MarshalizerStub) IsInterfaceNil ¶ added in v1.0.104
func (ms *MarshalizerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*MarshalizerStub) Marshal ¶ added in v1.0.104
func (ms *MarshalizerStub) Marshal(obj interface{}) ([]byte, error)
Marshal -
func (*MarshalizerStub) Unmarshal ¶ added in v1.0.104
func (ms *MarshalizerStub) Unmarshal(obj interface{}, buff []byte) error
Unmarshal -
type MemDbMock ¶
type MemDbMock struct {
// contains filtered or unexported fields
}
MemDbMock represents the memory database storage. It holds a map of key value pairs and a mutex to handle concurrent accesses to the map
func (*MemDbMock) DestroyClosed ¶
DestroyClosed removes the already closed storage medium stored data
func (*MemDbMock) Has ¶
Has returns true if the given key is present in the persistence medium, false otherwise
func (*MemDbMock) IsInterfaceNil ¶
IsInterfaceNil returns true if there is no value under the interface
type MultipleShardsCoordinatorMock ¶
type MultipleShardsCoordinatorMock struct { ComputeIdCalled func(address []byte) uint32 NoShards uint32 CurrentShard uint32 }
MultipleShardsCoordinatorMock -
func NewMultiShardsCoordinatorMock ¶
func NewMultiShardsCoordinatorMock(nrShard uint32) *MultipleShardsCoordinatorMock
NewMultiShardsCoordinatorMock -
func (*MultipleShardsCoordinatorMock) CommunicationIdentifier ¶
func (scm *MultipleShardsCoordinatorMock) CommunicationIdentifier(destShardID uint32) string
CommunicationIdentifier returns the identifier between current shard ID and destination shard ID identifier is generated such as the first shard from identifier is always smaller than the last
func (*MultipleShardsCoordinatorMock) ComputeId ¶
func (scm *MultipleShardsCoordinatorMock) ComputeId(address []byte) uint32
ComputeId -
func (*MultipleShardsCoordinatorMock) IsInterfaceNil ¶
func (scm *MultipleShardsCoordinatorMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*MultipleShardsCoordinatorMock) NumberOfShards ¶
func (scm *MultipleShardsCoordinatorMock) NumberOfShards() uint32
NumberOfShards -
func (*MultipleShardsCoordinatorMock) SameShard ¶
func (scm *MultipleShardsCoordinatorMock) SameShard(_, _ []byte) bool
SameShard -
func (*MultipleShardsCoordinatorMock) SelfId ¶
func (scm *MultipleShardsCoordinatorMock) SelfId() uint32
SelfId -
func (*MultipleShardsCoordinatorMock) SetNoShards ¶
func (scm *MultipleShardsCoordinatorMock) SetNoShards(noShards uint32)
SetNoShards -
func (*MultipleShardsCoordinatorMock) SetSelfId ¶
func (scm *MultipleShardsCoordinatorMock) SetSelfId(_ uint32) error
SetSelfId -
type PathManagerStub ¶
type PathManagerStub struct { PathForEpochCalled func(shardId string, epoch uint32, identifier string) string PathForStaticCalled func(shardId string, identifier string) string }
PathManagerStub -
func (*PathManagerStub) IsInterfaceNil ¶
func (p *PathManagerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*PathManagerStub) PathForEpoch ¶
func (p *PathManagerStub) PathForEpoch(shardId string, epoch uint32, identifier string) string
PathForEpoch -
func (*PathManagerStub) PathForStatic ¶
func (p *PathManagerStub) PathForStatic(shardId string, identifier string) string
PathForStatic -
type ProtobufMarshalizerMock ¶
type ProtobufMarshalizerMock struct { }
ProtobufMarshalizerMock implements marshaling with protobuf
func (*ProtobufMarshalizerMock) IsInterfaceNil ¶
func (x *ProtobufMarshalizerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ProtobufMarshalizerMock) Marshal ¶
func (x *ProtobufMarshalizerMock) Marshal(obj interface{}) ([]byte, error)
Marshal does the actual serialization of an object through protobuf
func (*ProtobufMarshalizerMock) Unmarshal ¶
func (x *ProtobufMarshalizerMock) Unmarshal(obj interface{}, buff []byte) error
Unmarshal does the actual deserialization of an object through protobuf
type PubkeyConverterStub ¶ added in v1.0.104
type PubkeyConverterStub struct { LenCalled func() int DecodeCalled func(humanReadable string) ([]byte, error) EncodeCalled func(pkBytes []byte) string }
PubkeyConverterStub -
func (*PubkeyConverterStub) Decode ¶ added in v1.0.104
func (pcs *PubkeyConverterStub) Decode(humanReadable string) ([]byte, error)
Decode -
func (*PubkeyConverterStub) Encode ¶ added in v1.0.104
func (pcs *PubkeyConverterStub) Encode(pkBytes []byte) string
Encode -
func (*PubkeyConverterStub) IsInterfaceNil ¶ added in v1.0.104
func (pcs *PubkeyConverterStub) IsInterfaceNil() bool
IsInterfaceNil -
type RequestHandlerStub ¶ added in v1.0.102
type RequestHandlerStub struct { RequestShardHeaderCalled func(shardID uint32, hash []byte) RequestMetaHeaderCalled func(hash []byte) RequestMetaHeaderByNonceCalled func(nonce uint64) RequestShardHeaderByNonceCalled func(shardID uint32, nonce uint64) RequestTransactionHandlerCalled func(destShardID uint32, txHashes [][]byte) RequestScrHandlerCalled func(destShardID uint32, txHashes [][]byte) RequestRewardTxHandlerCalled func(destShardID uint32, txHashes [][]byte) RequestMiniBlockHandlerCalled func(destShardID uint32, miniblockHash []byte) RequestMiniBlocksHandlerCalled func(destShardID uint32, miniblocksHashes [][]byte) RequestTrieNodesCalled func(destShardID uint32, hashes [][]byte, topic string) RequestStartOfEpochMetaBlockCalled func(epoch uint32) }
RequestHandlerStub -
func (*RequestHandlerStub) IsInterfaceNil ¶ added in v1.0.102
func (rhs *RequestHandlerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*RequestHandlerStub) RequestInterval ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestInterval() time.Duration
RequestInterval -
func (*RequestHandlerStub) RequestMetaHeader ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestMetaHeader(hash []byte)
RequestMetaHeader -
func (*RequestHandlerStub) RequestMetaHeaderByNonce ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestMetaHeaderByNonce(nonce uint64)
RequestMetaHeaderByNonce -
func (*RequestHandlerStub) RequestMiniBlock ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestMiniBlock(destShardID uint32, miniblockHash []byte)
RequestMiniBlock -
func (*RequestHandlerStub) RequestMiniBlocks ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestMiniBlocks(destShardID uint32, miniblocksHashes [][]byte)
RequestMiniBlocks -
func (*RequestHandlerStub) RequestRewardTransactions ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestRewardTransactions(destShardID uint32, txHashes [][]byte)
RequestRewardTransactions -
func (*RequestHandlerStub) RequestShardHeader ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestShardHeader(shardID uint32, hash []byte)
RequestShardHeader -
func (*RequestHandlerStub) RequestShardHeaderByNonce ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestShardHeaderByNonce(shardID uint32, nonce uint64)
RequestShardHeaderByNonce -
func (*RequestHandlerStub) RequestStartOfEpochMetaBlock ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestStartOfEpochMetaBlock(epoch uint32)
RequestStartOfEpochMetaBlock -
func (*RequestHandlerStub) RequestTransaction ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestTransaction(destShardID uint32, txHashes [][]byte)
RequestTransaction -
func (*RequestHandlerStub) RequestTrieNodes ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestTrieNodes(destShardID uint32, hashes [][]byte, topic string)
RequestTrieNodes -
func (*RequestHandlerStub) RequestUnsignedTransactions ¶ added in v1.0.102
func (rhs *RequestHandlerStub) RequestUnsignedTransactions(destShardID uint32, txHashes [][]byte)
RequestUnsignedTransactions -
func (*RequestHandlerStub) SetEpoch ¶ added in v1.0.102
func (rhs *RequestHandlerStub) SetEpoch(_ uint32)
SetEpoch -
type ShardCoordinatorMock ¶
ShardCoordinatorMock -
func (ShardCoordinatorMock) CommunicationIdentifier ¶
func (scm ShardCoordinatorMock) CommunicationIdentifier(destShardID uint32) string
CommunicationIdentifier -
func (ShardCoordinatorMock) ComputeId ¶
func (scm ShardCoordinatorMock) ComputeId(_ []byte) uint32
ComputeId -
func (*ShardCoordinatorMock) IsInterfaceNil ¶
func (scm *ShardCoordinatorMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (ShardCoordinatorMock) NumberOfShards ¶
func (scm ShardCoordinatorMock) NumberOfShards() uint32
NumberOfShards -
func (ShardCoordinatorMock) SameShard ¶
func (scm ShardCoordinatorMock) SameShard(_, _ []byte) bool
SameShard -
func (ShardCoordinatorMock) SetSelfId ¶
func (scm ShardCoordinatorMock) SetSelfId(_ uint32) error
SetSelfId -
type StorageManagerStub ¶ added in v1.0.129
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 ¶ added in v1.0.129
func (sms *StorageManagerStub) CancelPrune([]byte, data.TriePruningIdentifier)
CancelPrune --
func (*StorageManagerStub) Database ¶ added in v1.0.129
func (sms *StorageManagerStub) Database() data.DBWriteCacher
Database --
func (*StorageManagerStub) EnterSnapshotMode ¶ added in v1.0.129
func (sms *StorageManagerStub) EnterSnapshotMode()
EnterSnapshotMode --
func (*StorageManagerStub) ExitSnapshotMode ¶ added in v1.0.129
func (sms *StorageManagerStub) ExitSnapshotMode()
ExitSnapshotMode --
func (*StorageManagerStub) GetSnapshotDbBatchDelay ¶ added in v1.0.149
func (sms *StorageManagerStub) GetSnapshotDbBatchDelay() int
GetSnapshotDbBatchDelay -
func (*StorageManagerStub) GetSnapshotThatContainsHash ¶ added in v1.0.129
func (sms *StorageManagerStub) GetSnapshotThatContainsHash(d []byte) data.SnapshotDbHandler
GetSnapshotThatContainsHash --
func (*StorageManagerStub) IsInterfaceNil ¶ added in v1.0.129
func (sms *StorageManagerStub) IsInterfaceNil() bool
IsInterfaceNil --
func (*StorageManagerStub) IsPruningEnabled ¶ added in v1.0.129
func (sms *StorageManagerStub) IsPruningEnabled() bool
IsPruningEnabled --
func (*StorageManagerStub) MarkForEviction ¶ added in v1.0.129
func (sms *StorageManagerStub) MarkForEviction(d []byte, m data.ModifiedHashes) error
MarkForEviction --
func (*StorageManagerStub) Prune ¶ added in v1.0.129
func (sms *StorageManagerStub) Prune([]byte, data.TriePruningIdentifier)
Prune --
func (*StorageManagerStub) SetCheckpoint ¶ added in v1.0.129
func (sms *StorageManagerStub) SetCheckpoint([]byte)
SetCheckpoint --
func (*StorageManagerStub) TakeSnapshot ¶ added in v1.0.129
func (sms *StorageManagerStub) TakeSnapshot([]byte)
TakeSnapshot --
type StorerStub ¶
type StorerStub struct { PutCalled func(key, data []byte) error PutInEpochCalled func(key, data []byte) error GetCalled func(key []byte) ([]byte, error) GetFromEpochCalled func(key []byte, epoch uint32) ([]byte, error) HasCalled func(key []byte) error HasInEpochCalled func(key []byte, epoch uint32) error SearchFirstCalled func(key []byte) ([]byte, error) RemoveCalled func(key []byte) error ClearCacheCalled func() CloseCalled func() error DestroyUnitCalled func() error RangeKeysCalled func(handler func(key []byte, val []byte) bool) GetBulkFromEpochCalled func(keys [][]byte, epoch uint32) (map[string][]byte, error) }
StorerStub -
func (*StorerStub) GetBulkFromEpoch ¶ added in v1.0.147
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) PutInEpoch ¶ added in v1.1.1
func (ss *StorerStub) PutInEpoch(key, data []byte, epoch uint32) error
PutInEpoch -
func (*StorerStub) RangeKeys ¶ added in v1.0.138
func (ss *StorerStub) RangeKeys(handler func(key []byte, val []byte) bool)
RangeKeys -
func (*StorerStub) SearchFirst ¶
func (ss *StorerStub) SearchFirst(key []byte) ([]byte, error)
SearchFirst -
type TrieNodesResolverStub ¶
type TrieNodesResolverStub struct { RequestDataFromHashCalled func(hash []byte) error ProcessReceivedMessageCalled func(message p2p.MessageP2P) error }
TrieNodesResolverStub -
func (*TrieNodesResolverStub) IsInterfaceNil ¶
func (tnrs *TrieNodesResolverStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*TrieNodesResolverStub) ProcessReceivedMessage ¶
func (tnrs *TrieNodesResolverStub) ProcessReceivedMessage(message p2p.MessageP2P, _ core.PeerID) error
ProcessReceivedMessage -
func (*TrieNodesResolverStub) RequestDataFromHash ¶
func (tnrs *TrieNodesResolverStub) RequestDataFromHash(hash []byte, _ uint32) error
RequestDataFromHash -
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) TakeSnapshotCalled func(rootHash []byte) SetCheckpointCalled func(rootHash []byte) GetSerializedNodesCalled func([]byte, uint64) ([][]byte, uint64, error) DatabaseCalled func() data.DBWriteCacher GetAllLeavesCalled func() (map[string][]byte, error) GetAllLeavesOnChannelCalled func() chan core.KeyValueHolder GetAllHashesCalled func() ([][]byte, error) IsPruningEnabledCalled func() bool ClosePersisterCalled func() 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) EnterSnapshotMode ¶ added in v1.0.102
func (ts *TrieStub) EnterSnapshotMode()
EnterSnapshotMode -
func (*TrieStub) ExitSnapshotMode ¶ added in v1.0.102
func (ts *TrieStub) ExitSnapshotMode()
ExitSnapshotMode -
func (*TrieStub) GetAllHashes ¶ added in v1.0.137
GetAllHashes -
func (*TrieStub) GetAllLeaves ¶
GetAllLeaves -
func (*TrieStub) GetAllLeavesOnChannel ¶ added in v1.0.137
func (ts *TrieStub) GetAllLeavesOnChannel() chan core.KeyValueHolder
GetAllLeavesOnChannel -
func (*TrieStub) GetDirtyHashes ¶ added in v1.0.111
func (ts *TrieStub) GetDirtyHashes() (data.ModifiedHashes, error)
GetDirtyHashes -
func (*TrieStub) GetSerializedNodes ¶
GetSerializedNodes -
func (*TrieStub) GetSnapshotDbBatchDelay ¶ added in v1.0.149
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 ¶ added in v1.0.111
func (ts *TrieStub) SetNewHashes(_ data.ModifiedHashes)
SetNewHashes -
type UnsignedTxHandlerMock ¶
type UnsignedTxHandlerMock struct { CleanProcessedUtxsCalled func() ProcessTransactionFeeCalled func(cost *big.Int, hash []byte) CreateAllUTxsCalled func() []data.TransactionHandler VerifyCreatedUTxsCalled func() error AddTxFeeFromBlockCalled func(tx data.TransactionHandler) }
UnsignedTxHandlerMock -
func (*UnsignedTxHandlerMock) AddRewardTxFromBlock ¶
func (ut *UnsignedTxHandlerMock) AddRewardTxFromBlock(tx data.TransactionHandler)
AddRewardTxFromBlock -
func (*UnsignedTxHandlerMock) CleanProcessedUTxs ¶
func (ut *UnsignedTxHandlerMock) CleanProcessedUTxs()
CleanProcessedUTxs -
func (*UnsignedTxHandlerMock) CreateAllUTxs ¶
func (ut *UnsignedTxHandlerMock) CreateAllUTxs() []data.TransactionHandler
CreateAllUTxs -
func (*UnsignedTxHandlerMock) ProcessTransactionFee ¶
func (ut *UnsignedTxHandlerMock) ProcessTransactionFee(cost *big.Int, hash []byte)
ProcessTransactionFee -
func (*UnsignedTxHandlerMock) VerifyCreatedUTxs ¶
func (ut *UnsignedTxHandlerMock) VerifyCreatedUTxs() error
VerifyCreatedUTxs -
type UpdaterStub ¶
UpdaterStub -
func (*UpdaterStub) IsInterfaceNil ¶
func (updater *UpdaterStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
Source Files ¶
- accountFactoryStub.go
- accountWrapperMock.go
- accountWrapperMock.pb.go
- appStatusHandlerStub.go
- dataTrieTrackerStub.go
- evictionWaitingListMock.go
- hasherMock.go
- hasherMock127.go
- keccakMock.go
- marshalizerMock.go
- marshalizerStub.go
- memDbMock.go
- multipleShardsCoordinatorMock.go
- pathManagerStub.go
- protobufMock.go
- pubkeyConverterStub.go
- requestHandlerStub.go
- shardCoordinatorMock.go
- storageManagerStub.go
- storerStub.go
- trieNodesResolverStub.go
- trieStub.go
- unsignedTxHandlerMock.go
- updaterStub.go