testscommon

package
v1.999.0 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Nov 17, 2022 License: GPL-3.0 Imports: 45 Imported by: 0

Documentation

Index

Constants

View Source
const HashSize = 32

HashSize holds the size of a typical hash used by the protocol

Variables

View Source
var (
	// TestAddressAlice is a test address
	TestAddressAlice = "erd1qyu5wthldzr8wx5c9ucg8kjagg0jfs53s8nr3zpz3hypefsdd8ssycr6th"
	// TestPubKeyAlice is a test pubkey
	TestPubKeyAlice, _ = RealWorldBech32PubkeyConverter.Decode(TestAddressAlice)
	// TestPubKeyHexAlice is a test pubkey
	TestPubKeyHexAlice = hex.EncodeToString(TestPubKeyAlice)

	// TestAddressBob is a test address
	TestAddressBob = "erd1spyavw0956vq68xj8y4tenjpq2wd5a9p2c6j8gsz7ztyrnpxrruqzu66jx"
	// TestPubKeyBob is a test pubkey
	TestPubKeyBob, _ = RealWorldBech32PubkeyConverter.Decode(TestAddressBob)
	// TestPubKeyHexBob is a test pubkey
	TestPubKeyHexBob = hex.EncodeToString(TestPubKeyBob)
)
View Source
var ErrMockMarshalizer = errors.New("MarshalizerMock generic error")

ErrMockMarshalizer -

View Source
var RealWorldBech32PubkeyConverter, _ = pubkeyConverter.NewBech32PubkeyConverter(32, logger.GetOrCreate("testscommon"))

RealWorldBech32PubkeyConverter is a bech32 converter, to be used in tests

Functions

func AddTimestampSuffix

func AddTimestampSuffix(tag string) string

AddTimestampSuffix -

func CreateGinContextWithRawQuery

func CreateGinContextWithRawQuery(rawQuery string) *gin.Context

CreateGinContextWithRawQuery creates a test gin context

func CreateMemUnit

func CreateMemUnit() storage.Storer

CreateMemUnit creates a new in-memory storage unit

func GetEconomicsConfig

func GetEconomicsConfig() config.EconomicsConfig

GetEconomicsConfig returns the common configuration used for testing

func GetGeneralConfig

func GetGeneralConfig() config.Config

GetGeneralConfig returns the common configuration used for testing

func NewNonceHashConverterMock

func NewNonceHashConverterMock() *nonceHashConverterMock

NewNonceHashConverterMock -

func NewTimeoutHandlerMock

func NewTimeoutHandlerMock(timeout time.Duration) *timeoutHandlerMock

NewTimeoutHandlerMock -

Types

type AlarmSchedulerStub

type AlarmSchedulerStub struct {
	AddCalled    func(func(alarmID string), time.Duration, string)
	CancelCalled func(string)
	CloseCalled  func()
	ResetCalled  func(string)
}

AlarmSchedulerStub -

func (*AlarmSchedulerStub) Add

func (a *AlarmSchedulerStub) Add(callback func(alarmID string), duration time.Duration, alarmID string)

Add -

func (*AlarmSchedulerStub) Cancel

func (a *AlarmSchedulerStub) Cancel(alarmID string)

Cancel -

func (*AlarmSchedulerStub) Close

func (a *AlarmSchedulerStub) Close()

Close -

func (*AlarmSchedulerStub) IsInterfaceNil

func (a *AlarmSchedulerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*AlarmSchedulerStub) Reset

func (a *AlarmSchedulerStub) Reset(alarmID string)

Reset -

type BalanceComputationStub

type BalanceComputationStub struct {
	InitCalled                    func()
	SetBalanceToAddressCalled     func(address []byte, value *big.Int)
	AddBalanceToAddressCalled     func(address []byte, value *big.Int) bool
	SubBalanceFromAddressCalled   func(address []byte, value *big.Int) bool
	IsAddressSetCalled            func(address []byte) bool
	AddressHasEnoughBalanceCalled func(address []byte, value *big.Int) bool
}

BalanceComputationStub -

func (*BalanceComputationStub) AddBalanceToAddress

func (bcs *BalanceComputationStub) AddBalanceToAddress(address []byte, value *big.Int) bool

AddBalanceToAddress -

func (*BalanceComputationStub) AddressHasEnoughBalance

func (bcs *BalanceComputationStub) AddressHasEnoughBalance(address []byte, value *big.Int) bool

AddressHasEnoughBalance -

func (*BalanceComputationStub) Init

func (bcs *BalanceComputationStub) Init()

Init -

func (*BalanceComputationStub) IsAddressSet

func (bcs *BalanceComputationStub) IsAddressSet(address []byte) bool

IsAddressSet -

func (*BalanceComputationStub) IsInterfaceNil

func (bcs *BalanceComputationStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*BalanceComputationStub) SetBalanceToAddress

func (bcs *BalanceComputationStub) SetBalanceToAddress(address []byte, value *big.Int)

SetBalanceToAddress -

func (*BalanceComputationStub) SubBalanceFromAddress

func (bcs *BalanceComputationStub) SubBalanceFromAddress(address []byte, value *big.Int) bool

SubBalanceFromAddress -

type BlockChainHookStub

type BlockChainHookStub struct {
	NewAddressCalled                     func(creatorAddress []byte, creatorNonce uint64, vmType []byte) ([]byte, error)
	GetStorageDataCalled                 func(accountsAddress []byte, index []byte) ([]byte, error)
	GetBlockHashCalled                   func(nonce uint64) ([]byte, error)
	LastNonceCalled                      func() uint64
	LastRoundCalled                      func() uint64
	LastTimeStampCalled                  func() uint64
	LastRandomSeedCalled                 func() []byte
	LastEpochCalled                      func() uint32
	GetStateRootHashCalled               func() []byte
	CurrentNonceCalled                   func() uint64
	CurrentRoundCalled                   func() uint64
	CurrentTimeStampCalled               func() uint64
	CurrentRandomSeedCalled              func() []byte
	CurrentEpochCalled                   func() uint32
	ProcessBuiltInFunctionCalled         func(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error)
	GetBuiltinFunctionNamesCalled        func() vmcommon.FunctionNames
	GetBuiltinFunctionsContainerCalled   func() vmcommon.BuiltInFunctionContainer
	GetAllStateCalled                    func(address []byte) (map[string][]byte, error)
	GetUserAccountCalled                 func(address []byte) (vmcommon.UserAccountHandler, error)
	GetShardOfAddressCalled              func(address []byte) uint32
	IsSmartContractCalled                func(address []byte) bool
	IsPayableCalled                      func(sndAddress []byte, recvAddress []byte) (bool, error)
	GetCompiledCodeCalled                func(codeHash []byte) (bool, []byte)
	SaveCompiledCodeCalled               func(codeHash []byte, code []byte)
	ClearCompiledCodesCalled             func()
	GetCodeCalled                        func(account vmcommon.UserAccountHandler) []byte
	GetESDTTokenCalled                   func(address []byte, tokenID []byte, nonce uint64) (*esdt.ESDigitalToken, error)
	NumberOfShardsCalled                 func() uint32
	GetSnapshotCalled                    func() int
	RevertToSnapshotCalled               func(snapshot int) error
	SetCurrentHeaderCalled               func(hdr data.HeaderHandler)
	DeleteCompiledCodeCalled             func(codeHash []byte)
	SaveNFTMetaDataToSystemAccountCalled func(tx data.TransactionHandler) error
	CloseCalled                          func() error
	FilterCodeMetadataForUpgradeCalled   func(input []byte) ([]byte, error)
	ApplyFiltersOnCodeMetadataCalled     func(codeMetadata vmcommon.CodeMetadata) vmcommon.CodeMetadata
}

BlockChainHookStub -

func (*BlockChainHookStub) ApplyFiltersOnCodeMetadata

func (stub *BlockChainHookStub) ApplyFiltersOnCodeMetadata(codeMetadata vmcommon.CodeMetadata) vmcommon.CodeMetadata

ApplyFiltersOnCodeMetadata -

func (*BlockChainHookStub) ClearCompiledCodes

func (stub *BlockChainHookStub) ClearCompiledCodes()

ClearCompiledCodes -

func (*BlockChainHookStub) Close

func (stub *BlockChainHookStub) Close() error

Close -

func (*BlockChainHookStub) CurrentEpoch

func (stub *BlockChainHookStub) CurrentEpoch() uint32

CurrentEpoch -

func (*BlockChainHookStub) CurrentNonce

func (stub *BlockChainHookStub) CurrentNonce() uint64

CurrentNonce -

func (*BlockChainHookStub) CurrentRandomSeed

func (stub *BlockChainHookStub) CurrentRandomSeed() []byte

CurrentRandomSeed -

func (*BlockChainHookStub) CurrentRound

func (stub *BlockChainHookStub) CurrentRound() uint64

CurrentRound -

func (*BlockChainHookStub) CurrentTimeStamp

func (stub *BlockChainHookStub) CurrentTimeStamp() uint64

CurrentTimeStamp -

func (*BlockChainHookStub) DeleteCompiledCode

func (stub *BlockChainHookStub) DeleteCompiledCode(codeHash []byte)

DeleteCompiledCode -

func (*BlockChainHookStub) FilterCodeMetadataForUpgrade

func (stub *BlockChainHookStub) FilterCodeMetadataForUpgrade(input []byte) ([]byte, error)

FilterCodeMetadataForUpgrade -

func (*BlockChainHookStub) GetAllState

func (stub *BlockChainHookStub) GetAllState(address []byte) (map[string][]byte, error)

GetAllState -

func (*BlockChainHookStub) GetBlockhash

func (stub *BlockChainHookStub) GetBlockhash(nonce uint64) ([]byte, error)

GetBlockhash -

func (*BlockChainHookStub) GetBuiltinFunctionNames

func (stub *BlockChainHookStub) GetBuiltinFunctionNames() vmcommon.FunctionNames

GetBuiltinFunctionNames -

func (*BlockChainHookStub) GetBuiltinFunctionsContainer

func (stub *BlockChainHookStub) GetBuiltinFunctionsContainer() vmcommon.BuiltInFunctionContainer

GetBuiltinFunctionsContainer -

func (*BlockChainHookStub) GetCode

func (stub *BlockChainHookStub) GetCode(account vmcommon.UserAccountHandler) []byte

GetCode -

func (*BlockChainHookStub) GetCompiledCode

func (stub *BlockChainHookStub) GetCompiledCode(codeHash []byte) (bool, []byte)

GetCompiledCode -

func (*BlockChainHookStub) GetESDTToken

func (stub *BlockChainHookStub) GetESDTToken(address []byte, tokenID []byte, nonce uint64) (*esdt.ESDigitalToken, error)

GetESDTToken -

func (*BlockChainHookStub) GetShardOfAddress

func (stub *BlockChainHookStub) GetShardOfAddress(address []byte) uint32

GetShardOfAddress -

func (*BlockChainHookStub) GetSnapshot

func (stub *BlockChainHookStub) GetSnapshot() int

GetSnapshot -

func (*BlockChainHookStub) GetStateRootHash

func (stub *BlockChainHookStub) GetStateRootHash() []byte

GetStateRootHash -

func (*BlockChainHookStub) GetStorageData

func (stub *BlockChainHookStub) GetStorageData(accountAddress []byte, index []byte) ([]byte, error)

GetStorageData -

func (*BlockChainHookStub) GetUserAccount

func (stub *BlockChainHookStub) GetUserAccount(address []byte) (vmcommon.UserAccountHandler, error)

GetUserAccount -

func (*BlockChainHookStub) IsInterfaceNil

func (stub *BlockChainHookStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*BlockChainHookStub) IsLimitedTransfer

func (stub *BlockChainHookStub) IsLimitedTransfer(_ []byte) bool

IsLimitedTransfer -

func (*BlockChainHookStub) IsPaused

func (stub *BlockChainHookStub) IsPaused(_ []byte) bool

IsPaused -

func (*BlockChainHookStub) IsPayable

func (stub *BlockChainHookStub) IsPayable(sndAddress []byte, recvAddress []byte) (bool, error)

IsPayable -

func (*BlockChainHookStub) IsSmartContract

func (stub *BlockChainHookStub) IsSmartContract(address []byte) bool

IsSmartContract -

func (*BlockChainHookStub) LastEpoch

func (stub *BlockChainHookStub) LastEpoch() uint32

LastEpoch -

func (*BlockChainHookStub) LastNonce

func (stub *BlockChainHookStub) LastNonce() uint64

LastNonce -

func (*BlockChainHookStub) LastRandomSeed

func (stub *BlockChainHookStub) LastRandomSeed() []byte

LastRandomSeed -

func (*BlockChainHookStub) LastRound

func (stub *BlockChainHookStub) LastRound() uint64

LastRound -

func (*BlockChainHookStub) LastTimeStamp

func (stub *BlockChainHookStub) LastTimeStamp() uint64

LastTimeStamp -

func (*BlockChainHookStub) NewAddress

func (stub *BlockChainHookStub) NewAddress(creatorAddress []byte, creatorNonce uint64, vmType []byte) ([]byte, error)

NewAddress -

func (*BlockChainHookStub) NumberOfShards

func (stub *BlockChainHookStub) NumberOfShards() uint32

NumberOfShards -

func (*BlockChainHookStub) ProcessBuiltInFunction

func (stub *BlockChainHookStub) ProcessBuiltInFunction(input *vmcommon.ContractCallInput) (*vmcommon.VMOutput, error)

ProcessBuiltInFunction -

func (*BlockChainHookStub) RevertToSnapshot

func (stub *BlockChainHookStub) RevertToSnapshot(snapshot int) error

RevertToSnapshot -

func (*BlockChainHookStub) SaveCompiledCode

func (stub *BlockChainHookStub) SaveCompiledCode(codeHash []byte, code []byte)

SaveCompiledCode -

func (*BlockChainHookStub) SaveNFTMetaDataToSystemAccount

func (stub *BlockChainHookStub) SaveNFTMetaDataToSystemAccount(tx data.TransactionHandler) error

SaveNFTMetaDataToSystemAccount -

func (*BlockChainHookStub) SetCurrentHeader

func (stub *BlockChainHookStub) SetCurrentHeader(hdr data.HeaderHandler)

SetCurrentHeader -

type BlockInfoProviderStub

type BlockInfoProviderStub struct {
	GetBlockInfoCalled func() common.BlockInfo
}

BlockInfoProviderStub -

func (*BlockInfoProviderStub) GetBlockInfo

func (stub *BlockInfoProviderStub) GetBlockInfo() common.BlockInfo

GetBlockInfo -

func (*BlockInfoProviderStub) IsInterfaceNil

func (stub *BlockInfoProviderStub) IsInterfaceNil() bool

IsInterfaceNil -

type BlockSizeComputationStub

type BlockSizeComputationStub struct {
	InitCalled                                 func()
	AddNumMiniBlocksCalled                     func(int)
	AddNumTxsCalled                            func(int)
	IsMaxBlockSizeReachedCalled                func(int, int) bool
	IsMaxBlockSizeWithoutThrottleReachedCalled func(int, int) bool
}

BlockSizeComputationStub -

func (*BlockSizeComputationStub) AddNumMiniBlocks

func (bscs *BlockSizeComputationStub) AddNumMiniBlocks(numMiniBlocks int)

AddNumMiniBlocks -

func (*BlockSizeComputationStub) AddNumTxs

func (bscs *BlockSizeComputationStub) AddNumTxs(numTxs int)

AddNumTxs -

func (*BlockSizeComputationStub) Init

func (bscs *BlockSizeComputationStub) Init()

Init -

func (*BlockSizeComputationStub) IsInterfaceNil

func (bscs *BlockSizeComputationStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*BlockSizeComputationStub) IsMaxBlockSizeReached

func (bscs *BlockSizeComputationStub) IsMaxBlockSizeReached(numNewMiniBlocks int, numNewTxs int) bool

IsMaxBlockSizeReached -

func (*BlockSizeComputationStub) IsMaxBlockSizeWithoutThrottleReached

func (bscs *BlockSizeComputationStub) IsMaxBlockSizeWithoutThrottleReached(numNewMiniBlocks int, numNewTxs int) bool

IsMaxBlockSizeWithoutThrottleReached -

type BuiltInCostHandlerStub

type BuiltInCostHandlerStub struct {
	ComputeBuiltInCostCalled func(tx data.TransactionWithFeeHandler) uint64
	IsBuiltInFuncCallCalled  func(tx data.TransactionWithFeeHandler) bool
}

BuiltInCostHandlerStub -

func (*BuiltInCostHandlerStub) ComputeBuiltInCost

func (stub *BuiltInCostHandlerStub) ComputeBuiltInCost(tx data.TransactionWithFeeHandler) uint64

ComputeBuiltInCost -

func (*BuiltInCostHandlerStub) IsBuiltInFuncCall

func (stub *BuiltInCostHandlerStub) IsBuiltInFuncCall(tx data.TransactionWithFeeHandler) bool

IsBuiltInFuncCall -

func (*BuiltInCostHandlerStub) IsInterfaceNil

func (stub *BuiltInCostHandlerStub) IsInterfaceNil() bool

IsInterfaceNil returns true if underlying object is nil

type CacherMock

type CacherMock struct {
	// contains filtered or unexported fields
}

CacherMock -

func NewCacherMock

func NewCacherMock() *CacherMock

NewCacherMock -

func (*CacherMock) Clear

func (cacher *CacherMock) Clear()

Clear -

func (*CacherMock) Close

func (cacher *CacherMock) Close() error

Close -

func (*CacherMock) Get

func (cacher *CacherMock) Get(key []byte) (value interface{}, ok bool)

Get -

func (*CacherMock) Has

func (cacher *CacherMock) Has(key []byte) bool

Has -

func (*CacherMock) HasOrAdd

func (cacher *CacherMock) HasOrAdd(key []byte, value interface{}, _ int) (has, added bool)

HasOrAdd -

func (*CacherMock) IsInterfaceNil

func (cacher *CacherMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*CacherMock) Keys

func (cacher *CacherMock) Keys() [][]byte

Keys -

func (*CacherMock) Len

func (cacher *CacherMock) Len() int

Len -

func (*CacherMock) MaxSize

func (cacher *CacherMock) MaxSize() int

MaxSize -

func (*CacherMock) Peek

func (cacher *CacherMock) Peek(key []byte) (value interface{}, ok bool)

Peek -

func (*CacherMock) Put

func (cacher *CacherMock) Put(key []byte, value interface{}, _ int) (evicted bool)

Put -

func (*CacherMock) RegisterHandler

func (cacher *CacherMock) RegisterHandler(handler func(key []byte, value interface{}), _ string)

RegisterHandler -

func (*CacherMock) Remove

func (cacher *CacherMock) Remove(key []byte)

Remove -

func (*CacherMock) SizeInBytesContained

func (cacher *CacherMock) SizeInBytesContained() uint64

SizeInBytesContained -

func (*CacherMock) UnRegisterHandler

func (cacher *CacherMock) UnRegisterHandler(string)

UnRegisterHandler -

type CacherStub

type CacherStub struct {
	ClearCalled             func()
	PutCalled               func(key []byte, value interface{}, sizeInBytes int) (evicted bool)
	GetCalled               func(key []byte) (value interface{}, ok bool)
	HasCalled               func(key []byte) bool
	PeekCalled              func(key []byte) (value interface{}, ok bool)
	HasOrAddCalled          func(key []byte, value interface{}, sizeInBytes int) (has, added bool)
	RemoveCalled            func(key []byte)
	RemoveOldestCalled      func()
	KeysCalled              func() [][]byte
	LenCalled               func() int
	MaxSizeCalled           func() int
	RegisterHandlerCalled   func(func(key []byte, value interface{}))
	UnRegisterHandlerCalled func(id string)
	CloseCalled             func() error
}

CacherStub -

func NewCacherStub

func NewCacherStub() *CacherStub

NewCacherStub -

func (*CacherStub) Clear

func (cacher *CacherStub) Clear()

Clear -

func (*CacherStub) Close

func (cacher *CacherStub) Close() error

Close -

func (*CacherStub) Get

func (cacher *CacherStub) Get(key []byte) (value interface{}, ok bool)

Get -

func (*CacherStub) Has

func (cacher *CacherStub) Has(key []byte) bool

Has -

func (*CacherStub) HasOrAdd

func (cacher *CacherStub) HasOrAdd(key []byte, value interface{}, sizeInBytes int) (has, added bool)

HasOrAdd -

func (*CacherStub) IsInterfaceNil

func (cacher *CacherStub) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*CacherStub) Keys

func (cacher *CacherStub) Keys() [][]byte

Keys -

func (*CacherStub) Len

func (cacher *CacherStub) Len() int

Len -

func (*CacherStub) MaxSize

func (cacher *CacherStub) MaxSize() int

MaxSize -

func (*CacherStub) Peek

func (cacher *CacherStub) Peek(key []byte) (value interface{}, ok bool)

Peek -

func (*CacherStub) Put

func (cacher *CacherStub) Put(key []byte, value interface{}, sizeInBytes int) (evicted bool)

Put -

func (*CacherStub) RegisterHandler

func (cacher *CacherStub) RegisterHandler(handler func(key []byte, value interface{}), _ string)

RegisterHandler -

func (*CacherStub) Remove

func (cacher *CacherStub) Remove(key []byte)

Remove -

func (*CacherStub) SizeInBytesContained

func (cacher *CacherStub) SizeInBytesContained() uint64

SizeInBytesContained -

func (*CacherStub) UnRegisterHandler

func (cacher *CacherStub) UnRegisterHandler(id string)

UnRegisterHandler -

type ChainHandlerMock

type ChainHandlerMock struct {
	// contains filtered or unexported fields
}

ChainHandlerMock -

func (*ChainHandlerMock) GetCurrentBlockHeader

func (mock *ChainHandlerMock) GetCurrentBlockHeader() data.HeaderHandler

GetCurrentBlockHeader -

func (*ChainHandlerMock) GetCurrentBlockHeaderHash

func (mock *ChainHandlerMock) GetCurrentBlockHeaderHash() []byte

GetCurrentBlockHeaderHash -

func (*ChainHandlerMock) GetCurrentBlockRootHash

func (mock *ChainHandlerMock) GetCurrentBlockRootHash() []byte

GetCurrentBlockRootHash -

func (*ChainHandlerMock) GetFinalBlockInfo

func (mock *ChainHandlerMock) GetFinalBlockInfo() (nonce uint64, blockHash []byte, rootHash []byte)

GetFinalBlockInfo -

func (*ChainHandlerMock) GetGenesisHeader

func (mock *ChainHandlerMock) GetGenesisHeader() data.HeaderHandler

GetGenesisHeader -

func (*ChainHandlerMock) GetGenesisHeaderHash

func (mock *ChainHandlerMock) GetGenesisHeaderHash() []byte

GetGenesisHeaderHash -

func (*ChainHandlerMock) IsInterfaceNil

func (mock *ChainHandlerMock) IsInterfaceNil() bool

IsInterfaceNil -

func (*ChainHandlerMock) SetCurrentBlockHeaderAndRootHash

func (mock *ChainHandlerMock) SetCurrentBlockHeaderAndRootHash(header data.HeaderHandler, rootHash []byte) error

SetCurrentBlockHeaderAndRootHash -

func (*ChainHandlerMock) SetCurrentBlockHeaderHash

func (mock *ChainHandlerMock) SetCurrentBlockHeaderHash(hash []byte)

SetCurrentBlockHeaderHash -

func (*ChainHandlerMock) SetFinalBlockInfo

func (mock *ChainHandlerMock) SetFinalBlockInfo(nonce uint64, headerHash []byte, rootHash []byte)

SetFinalBlockInfoCalled -

func (*ChainHandlerMock) SetGenesisHeader

func (mock *ChainHandlerMock) SetGenesisHeader(genesisBlock data.HeaderHandler) error

SetGenesisHeader -

func (*ChainHandlerMock) SetGenesisHeaderHash

func (mock *ChainHandlerMock) SetGenesisHeaderHash(hash []byte)

SetGenesisHeaderHash -

type ChainHandlerStub

type ChainHandlerStub struct {
	GetGenesisHeaderCalled                 func() data.HeaderHandler
	SetGenesisHeaderCalled                 func(handler data.HeaderHandler) error
	GetGenesisHeaderHashCalled             func() []byte
	SetGenesisHeaderHashCalled             func([]byte)
	GetCurrentBlockHeaderCalled            func() data.HeaderHandler
	SetCurrentBlockHeaderAndRootHashCalled func(header data.HeaderHandler, rootHash []byte) error
	GetCurrentBlockHeaderHashCalled        func() []byte
	SetCurrentBlockHeaderHashCalled        func([]byte)
	GetCurrentBlockRootHashCalled          func() []byte
	SetFinalBlockInfoCalled                func(nonce uint64, headerHash []byte, rootHash []byte)
	GetFinalBlockInfoCalled                func() (nonce uint64, blockHash []byte, rootHash []byte)
}

ChainHandlerStub -

func (*ChainHandlerStub) GetCurrentBlockHeader

func (stub *ChainHandlerStub) GetCurrentBlockHeader() data.HeaderHandler

GetCurrentBlockHeader -

func (*ChainHandlerStub) GetCurrentBlockHeaderHash

func (stub *ChainHandlerStub) GetCurrentBlockHeaderHash() []byte

GetCurrentBlockHeaderHash -

func (*ChainHandlerStub) GetCurrentBlockRootHash

func (stub *ChainHandlerStub) GetCurrentBlockRootHash() []byte

GetCurrentBlockRootHash -

func (*ChainHandlerStub) GetFinalBlockInfo

func (stub *ChainHandlerStub) GetFinalBlockInfo() (nonce uint64, blockHash []byte, rootHash []byte)

GetFinalBlockInfo -

func (*ChainHandlerStub) GetGenesisHeader

func (stub *ChainHandlerStub) GetGenesisHeader() data.HeaderHandler

GetGenesisHeader -

func (*ChainHandlerStub) GetGenesisHeaderHash

func (stub *ChainHandlerStub) GetGenesisHeaderHash() []byte

GetGenesisHeaderHash -

func (*ChainHandlerStub) IsInterfaceNil

func (stub *ChainHandlerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*ChainHandlerStub) SetCurrentBlockHeaderAndRootHash

func (stub *ChainHandlerStub) SetCurrentBlockHeaderAndRootHash(header data.HeaderHandler, rootHash []byte) error

SetCurrentBlockHeaderAndRootHash -

func (*ChainHandlerStub) SetCurrentBlockHeaderHash

func (stub *ChainHandlerStub) SetCurrentBlockHeaderHash(hash []byte)

SetCurrentBlockHeaderHash -

func (*ChainHandlerStub) SetFinalBlockInfo

func (stub *ChainHandlerStub) SetFinalBlockInfo(nonce uint64, headerHash []byte, rootHash []byte)

SetFinalBlockInfoCalled -

func (*ChainHandlerStub) SetGenesisHeader

func (stub *ChainHandlerStub) SetGenesisHeader(genesisBlock data.HeaderHandler) error

SetGenesisHeader -

func (*ChainHandlerStub) SetGenesisHeaderHash

func (stub *ChainHandlerStub) SetGenesisHeaderHash(hash []byte)

SetGenesisHeaderHash -

type CurrentEpochProviderStub

type CurrentEpochProviderStub struct {
	EpochIsActiveInNetworkCalled func(epoch uint32) bool
}

CurrentEpochProviderStub -

func (*CurrentEpochProviderStub) EpochIsActiveInNetwork

func (c *CurrentEpochProviderStub) EpochIsActiveInNetwork(epoch uint32) bool

EpochIsActiveInNetwork -

func (*CurrentEpochProviderStub) IsInterfaceNil

func (c *CurrentEpochProviderStub) IsInterfaceNil() bool

IsInterfaceNil -

type CustomDatabaseRemoverStub

type CustomDatabaseRemoverStub struct {
	ShouldRemoveCalled func(dbIdentifier string, epoch uint32) bool
}

CustomDatabaseRemoverStub -

func (*CustomDatabaseRemoverStub) IsInterfaceNil

func (c *CustomDatabaseRemoverStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*CustomDatabaseRemoverStub) ShouldRemove

func (c *CustomDatabaseRemoverStub) ShouldRemove(dbIdentifier string, epoch uint32) bool

ShouldRemove -

type DataFieldParserStub

type DataFieldParserStub struct {
	ParseCalled func(dataField []byte, sender, receiver []byte) *datafield.ResponseParseData
}

DataFieldParserStub -

func (*DataFieldParserStub) Parse

func (df *DataFieldParserStub) Parse(dataField []byte, sender, receiver []byte) *datafield.ResponseParseData

Parse -

type ESDTGlobalSettingsHandlerStub

type ESDTGlobalSettingsHandlerStub struct {
	IsPausedCalled          func(esdtTokenKey []byte) bool
	IsLimitedTransferCalled func(esdtTokenKey []byte) bool
}

ESDTGlobalSettingsHandlerStub -

func (*ESDTGlobalSettingsHandlerStub) IsInterfaceNil

func (e *ESDTGlobalSettingsHandlerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*ESDTGlobalSettingsHandlerStub) IsLimitedTransfer

func (e *ESDTGlobalSettingsHandlerStub) IsLimitedTransfer(esdtTokenKey []byte) bool

IsLimitedTransfer -

func (*ESDTGlobalSettingsHandlerStub) IsPaused

func (e *ESDTGlobalSettingsHandlerStub) IsPaused(esdtTokenKey []byte) bool

IsPaused -

type EpochStartTriggerStub

type EpochStartTriggerStub struct {
	ForceEpochStartCalled             func(round uint64)
	IsEpochStartCalled                func() bool
	EpochCalled                       func() uint32
	MetaEpochCalled                   func() uint32
	ReceivedHeaderCalled              func(handler data.HeaderHandler)
	UpdateCalled                      func(round uint64, nonce uint64)
	ProcessedCalled                   func(header data.HeaderHandler)
	EpochStartRoundCalled             func() uint64
	EpochFinalityAttestingRoundCalled func() uint64
	EpochStartMetaHdrHashCalled       func() []byte
}

EpochStartTriggerStub -

func (*EpochStartTriggerStub) Close

func (e *EpochStartTriggerStub) Close() error

Close -

func (*EpochStartTriggerStub) Epoch

func (e *EpochStartTriggerStub) Epoch() uint32

Epoch -

func (*EpochStartTriggerStub) EpochFinalityAttestingRound

func (e *EpochStartTriggerStub) EpochFinalityAttestingRound() uint64

EpochFinalityAttestingRound -

func (*EpochStartTriggerStub) EpochStartMetaHdrHash

func (e *EpochStartTriggerStub) EpochStartMetaHdrHash() []byte

EpochStartMetaHdrHash -

func (*EpochStartTriggerStub) EpochStartRound

func (e *EpochStartTriggerStub) EpochStartRound() uint64

EpochStartRound -

func (*EpochStartTriggerStub) ForceEpochStart

func (e *EpochStartTriggerStub) ForceEpochStart(round uint64)

ForceEpochStart -

func (*EpochStartTriggerStub) GetSavedStateKey

func (e *EpochStartTriggerStub) GetSavedStateKey() []byte

GetSavedStateKey -

func (*EpochStartTriggerStub) IsEpochStart

func (e *EpochStartTriggerStub) IsEpochStart() bool

IsEpochStart -

func (*EpochStartTriggerStub) IsInterfaceNil

func (e *EpochStartTriggerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*EpochStartTriggerStub) LoadState

func (e *EpochStartTriggerStub) LoadState(_ []byte) error

LoadState -

func (*EpochStartTriggerStub) MetaEpoch

func (e *EpochStartTriggerStub) MetaEpoch() uint32

MetaEpoch -

func (*EpochStartTriggerStub) NotifyAll

func (e *EpochStartTriggerStub) NotifyAll(_ data.HeaderHandler)

NotifyAll -

func (*EpochStartTriggerStub) RequestEpochStartIfNeeded

func (e *EpochStartTriggerStub) RequestEpochStartIfNeeded(_ data.HeaderHandler)

RequestEpochStartIfNeeded -

func (*EpochStartTriggerStub) Revert

Revert -

func (*EpochStartTriggerStub) RevertStateToBlock

func (e *EpochStartTriggerStub) RevertStateToBlock(_ data.HeaderHandler) error

RevertStateToBlock -

func (*EpochStartTriggerStub) SetAppStatusHandler

func (e *EpochStartTriggerStub) SetAppStatusHandler(_ core.AppStatusHandler) error

SetAppStatusHandler -

func (*EpochStartTriggerStub) SetCurrentEpochStartRound

func (e *EpochStartTriggerStub) SetCurrentEpochStartRound(_ uint64)

SetCurrentEpochStartRound -

func (*EpochStartTriggerStub) SetFinalityAttestingRound

func (e *EpochStartTriggerStub) SetFinalityAttestingRound(_ uint64)

SetFinalityAttestingRound -

func (*EpochStartTriggerStub) SetProcessed

func (e *EpochStartTriggerStub) SetProcessed(header data.HeaderHandler, _ data.BodyHandler)

SetProcessed -

func (*EpochStartTriggerStub) Update

func (e *EpochStartTriggerStub) Update(round uint64, nonce uint64)

Update -

type FallBackHeaderValidatorStub

type FallBackHeaderValidatorStub struct {
	ShouldApplyFallbackValidationCalled func(headerHandler data.HeaderHandler) bool
}

FallBackHeaderValidatorStub -

func (*FallBackHeaderValidatorStub) IsInterfaceNil

func (fhvs *FallBackHeaderValidatorStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*FallBackHeaderValidatorStub) ShouldApplyFallbackValidation

func (fhvs *FallBackHeaderValidatorStub) ShouldApplyFallbackValidation(headerHandler data.HeaderHandler) bool

ShouldApplyFallbackValidation -

type FeeComputerStub

type FeeComputerStub struct {
	ComputeTransactionFeeCalled func(tx *transaction.ApiTransactionResult) *big.Int
}

FeeComputerStub -

func (*FeeComputerStub) ComputeTransactionFee

func (stub *FeeComputerStub) ComputeTransactionFee(tx *transaction.ApiTransactionResult) *big.Int

ComputeTransactionFee -

func (*FeeComputerStub) IsInterfaceNil

func (stub *FeeComputerStub) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

type GasHandlerStub

type GasHandlerStub struct {
	InitCalled                          func()
	ResetCalled                         func(key []byte)
	SetGasProvidedCalled                func(gasProvided uint64, hash []byte)
	SetGasProvidedAsScheduledCalled     func(gasProvided uint64, hash []byte)
	SetGasRefundedCalled                func(gasRefunded uint64, hash []byte)
	SetGasPenalizedCalled               func(gasPenalized uint64, hash []byte)
	GasProvidedCalled                   func(hash []byte) uint64
	GasProvidedAsScheduledCalled        func(hash []byte) uint64
	GasRefundedCalled                   func(hash []byte) uint64
	GasPenalizedCalled                  func(hash []byte) uint64
	TotalGasProvidedCalled              func() uint64
	TotalGasProvidedAsScheduledCalled   func() uint64
	TotalGasProvidedWithScheduledCalled func() uint64
	TotalGasRefundedCalled              func() uint64
	TotalGasPenalizedCalled             func() uint64
	RemoveGasProvidedCalled             func(hashes [][]byte)
	RemoveGasProvidedAsScheduledCalled  func(hashes [][]byte)
	RemoveGasRefundedCalled             func(hashes [][]byte)
	RemoveGasPenalizedCalled            func(hashes [][]byte)
	RestoreGasSinceLastResetCalled      func(key []byte)
	ComputeGasProvidedByMiniBlockCalled func(miniBlock *block.MiniBlock, mapHashTx map[string]data.TransactionHandler) (uint64, uint64, error)
	ComputeGasProvidedByTxCalled        func(txSenderShardId uint32, txReceiverSharedId uint32, txHandler data.TransactionHandler) (uint64, uint64, error)
}

GasHandlerStub -

func (*GasHandlerStub) ComputeGasProvidedByMiniBlock

func (ghs *GasHandlerStub) ComputeGasProvidedByMiniBlock(miniBlock *block.MiniBlock, mapHashTx map[string]data.TransactionHandler) (uint64, uint64, error)

ComputeGasProvidedByMiniBlock -

func (*GasHandlerStub) ComputeGasProvidedByTx

func (ghs *GasHandlerStub) ComputeGasProvidedByTx(txSenderShardId uint32, txReceiverShardId uint32, txHandler data.TransactionHandler) (uint64, uint64, error)

ComputeGasProvidedByTx -

func (*GasHandlerStub) GasPenalized

func (ghs *GasHandlerStub) GasPenalized(hash []byte) uint64

GasPenalized -

func (*GasHandlerStub) GasProvided

func (ghs *GasHandlerStub) GasProvided(hash []byte) uint64

GasProvided -

func (*GasHandlerStub) GasProvidedAsScheduled

func (ghs *GasHandlerStub) GasProvidedAsScheduled(hash []byte) uint64

GasProvidedAsScheduled -

func (*GasHandlerStub) GasRefunded

func (ghs *GasHandlerStub) GasRefunded(hash []byte) uint64

GasRefunded -

func (*GasHandlerStub) Init

func (ghs *GasHandlerStub) Init()

Init -

func (*GasHandlerStub) IsInterfaceNil

func (ghs *GasHandlerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*GasHandlerStub) RemoveGasPenalized

func (ghs *GasHandlerStub) RemoveGasPenalized(hashes [][]byte)

RemoveGasPenalized -

func (*GasHandlerStub) RemoveGasProvided

func (ghs *GasHandlerStub) RemoveGasProvided(hashes [][]byte)

RemoveGasProvided -

func (*GasHandlerStub) RemoveGasProvidedAsScheduled

func (ghs *GasHandlerStub) RemoveGasProvidedAsScheduled(hashes [][]byte)

RemoveGasProvidedAsScheduled -

func (*GasHandlerStub) RemoveGasRefunded

func (ghs *GasHandlerStub) RemoveGasRefunded(hashes [][]byte)

RemoveGasRefunded -

func (*GasHandlerStub) Reset

func (ghs *GasHandlerStub) Reset(key []byte)

Reset -

func (*GasHandlerStub) RestoreGasSinceLastReset

func (ghs *GasHandlerStub) RestoreGasSinceLastReset(key []byte)

RestoreGasSinceLastReset -

func (*GasHandlerStub) SetGasPenalized

func (ghs *GasHandlerStub) SetGasPenalized(gasPenalized uint64, hash []byte)

SetGasPenalized -

func (*GasHandlerStub) SetGasProvided

func (ghs *GasHandlerStub) SetGasProvided(gasProvided uint64, hash []byte)

SetGasProvided -

func (*GasHandlerStub) SetGasProvidedAsScheduled

func (ghs *GasHandlerStub) SetGasProvidedAsScheduled(gasProvided uint64, hash []byte)

SetGasProvidedAsScheduled -

func (*GasHandlerStub) SetGasRefunded

func (ghs *GasHandlerStub) SetGasRefunded(gasRefunded uint64, hash []byte)

SetGasRefunded -

func (*GasHandlerStub) TotalGasPenalized

func (ghs *GasHandlerStub) TotalGasPenalized() uint64

TotalGasPenalized -

func (*GasHandlerStub) TotalGasProvided

func (ghs *GasHandlerStub) TotalGasProvided() uint64

TotalGasProvided -

func (*GasHandlerStub) TotalGasProvidedAsScheduled

func (ghs *GasHandlerStub) TotalGasProvidedAsScheduled() uint64

TotalGasProvidedAsScheduled -

func (*GasHandlerStub) TotalGasProvidedWithScheduled

func (ghs *GasHandlerStub) TotalGasProvidedWithScheduled() uint64

TotalGasProvidedWithScheduled -

func (*GasHandlerStub) TotalGasRefunded

func (ghs *GasHandlerStub) TotalGasRefunded() uint64

TotalGasRefunded -

type GasScheduleNotifierMock

type GasScheduleNotifierMock struct {
	GasSchedule                 map[string]map[string]uint64
	RegisterNotifyHandlerCalled func(handler core.GasScheduleSubscribeHandler)
	LatestGasScheduleCalled     func() map[string]map[string]uint64
	LatestGasScheduleCopyCalled func() map[string]map[string]uint64
}

GasScheduleNotifierMock -

func NewGasScheduleNotifierMock

func NewGasScheduleNotifierMock(gasSchedule map[string]map[string]uint64) *GasScheduleNotifierMock

NewGasScheduleNotifierMock -

func (*GasScheduleNotifierMock) IsInterfaceNil

func (g *GasScheduleNotifierMock) IsInterfaceNil() bool

IsInterfaceNil -

func (*GasScheduleNotifierMock) LatestGasSchedule

func (g *GasScheduleNotifierMock) LatestGasSchedule() map[string]map[string]uint64

LatestGasSchedule -

func (*GasScheduleNotifierMock) LatestGasScheduleCopy

func (g *GasScheduleNotifierMock) LatestGasScheduleCopy() map[string]map[string]uint64

LatestGasScheduleCopy -

func (*GasScheduleNotifierMock) RegisterNotifyHandler

func (g *GasScheduleNotifierMock) RegisterNotifyHandler(handler core.GasScheduleSubscribeHandler)

RegisterNotifyHandler -

func (*GasScheduleNotifierMock) UnRegisterAll

func (g *GasScheduleNotifierMock) UnRegisterAll()

UnRegisterAll -

type HardforkTriggerStub

type HardforkTriggerStub struct {
	SetExportFactoryHandlerCalled func(exportFactoryHandler update.ExportFactoryHandler) error
	TriggerCalled                 func(epoch uint32, withEarlyEndOfEpoch bool) error
	IsSelfTriggerCalled           func() bool
	TriggerReceivedCalled         func(payload []byte, data []byte, pkBytes []byte) (bool, error)
	RecordedTriggerMessageCalled  func() ([]byte, bool)
	CreateDataCalled              func() []byte
	AddCloserCalled               func(closer update.Closer) error
	NotifyTriggerReceivedCalled   func() <-chan struct{}
	NotifyTriggerReceivedV2Called func() <-chan struct{}
}

HardforkTriggerStub -

func (*HardforkTriggerStub) AddCloser

func (hts *HardforkTriggerStub) AddCloser(closer update.Closer) error

AddCloser -

func (*HardforkTriggerStub) CreateData

func (hts *HardforkTriggerStub) CreateData() []byte

CreateData -

func (*HardforkTriggerStub) IsInterfaceNil

func (hts *HardforkTriggerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*HardforkTriggerStub) IsSelfTrigger

func (hts *HardforkTriggerStub) IsSelfTrigger() bool

IsSelfTrigger -

func (*HardforkTriggerStub) NotifyTriggerReceived

func (hts *HardforkTriggerStub) NotifyTriggerReceived() <-chan struct{}

NotifyTriggerReceived -

func (*HardforkTriggerStub) NotifyTriggerReceivedV2

func (hts *HardforkTriggerStub) NotifyTriggerReceivedV2() <-chan struct{}

NotifyTriggerReceivedV2 -

func (*HardforkTriggerStub) RecordedTriggerMessage

func (hts *HardforkTriggerStub) RecordedTriggerMessage() ([]byte, bool)

RecordedTriggerMessage -

func (*HardforkTriggerStub) SetExportFactoryHandler

func (hts *HardforkTriggerStub) SetExportFactoryHandler(exportFactoryHandler update.ExportFactoryHandler) error

SetExportFactoryHandler -

func (*HardforkTriggerStub) Trigger

func (hts *HardforkTriggerStub) Trigger(epoch uint32, withEarlyEndOfEpoch bool) error

Trigger -

func (*HardforkTriggerStub) TriggerReceived

func (hts *HardforkTriggerStub) TriggerReceived(payload []byte, data []byte, pkBytes []byte) (bool, error)

TriggerReceived -

type HasherStub

type HasherStub struct {
	ComputeCalled   func(s string) []byte
	EmptyHashCalled func() []byte
	SizeCalled      func() int
}

HasherStub -

func (*HasherStub) Compute

func (hash *HasherStub) Compute(s string) []byte

Compute -

func (*HasherStub) EmptyHash

func (hash *HasherStub) EmptyHash() []byte

EmptyHash -

func (*HasherStub) IsInterfaceNil

func (hash *HasherStub) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*HasherStub) Size

func (hash *HasherStub) Size() int

Size -

type HeaderHandlerStub

type HeaderHandlerStub struct {
	EpochField                             uint32
	TimestampField                         uint64
	GetMiniBlockHeadersWithDstCalled       func(destId uint32) map[string]uint32
	GetOrderedCrossMiniblocksWithDstCalled func(destId uint32) []*data.MiniBlockInfo
	GetPubKeysBitmapCalled                 func() []byte
	GetSignatureCalled                     func() []byte
	GetRootHashCalled                      func() []byte
	GetRandSeedCalled                      func() []byte
	GetPrevRandSeedCalled                  func() []byte
	GetPrevHashCalled                      func() []byte
	CloneCalled                            func() data.HeaderHandler
	GetChainIDCalled                       func() []byte
	CheckChainIDCalled                     func(reference []byte) error
	GetReservedCalled                      func() []byte
	IsStartOfEpochBlockCalled              func() bool
	HasScheduledMiniBlocksCalled           func() bool
	GetNonceCalled                         func() uint64
}

HeaderHandlerStub -

func (*HeaderHandlerStub) GetAccumulatedFees

func (hhs *HeaderHandlerStub) GetAccumulatedFees() *big.Int

GetAccumulatedFees -

func (*HeaderHandlerStub) GetAdditionalData

func (hhs *HeaderHandlerStub) GetAdditionalData() headerVersionData.HeaderAdditionalData

GetAdditionalData gets the additional version-related data

func (*HeaderHandlerStub) GetBlockBodyTypeInt32

func (hhs *HeaderHandlerStub) GetBlockBodyTypeInt32() int32

GetBlockBodyTypeInt32 -

func (*HeaderHandlerStub) GetChainID

func (hhs *HeaderHandlerStub) GetChainID() []byte

GetChainID -

func (*HeaderHandlerStub) GetDevFeesInEpoch

func (hhs *HeaderHandlerStub) GetDevFeesInEpoch() *big.Int

GetDevFeesInEpoch -

func (*HeaderHandlerStub) GetDeveloperFees

func (hhs *HeaderHandlerStub) GetDeveloperFees() *big.Int

GetDeveloperFees -

func (*HeaderHandlerStub) GetEpoch

func (hhs *HeaderHandlerStub) GetEpoch() uint32

GetEpoch -

func (*HeaderHandlerStub) GetEpochStartHandler

func (hhs *HeaderHandlerStub) GetEpochStartHandler() data.EpochStartHandler

GetEpochStartHandler -

func (*HeaderHandlerStub) GetEpochStartMetaHash

func (hhs *HeaderHandlerStub) GetEpochStartMetaHash() []byte

GetEpochStartMetaHash -

func (*HeaderHandlerStub) GetLeaderSignature

func (hhs *HeaderHandlerStub) GetLeaderSignature() []byte

GetLeaderSignature -

func (*HeaderHandlerStub) GetMetaBlockHashes

func (hhs *HeaderHandlerStub) GetMetaBlockHashes() [][]byte

GetMetaBlockHashes -

func (*HeaderHandlerStub) GetMiniBlockHeaderHandlers

func (hhs *HeaderHandlerStub) GetMiniBlockHeaderHandlers() []data.MiniBlockHeaderHandler

GetMiniBlockHeaderHandlers -

func (*HeaderHandlerStub) GetMiniBlockHeadersHashes

func (hhs *HeaderHandlerStub) GetMiniBlockHeadersHashes() [][]byte

GetMiniBlockHeadersHashes -

func (*HeaderHandlerStub) GetMiniBlockHeadersWithDst

func (hhs *HeaderHandlerStub) GetMiniBlockHeadersWithDst(destId uint32) map[string]uint32

GetMiniBlockHeadersWithDst -

func (*HeaderHandlerStub) GetNonce

func (hhs *HeaderHandlerStub) GetNonce() uint64

GetNonce -

func (*HeaderHandlerStub) GetOrderedCrossMiniblocksWithDst

func (hhs *HeaderHandlerStub) GetOrderedCrossMiniblocksWithDst(destId uint32) []*data.MiniBlockInfo

GetOrderedCrossMiniblocksWithDst -

func (*HeaderHandlerStub) GetPrevHash

func (hhs *HeaderHandlerStub) GetPrevHash() []byte

GetPrevHash -

func (*HeaderHandlerStub) GetPrevRandSeed

func (hhs *HeaderHandlerStub) GetPrevRandSeed() []byte

GetPrevRandSeed -

func (*HeaderHandlerStub) GetPubKeysBitmap

func (hhs *HeaderHandlerStub) GetPubKeysBitmap() []byte

GetPubKeysBitmap -

func (*HeaderHandlerStub) GetRandSeed

func (hhs *HeaderHandlerStub) GetRandSeed() []byte

GetRandSeed -

func (*HeaderHandlerStub) GetReceiptsHash

func (hhs *HeaderHandlerStub) GetReceiptsHash() []byte

GetReceiptsHash -

func (*HeaderHandlerStub) GetReserved

func (hhs *HeaderHandlerStub) GetReserved() []byte

GetReserved -

func (*HeaderHandlerStub) GetRootHash

func (hhs *HeaderHandlerStub) GetRootHash() []byte

GetRootHash -

func (*HeaderHandlerStub) GetRound

func (hhs *HeaderHandlerStub) GetRound() uint64

GetRound -

func (*HeaderHandlerStub) GetShardID

func (hhs *HeaderHandlerStub) GetShardID() uint32

GetShardID -

func (*HeaderHandlerStub) GetShardInfoHandlers

func (hhs *HeaderHandlerStub) GetShardInfoHandlers() []data.ShardDataHandler

GetShardInfoHandlers -

func (*HeaderHandlerStub) GetSignature

func (hhs *HeaderHandlerStub) GetSignature() []byte

GetSignature -

func (*HeaderHandlerStub) GetSoftwareVersion

func (hhs *HeaderHandlerStub) GetSoftwareVersion() []byte

GetSoftwareVersion -

func (*HeaderHandlerStub) GetTimeStamp

func (hhs *HeaderHandlerStub) GetTimeStamp() uint64

GetTimeStamp -

func (*HeaderHandlerStub) GetTxCount

func (hhs *HeaderHandlerStub) GetTxCount() uint32

GetTxCount -

func (*HeaderHandlerStub) GetValidatorStatsRootHash

func (hhs *HeaderHandlerStub) GetValidatorStatsRootHash() []byte

GetValidatorStatsRootHash -

func (*HeaderHandlerStub) HasScheduledMiniBlocks

func (hhs *HeaderHandlerStub) HasScheduledMiniBlocks() bool

HasScheduledMiniBlocks -

func (*HeaderHandlerStub) HasScheduledSupport

func (hhs *HeaderHandlerStub) HasScheduledSupport() bool

HasScheduledSupport -

func (*HeaderHandlerStub) IsInterfaceNil

func (hhs *HeaderHandlerStub) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*HeaderHandlerStub) IsStartOfEpochBlock

func (hhs *HeaderHandlerStub) IsStartOfEpochBlock() bool

IsStartOfEpochBlock -

func (*HeaderHandlerStub) MapMiniBlockHashesToShards

func (hhs *HeaderHandlerStub) MapMiniBlockHashesToShards() map[string]uint32

MapMiniBlockHashesToShards -

func (*HeaderHandlerStub) SetAccumulatedFees

func (hhs *HeaderHandlerStub) SetAccumulatedFees(_ *big.Int) error

SetAccumulatedFees -

func (*HeaderHandlerStub) SetAccumulatedFeesInEpoch

func (hhs *HeaderHandlerStub) SetAccumulatedFeesInEpoch(_ *big.Int) error

SetAccumulatedFeesInEpoch -

func (*HeaderHandlerStub) SetAdditionalData

SetAdditionalData sets the additional version-related data

func (*HeaderHandlerStub) SetChainID

func (hhs *HeaderHandlerStub) SetChainID(_ []byte) error

SetChainID -

func (*HeaderHandlerStub) SetDevFeesInEpoch

func (hhs *HeaderHandlerStub) SetDevFeesInEpoch(_ *big.Int) error

SetDevFeesInEpoch -

func (*HeaderHandlerStub) SetDeveloperFees

func (hhs *HeaderHandlerStub) SetDeveloperFees(_ *big.Int) error

SetDeveloperFees -

func (*HeaderHandlerStub) SetEpoch

func (hhs *HeaderHandlerStub) SetEpoch(_ uint32) error

SetEpoch -

func (*HeaderHandlerStub) SetEpochStartMetaHash

func (h *HeaderHandlerStub) SetEpochStartMetaHash(_ []byte) error

SetEpochStartMetaHash -

func (*HeaderHandlerStub) SetLeaderSignature

func (hhs *HeaderHandlerStub) SetLeaderSignature(_ []byte) error

SetLeaderSignature -

func (*HeaderHandlerStub) SetMetaBlockHashes

func (hhs *HeaderHandlerStub) SetMetaBlockHashes(_ [][]byte) error

SetMetaBlockHashes -

func (*HeaderHandlerStub) SetMiniBlockHeaderHandlers

func (hhs *HeaderHandlerStub) SetMiniBlockHeaderHandlers(_ []data.MiniBlockHeaderHandler) error

SetMiniBlockHeaderHandlers -

func (*HeaderHandlerStub) SetNonce

func (hhs *HeaderHandlerStub) SetNonce(_ uint64) error

SetNonce -

func (*HeaderHandlerStub) SetPrevHash

func (hhs *HeaderHandlerStub) SetPrevHash(_ []byte) error

SetPrevHash -

func (*HeaderHandlerStub) SetPrevRandSeed

func (hhs *HeaderHandlerStub) SetPrevRandSeed(_ []byte) error

SetPrevRandSeed -

func (*HeaderHandlerStub) SetPubKeysBitmap

func (hhs *HeaderHandlerStub) SetPubKeysBitmap(_ []byte) error

SetPubKeysBitmap -

func (*HeaderHandlerStub) SetRandSeed

func (hhs *HeaderHandlerStub) SetRandSeed(_ []byte) error

SetRandSeed -

func (*HeaderHandlerStub) SetReceiptsHash

func (hhs *HeaderHandlerStub) SetReceiptsHash(_ []byte) error

SetReceiptsHash -

func (*HeaderHandlerStub) SetRootHash

func (hhs *HeaderHandlerStub) SetRootHash(_ []byte) error

SetRootHash -

func (*HeaderHandlerStub) SetRound

func (hhs *HeaderHandlerStub) SetRound(_ uint64) error

SetRound -

func (*HeaderHandlerStub) SetScheduledRootHash

func (hhs *HeaderHandlerStub) SetScheduledRootHash(_ []byte) error

SetScheduledRootHash -

func (*HeaderHandlerStub) SetShardID

func (hhs *HeaderHandlerStub) SetShardID(_ uint32) error

SetShardID -

func (*HeaderHandlerStub) SetShardInfoHandlers

func (hhs *HeaderHandlerStub) SetShardInfoHandlers(_ []data.ShardDataHandler) error

SetShardInfoHandlers -

func (*HeaderHandlerStub) SetSignature

func (hhs *HeaderHandlerStub) SetSignature(_ []byte) error

SetSignature -

func (*HeaderHandlerStub) SetSoftwareVersion

func (hhs *HeaderHandlerStub) SetSoftwareVersion(_ []byte) error

SetSoftwareVersion -

func (*HeaderHandlerStub) SetTimeStamp

func (hhs *HeaderHandlerStub) SetTimeStamp(_ uint64) error

SetTimeStamp -

func (*HeaderHandlerStub) SetTxCount

func (hhs *HeaderHandlerStub) SetTxCount(_ uint32) error

SetTxCount -

func (*HeaderHandlerStub) SetValidatorStatsRootHash

func (hhs *HeaderHandlerStub) SetValidatorStatsRootHash(_ []byte) error

SetValidatorStatsRootHash -

func (*HeaderHandlerStub) ShallowClone

func (hhs *HeaderHandlerStub) ShallowClone() data.HeaderHandler

ShallowClone -

func (*HeaderHandlerStub) ValidateHeaderVersion

func (hhs *HeaderHandlerStub) ValidateHeaderVersion() error

ValidateHeaderVersion -

type HeaderVersionHandlerStub

type HeaderVersionHandlerStub struct {
	GetVersionCalled     func(epoch uint32) string
	VerifyCalled         func(hdr data.HeaderHandler) error
	IsInterfaceNilCalled func() bool
}

HeaderVersionHandlerStub -

func (*HeaderVersionHandlerStub) GetVersion

func (hvm *HeaderVersionHandlerStub) GetVersion(epoch uint32) string

GetVersion -

func (*HeaderVersionHandlerStub) IsInterfaceNil

func (hvm *HeaderVersionHandlerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*HeaderVersionHandlerStub) Verify

Verify -

type ImportStartHandlerStub

type ImportStartHandlerStub struct {
	SetStartImportCalled            func() error
	ResetStartImportCalled          func() error
	IsAfterExportBeforeImportCalled func() bool
	ShouldStartImportCalled         func() bool
}

ImportStartHandlerStub -

func (*ImportStartHandlerStub) IsAfterExportBeforeImport

func (ish *ImportStartHandlerStub) IsAfterExportBeforeImport() bool

IsAfterExportBeforeImport -

func (*ImportStartHandlerStub) IsInterfaceNil

func (ish *ImportStartHandlerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*ImportStartHandlerStub) ResetStartImport

func (ish *ImportStartHandlerStub) ResetStartImport() error

ResetStartImport -

func (*ImportStartHandlerStub) SetStartImport

func (ish *ImportStartHandlerStub) SetStartImport() error

SetStartImport -

func (*ImportStartHandlerStub) ShouldStartImport

func (ish *ImportStartHandlerStub) ShouldStartImport() bool

ShouldStartImport -

type InterceptedDataStub

type InterceptedDataStub struct {
	CheckValidityCalled     func() error
	IsForCurrentShardCalled func() bool
	HashCalled              func() []byte
	TypeCalled              func() string
	IdentifiersCalled       func() [][]byte
	StringCalled            func() string
}

InterceptedDataStub -

func (*InterceptedDataStub) CheckValidity

func (ids *InterceptedDataStub) CheckValidity() error

CheckValidity -

func (*InterceptedDataStub) Hash

func (ids *InterceptedDataStub) Hash() []byte

Hash -

func (*InterceptedDataStub) Identifiers

func (ids *InterceptedDataStub) Identifiers() [][]byte

Identifiers -

func (*InterceptedDataStub) IsForCurrentShard

func (ids *InterceptedDataStub) IsForCurrentShard() bool

IsForCurrentShard -

func (*InterceptedDataStub) IsInterfaceNil

func (ids *InterceptedDataStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*InterceptedDataStub) String

func (ids *InterceptedDataStub) String() string

String -

func (*InterceptedDataStub) Type

func (ids *InterceptedDataStub) Type() string

Type -

type InterceptorStub

type InterceptorStub struct {
	ProcessReceivedMessageCalled     func(message p2p.MessageP2P) error
	SetInterceptedDebugHandlerCalled func(debugger process.InterceptedDebugger) error
	RegisterHandlerCalled            func(handler func(topic string, hash []byte, data interface{}))
	CloseCalled                      func() error
}

InterceptorStub -

func (*InterceptorStub) Close

func (is *InterceptorStub) Close() error

Close -

func (*InterceptorStub) IsInterfaceNil

func (is *InterceptorStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*InterceptorStub) ProcessReceivedMessage

func (is *InterceptorStub) ProcessReceivedMessage(message p2p.MessageP2P, _ core.PeerID) error

ProcessReceivedMessage -

func (*InterceptorStub) RegisterHandler

func (is *InterceptorStub) RegisterHandler(handler func(topic string, hash []byte, data interface{}))

RegisterHandler -

func (*InterceptorStub) SetInterceptedDebugHandler

func (is *InterceptorStub) SetInterceptedDebugHandler(debugger process.InterceptedDebugger) error

SetInterceptedDebugHandler -

type InterceptorsContainerStub

type InterceptorsContainerStub struct {
	IterateCalled     func(handler func(key string, interceptor process.Interceptor) bool)
	GetCalled         func(string) (process.Interceptor, error)
	AddCalled         func(key string, interceptor process.Interceptor) error
	AddMultipleCalled func(keys []string, interceptors []process.Interceptor) error
	ReplaceCalled     func(key string, interceptor process.Interceptor) error
	RemoveCalled      func(key string)
	LenCalled         func() int
	CloseCalled       func() error
}

InterceptorsContainerStub -

func (*InterceptorsContainerStub) Add

func (ics *InterceptorsContainerStub) Add(key string, interceptor process.Interceptor) error

Add -

func (*InterceptorsContainerStub) AddMultiple

func (ics *InterceptorsContainerStub) AddMultiple(keys []string, interceptors []process.Interceptor) error

AddMultiple -

func (*InterceptorsContainerStub) Close

func (ics *InterceptorsContainerStub) Close() error

Close -

func (*InterceptorsContainerStub) Get

Get -

func (*InterceptorsContainerStub) IsInterfaceNil

func (ics *InterceptorsContainerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*InterceptorsContainerStub) Iterate

func (ics *InterceptorsContainerStub) Iterate(handler func(key string, interceptor process.Interceptor) bool)

Iterate -

func (*InterceptorsContainerStub) Len

func (ics *InterceptorsContainerStub) Len() int

Len -

func (*InterceptorsContainerStub) Remove

func (ics *InterceptorsContainerStub) Remove(key string)

Remove -

func (*InterceptorsContainerStub) Replace

func (ics *InterceptorsContainerStub) Replace(key string, interceptor process.Interceptor) error

Replace -

type KeccakMock

type KeccakMock struct {
}

KeccakMock is a sha3-Keccak implementation of the hasher interface.

func (KeccakMock) Compute

func (k KeccakMock) Compute(s string) []byte

Compute takes a string, and returns the sha3-Keccak hash of that string

func (KeccakMock) EmptyHash

func (k KeccakMock) EmptyHash() []byte

EmptyHash returns the sha3-Keccak hash of the empty string

func (*KeccakMock) IsInterfaceNil

func (k *KeccakMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (KeccakMock) Size

func (KeccakMock) Size() int

Size returns the size, in number of bytes, of a sha3-Keccak hash

type LoggerStub

type LoggerStub struct {
	TraceCalled      func(message string, args ...interface{})
	DebugCalled      func(message string, args ...interface{})
	InfoCalled       func(message string, args ...interface{})
	WarnCalled       func(message string, args ...interface{})
	ErrorCalled      func(message string, args ...interface{})
	LogIfErrorCalled func(err error, args ...interface{})
	LogCalled        func(logLevel logger.LogLevel, message string, args ...interface{})
	LogLineCalled    func(line *logger.LogLine)
	SetLevelCalled   func(logLevel logger.LogLevel)
	GetLevelCalled   func() logger.LogLevel
}

LoggerStub -

func (*LoggerStub) Debug

func (stub *LoggerStub) Debug(message string, args ...interface{})

Debug -

func (*LoggerStub) Error

func (stub *LoggerStub) Error(message string, args ...interface{})

Error -

func (*LoggerStub) GetLevel

func (stub *LoggerStub) GetLevel() logger.LogLevel

GetLevel -

func (*LoggerStub) Info

func (stub *LoggerStub) Info(message string, args ...interface{})

Info -

func (*LoggerStub) IsInterfaceNil

func (stub *LoggerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*LoggerStub) Log

func (stub *LoggerStub) Log(logLevel logger.LogLevel, message string, args ...interface{})

Log -

func (*LoggerStub) LogIfError

func (stub *LoggerStub) LogIfError(err error, args ...interface{})

LogIfError -

func (*LoggerStub) LogLine

func (stub *LoggerStub) LogLine(line *logger.LogLine)

LogLine -

func (*LoggerStub) SetLevel

func (stub *LoggerStub) SetLevel(logLevel logger.LogLevel)

SetLevel -

func (*LoggerStub) Trace

func (stub *LoggerStub) Trace(message string, args ...interface{})

Trace -

func (*LoggerStub) Warn

func (stub *LoggerStub) Warn(message string, args ...interface{})

Warn -

type LogsFacadeStub

type LogsFacadeStub struct {
	GetLogCalled                    func(txHash []byte, epoch uint32) (*transaction.ApiLogs, error)
	IncludeLogsInTransactionsCalled func(txs []*transaction.ApiTransactionResult, logsKeys [][]byte, epoch uint32) error
}

LogsFacadeStub -

func (*LogsFacadeStub) GetLog

func (stub *LogsFacadeStub) GetLog(logKey []byte, epoch uint32) (*transaction.ApiLogs, error)

GetLog -

func (*LogsFacadeStub) IncludeLogsInTransactions

func (stub *LogsFacadeStub) IncludeLogsInTransactions(txs []*transaction.ApiTransactionResult, logsKeys [][]byte, epoch uint32) error

IncludeLogsInTransactions

func (*LogsFacadeStub) IsInterfaceNil

func (stub *LogsFacadeStub) IsInterfaceNil() bool

IsInterfaceNil -

type MarshalizerMock

type MarshalizerMock struct {
	Fail bool
}

MarshalizerMock that will be used for testing

func (MarshalizerMock) IsInterfaceNil

func (mm MarshalizerMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (MarshalizerMock) Marshal

func (mm MarshalizerMock) Marshal(obj interface{}) ([]byte, error)

Marshal converts the input object in a slice of bytes

func (MarshalizerMock) Unmarshal

func (mm MarshalizerMock) Unmarshal(obj interface{}, buff []byte) error

Unmarshal applies the serialized values over an instantiated object

type MarshalizerStub

type MarshalizerStub struct {
	MarshalCalled   func(obj interface{}) ([]byte, error)
	UnmarshalCalled func(obj interface{}, buff []byte) error
}

MarshalizerStub -

func (*MarshalizerStub) IsInterfaceNil

func (ms *MarshalizerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*MarshalizerStub) Marshal

func (ms *MarshalizerStub) Marshal(obj interface{}) ([]byte, error)

Marshal -

func (*MarshalizerStub) Unmarshal

func (ms *MarshalizerStub) Unmarshal(obj interface{}, buff []byte) error

Unmarshal -

type MemDbMock

type MemDbMock struct {
	PutCalled func(key, val []byte) error
	// 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 NewMemDbMock

func NewMemDbMock() *MemDbMock

NewMemDbMock creates a new memorydb object

func (*MemDbMock) Close

func (s *MemDbMock) Close() error

Close closes the files/resources associated to the storage medium

func (*MemDbMock) Destroy

func (s *MemDbMock) Destroy() error

Destroy removes the storage medium stored data

func (*MemDbMock) DestroyClosed

func (s *MemDbMock) DestroyClosed() error

DestroyClosed removes the already closed storage medium stored data

func (*MemDbMock) Get

func (s *MemDbMock) Get(key []byte) ([]byte, error)

Get gets the value associated to the key, or reports an error

func (*MemDbMock) Has

func (s *MemDbMock) Has(key []byte) error

Has returns true if the given key is present in the persistence medium, false otherwise

func (*MemDbMock) IsInterfaceNil

func (s *MemDbMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*MemDbMock) Put

func (s *MemDbMock) Put(key, val []byte) error

Put adds the value to the (key, val) storage medium

func (*MemDbMock) RangeKeys

func (s *MemDbMock) RangeKeys(handler func(key []byte, value []byte) bool)

RangeKeys will iterate over all contained (key, value) pairs calling the handler for each pair

func (*MemDbMock) Remove

func (s *MemDbMock) Remove(key []byte) error

Remove removes the data associated to the given key

type MessageSignVerifierMock

type MessageSignVerifierMock struct {
}

MessageSignVerifierMock -

func (*MessageSignVerifierMock) IsInterfaceNil

func (m *MessageSignVerifierMock) IsInterfaceNil() bool

IsInterfaceNil -

func (*MessageSignVerifierMock) Verify

func (m *MessageSignVerifierMock) Verify(_ []byte, _ []byte, _ []byte) error

Verify -

type NodesSetupStub

type NodesSetupStub struct {
	InitialNodesPubKeysCalled                 func() map[uint32][]string
	InitialEligibleNodesPubKeysForShardCalled func(shardId uint32) ([]string, error)
	GetShardIDForPubKeyCalled                 func(pubKey []byte) (uint32, error)
	NumberOfShardsCalled                      func() uint32
	GetShardConsensusGroupSizeCalled          func() uint32
	GetMetaConsensusGroupSizeCalled           func() uint32
	GetRoundDurationCalled                    func() uint64
	MinNumberOfMetaNodesCalled                func() uint32
	MinNumberOfShardNodesCalled               func() uint32
	GetHysteresisCalled                       func() float32
	GetAdaptivityCalled                       func() bool
	InitialNodesInfoForShardCalled            func(shardId uint32) ([]nodesCoordinator.GenesisNodeInfoHandler, []nodesCoordinator.GenesisNodeInfoHandler, error)
	InitialNodesInfoCalled                    func() (map[uint32][]nodesCoordinator.GenesisNodeInfoHandler, map[uint32][]nodesCoordinator.GenesisNodeInfoHandler)
	GetStartTimeCalled                        func() int64
	MinNumberOfNodesCalled                    func() uint32
	AllInitialNodesCalled                     func() []nodesCoordinator.GenesisNodeInfoHandler
	MinNumberOfNodesWithHysteresisCalled      func() uint32
}

NodesSetupStub -

func (*NodesSetupStub) AllInitialNodes

AllInitialNodes -

func (*NodesSetupStub) GetAdaptivity

func (n *NodesSetupStub) GetAdaptivity() bool

GetAdaptivity -

func (*NodesSetupStub) GetHysteresis

func (n *NodesSetupStub) GetHysteresis() float32

GetHysteresis -

func (*NodesSetupStub) GetMetaConsensusGroupSize

func (n *NodesSetupStub) GetMetaConsensusGroupSize() uint32

GetMetaConsensusGroupSize -

func (*NodesSetupStub) GetRoundDuration

func (n *NodesSetupStub) GetRoundDuration() uint64

GetRoundDuration -

func (*NodesSetupStub) GetShardConsensusGroupSize

func (n *NodesSetupStub) GetShardConsensusGroupSize() uint32

GetShardConsensusGroupSize -

func (*NodesSetupStub) GetShardIDForPubKey

func (n *NodesSetupStub) GetShardIDForPubKey(pubkey []byte) (uint32, error)

GetShardIDForPubKey -

func (*NodesSetupStub) GetStartTime

func (n *NodesSetupStub) GetStartTime() int64

GetStartTime -

func (*NodesSetupStub) InitialEligibleNodesPubKeysForShard

func (n *NodesSetupStub) InitialEligibleNodesPubKeysForShard(shardId uint32) ([]string, error)

InitialEligibleNodesPubKeysForShard -

func (*NodesSetupStub) InitialNodesInfo

InitialNodesInfo -

func (*NodesSetupStub) InitialNodesInfoForShard

InitialNodesInfoForShard -

func (*NodesSetupStub) InitialNodesPubKeys

func (n *NodesSetupStub) InitialNodesPubKeys() map[uint32][]string

InitialNodesPubKeys -

func (*NodesSetupStub) IsInterfaceNil

func (n *NodesSetupStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*NodesSetupStub) MinNumberOfMetaNodes

func (n *NodesSetupStub) MinNumberOfMetaNodes() uint32

MinNumberOfMetaNodes -

func (*NodesSetupStub) MinNumberOfNodes

func (n *NodesSetupStub) MinNumberOfNodes() uint32

MinNumberOfNodes -

func (*NodesSetupStub) MinNumberOfNodesWithHysteresis

func (n *NodesSetupStub) MinNumberOfNodesWithHysteresis() uint32

MinNumberOfNodesWithHysteresis -

func (*NodesSetupStub) MinNumberOfShardNodes

func (n *NodesSetupStub) MinNumberOfShardNodes() uint32

MinNumberOfShardNodes -

func (*NodesSetupStub) NumberOfShards

func (n *NodesSetupStub) NumberOfShards() uint32

NumberOfShards -

type OldDataCleanerProviderStub

type OldDataCleanerProviderStub struct {
	ShouldCleanCalled func() bool
}

OldDataCleanerProviderStub -

func (*OldDataCleanerProviderStub) IsInterfaceNil

func (o *OldDataCleanerProviderStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*OldDataCleanerProviderStub) ShouldClean

func (o *OldDataCleanerProviderStub) ShouldClean() bool

ShouldClean -

type OutportStub

type OutportStub struct {
	SaveBlockCalled             func(args *indexer.ArgsSaveBlockData)
	SaveValidatorsRatingCalled  func(index string, validatorsInfo []*indexer.ValidatorRatingInfo)
	SaveValidatorsPubKeysCalled func(shardPubKeys map[uint32][][]byte, epoch uint32)
	HasDriversCalled            func() bool
}

OutportStub is a mock implementation fot the OutportHandler interface

func (*OutportStub) Close

func (as *OutportStub) Close() error

Close -

func (*OutportStub) FinalizedBlock

func (as *OutportStub) FinalizedBlock(_ []byte)

FinalizedBlock -

func (*OutportStub) HasDrivers

func (as *OutportStub) HasDrivers() bool

HasDrivers -

func (*OutportStub) IsInterfaceNil

func (as *OutportStub) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*OutportStub) RevertIndexedBlock

func (as *OutportStub) RevertIndexedBlock(_ data.HeaderHandler, _ data.BodyHandler)

RevertIndexedBlock -

func (*OutportStub) SaveAccounts

func (as *OutportStub) SaveAccounts(_ uint64, _ []data.UserAccountHandler)

SaveAccounts -

func (*OutportStub) SaveBlock

func (as *OutportStub) SaveBlock(args *indexer.ArgsSaveBlockData)

SaveBlock -

func (*OutportStub) SaveRoundsInfo

func (as *OutportStub) SaveRoundsInfo(_ []*indexer.RoundInfo)

SaveRoundsInfo -

func (*OutportStub) SaveValidatorsPubKeys

func (as *OutportStub) SaveValidatorsPubKeys(shardPubKeys map[uint32][][]byte, epoch uint32)

SaveValidatorsPubKeys -

func (*OutportStub) SaveValidatorsRating

func (as *OutportStub) SaveValidatorsRating(index string, validatorsInfo []*indexer.ValidatorRatingInfo)

SaveValidatorsRating -

func (*OutportStub) SubscribeDriver

func (as *OutportStub) SubscribeDriver(_ outport.Driver) error

SubscribeDriver -

type PanicDoubleTransactionsDetector

type PanicDoubleTransactionsDetector struct {
}

PanicDoubleTransactionsDetector -

func (*PanicDoubleTransactionsDetector) IsInterfaceNil

func (detector *PanicDoubleTransactionsDetector) IsInterfaceNil() bool

IsInterfaceNil -

func (*PanicDoubleTransactionsDetector) ProcessBlockBody

func (detector *PanicDoubleTransactionsDetector) ProcessBlockBody(body *block.Body)

ProcessBlockBody -

type PathManagerStub

type PathManagerStub struct {
	PathForEpochCalled  func(shardId string, epoch uint32, identifier string) string
	PathForStaticCalled func(shardId string, identifier string) string
	DatabasePathCalled  func() string
}

PathManagerStub -

func (*PathManagerStub) DatabasePath

func (p *PathManagerStub) DatabasePath() string

DatabasePath -

func (*PathManagerStub) IsInterfaceNil

func (p *PathManagerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*PathManagerStub) PathForEpoch

func (p *PathManagerStub) PathForEpoch(shardId string, epoch uint32, identifier string) string

PathForEpoch -

func (*PathManagerStub) PathForStatic

func (p *PathManagerStub) PathForStatic(shardId string, identifier string) string

PathForStatic -

type PeerAuthenticationPayloadValidatorStub

type PeerAuthenticationPayloadValidatorStub struct {
	ValidateTimestampCalled func(payloadTimestamp int64) error
}

PeerAuthenticationPayloadValidatorStub -

func (*PeerAuthenticationPayloadValidatorStub) IsInterfaceNil

func (stub *PeerAuthenticationPayloadValidatorStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*PeerAuthenticationPayloadValidatorStub) ValidateTimestamp

func (stub *PeerAuthenticationPayloadValidatorStub) ValidateTimestamp(payloadTimestamp int64) error

ValidateTimestamp -

type PeerHonestyHandlerStub

type PeerHonestyHandlerStub struct {
	ChangeScoreCalled func(pk string, topic string, units int)
}

PeerHonestyHandlerStub -

func (*PeerHonestyHandlerStub) ChangeScore

func (phhs *PeerHonestyHandlerStub) ChangeScore(pk string, topic string, units int)

ChangeScore -

func (*PeerHonestyHandlerStub) Close

func (phhs *PeerHonestyHandlerStub) Close() error

Close -

func (*PeerHonestyHandlerStub) IsInterfaceNil

func (phhs *PeerHonestyHandlerStub) IsInterfaceNil() bool

IsInterfaceNil -

type PreProcessorExecutionInfoHandlerMock

type PreProcessorExecutionInfoHandlerMock struct {
	GetNumOfCrossInterMbsAndTxsCalled func() (int, int)
	InitProcessedTxsResultsCalled     func(key []byte)
	RevertProcessedTxsResultsCalled   func(txHashes [][]byte, key []byte)
}

PreProcessorExecutionInfoHandlerMock -

func (*PreProcessorExecutionInfoHandlerMock) GetNumOfCrossInterMbsAndTxs

func (ppeihm *PreProcessorExecutionInfoHandlerMock) GetNumOfCrossInterMbsAndTxs() (int, int)

GetNumOfCrossInterMbsAndTxs -

func (*PreProcessorExecutionInfoHandlerMock) InitProcessedTxsResults

func (ppeihm *PreProcessorExecutionInfoHandlerMock) InitProcessedTxsResults(key []byte)

InitProcessedTxsResults -

func (*PreProcessorExecutionInfoHandlerMock) RevertProcessedTxsResults

func (ppeihm *PreProcessorExecutionInfoHandlerMock) RevertProcessedTxsResults(txHashes [][]byte, key []byte)

RevertProcessedTxsResults -

type ProcessStatusHandlerStub

type ProcessStatusHandlerStub struct {
	SetBusyCalled func(reason string)
	SetIdleCalled func()
	IsIdleCalled  func() bool
}

ProcessStatusHandlerStub -

func (*ProcessStatusHandlerStub) IsIdle

func (stub *ProcessStatusHandlerStub) IsIdle() bool

IsIdle -

func (*ProcessStatusHandlerStub) IsInterfaceNil

func (stub *ProcessStatusHandlerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*ProcessStatusHandlerStub) SetBusy

func (stub *ProcessStatusHandlerStub) SetBusy(reason string)

SetBusy -

func (*ProcessStatusHandlerStub) SetIdle

func (stub *ProcessStatusHandlerStub) SetIdle()

SetIdle -

type ProcessedMiniBlocksTrackerStub

type ProcessedMiniBlocksTrackerStub struct {
	SetProcessedMiniBlockInfoCalled            func(metaBlockHash []byte, miniBlockHash []byte, processedMbInfo *processedMb.ProcessedMiniBlockInfo)
	RemoveMetaBlockHashCalled                  func(metaBlockHash []byte)
	RemoveMiniBlockHashCalled                  func(miniBlockHash []byte)
	GetProcessedMiniBlocksInfoCalled           func(metaBlockHash []byte) map[string]*processedMb.ProcessedMiniBlockInfo
	GetProcessedMiniBlockInfoCalled            func(miniBlockHash []byte) (*processedMb.ProcessedMiniBlockInfo, []byte)
	IsMiniBlockFullyProcessedCalled            func(metaBlockHash []byte, miniBlockHash []byte) bool
	ConvertProcessedMiniBlocksMapToSliceCalled func() []bootstrapStorage.MiniBlocksInMeta
	ConvertSliceToProcessedMiniBlocksMapCalled func(miniBlocksInMetaBlocks []bootstrapStorage.MiniBlocksInMeta)
	DisplayProcessedMiniBlocksCalled           func()
}

ProcessedMiniBlocksTrackerStub -

func (*ProcessedMiniBlocksTrackerStub) ConvertProcessedMiniBlocksMapToSlice

func (pmbts *ProcessedMiniBlocksTrackerStub) ConvertProcessedMiniBlocksMapToSlice() []bootstrapStorage.MiniBlocksInMeta

ConvertProcessedMiniBlocksMapToSlice -

func (*ProcessedMiniBlocksTrackerStub) ConvertSliceToProcessedMiniBlocksMap

func (pmbts *ProcessedMiniBlocksTrackerStub) ConvertSliceToProcessedMiniBlocksMap(miniBlocksInMetaBlocks []bootstrapStorage.MiniBlocksInMeta)

ConvertSliceToProcessedMiniBlocksMap -

func (*ProcessedMiniBlocksTrackerStub) DisplayProcessedMiniBlocks

func (pmbts *ProcessedMiniBlocksTrackerStub) DisplayProcessedMiniBlocks()

DisplayProcessedMiniBlocks -

func (*ProcessedMiniBlocksTrackerStub) GetProcessedMiniBlockInfo

func (pmbts *ProcessedMiniBlocksTrackerStub) GetProcessedMiniBlockInfo(miniBlockHash []byte) (*processedMb.ProcessedMiniBlockInfo, []byte)

GetProcessedMiniBlockInfo -

func (*ProcessedMiniBlocksTrackerStub) GetProcessedMiniBlocksInfo

func (pmbts *ProcessedMiniBlocksTrackerStub) GetProcessedMiniBlocksInfo(metaBlockHash []byte) map[string]*processedMb.ProcessedMiniBlockInfo

GetProcessedMiniBlocksInfo -

func (*ProcessedMiniBlocksTrackerStub) IsInterfaceNil

func (pmbts *ProcessedMiniBlocksTrackerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*ProcessedMiniBlocksTrackerStub) IsMiniBlockFullyProcessed

func (pmbts *ProcessedMiniBlocksTrackerStub) IsMiniBlockFullyProcessed(metaBlockHash []byte, miniBlockHash []byte) bool

IsMiniBlockFullyProcessed -

func (*ProcessedMiniBlocksTrackerStub) RemoveMetaBlockHash

func (pmbts *ProcessedMiniBlocksTrackerStub) RemoveMetaBlockHash(metaBlockHash []byte)

RemoveMetaBlockHash -

func (*ProcessedMiniBlocksTrackerStub) RemoveMiniBlockHash

func (pmbts *ProcessedMiniBlocksTrackerStub) RemoveMiniBlockHash(miniBlockHash []byte)

RemoveMiniBlockHash -

func (*ProcessedMiniBlocksTrackerStub) SetProcessedMiniBlockInfo

func (pmbts *ProcessedMiniBlocksTrackerStub) SetProcessedMiniBlockInfo(metaBlockHash []byte, miniBlockHash []byte, processedMbInfo *processedMb.ProcessedMiniBlockInfo)

SetProcessedMiniBlockInfo -

type ProtoMarshalizerMock

type ProtoMarshalizerMock struct {
}

ProtoMarshalizerMock implements marshaling with protobuf

func (*ProtoMarshalizerMock) IsInterfaceNil

func (pmm *ProtoMarshalizerMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*ProtoMarshalizerMock) Marshal

func (pmm *ProtoMarshalizerMock) Marshal(obj interface{}) ([]byte, error)

Marshal does the actual serialization of an object The object to be serialized must implement the gogoProtoObj interface

func (*ProtoMarshalizerMock) Unmarshal

func (pmm *ProtoMarshalizerMock) Unmarshal(obj interface{}, buff []byte) error

Unmarshal does the actual deserialization of an object The object to be deserialized must implement the gogoProtoObj interface

type ProtobufMarshalizerMock

type ProtobufMarshalizerMock struct {
}

ProtobufMarshalizerMock implements marshaling with protobuf

func (*ProtobufMarshalizerMock) IsInterfaceNil

func (x *ProtobufMarshalizerMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*ProtobufMarshalizerMock) Marshal

func (x *ProtobufMarshalizerMock) Marshal(obj interface{}) ([]byte, error)

Marshal does the actual serialization of an object through protobuf

func (*ProtobufMarshalizerMock) Unmarshal

func (x *ProtobufMarshalizerMock) Unmarshal(obj interface{}, buff []byte) error

Unmarshal does the actual deserialization of an object through protobuf

type PubkeyConverterMock

type PubkeyConverterMock struct {
	// contains filtered or unexported fields
}

PubkeyConverterMock -

func NewPubkeyConverterMock

func NewPubkeyConverterMock(addressLen int) *PubkeyConverterMock

NewPubkeyConverterMock -

func (*PubkeyConverterMock) Decode

func (pcm *PubkeyConverterMock) Decode(humanReadable string) ([]byte, error)

Decode -

func (*PubkeyConverterMock) Encode

func (pcm *PubkeyConverterMock) Encode(pkBytes []byte) string

Encode -

func (*PubkeyConverterMock) IsInterfaceNil

func (pcm *PubkeyConverterMock) IsInterfaceNil() bool

IsInterfaceNil -

func (*PubkeyConverterMock) Len

func (pcm *PubkeyConverterMock) Len() int

Len -

type RaterMock

type RaterMock struct {
	StartRating           uint32
	MinRating             uint32
	MaxRating             uint32
	Chance                uint32
	IncreaseProposer      int32
	DecreaseProposer      int32
	IncreaseValidator     int32
	DecreaseValidator     int32
	MetaIncreaseProposer  int32
	MetaDecreaseProposer  int32
	MetaIncreaseValidator int32
	MetaDecreaseValidator int32

	GetRatingCalled                func(string) uint32
	GetStartRatingCalled           func() uint32
	GetSignedBlocksThresholdCalled func() float32
	ComputeIncreaseProposerCalled  func(shardId uint32, rating uint32) uint32
	ComputeDecreaseProposerCalled  func(shardId uint32, rating uint32, consecutiveMissedBlocks uint32) uint32
	RevertIncreaseProposerCalled   func(shardId uint32, rating uint32, nrReverts uint32) uint32
	RevertIncreaseValidatorCalled  func(shardId uint32, rating uint32, nrReverts uint32) uint32
	ComputeIncreaseValidatorCalled func(shardId uint32, rating uint32) uint32
	ComputeDecreaseValidatorCalled func(shardId uint32, rating uint32) uint32
	GetChancesCalled               func(val uint32) uint32
}

RaterMock -

func GetNewMockRater

func GetNewMockRater() *RaterMock

GetNewMockRater -

func (*RaterMock) ComputeDecreaseProposer

func (rm *RaterMock) ComputeDecreaseProposer(shardId uint32, currentRating uint32, consecutiveMisses uint32) uint32

ComputeDecreaseProposer -

func (*RaterMock) ComputeDecreaseValidator

func (rm *RaterMock) ComputeDecreaseValidator(shardId uint32, currentRating uint32) uint32

ComputeDecreaseValidator -

func (*RaterMock) ComputeIncreaseProposer

func (rm *RaterMock) ComputeIncreaseProposer(shardId uint32, currentRating uint32) uint32

ComputeIncreaseProposer -

func (*RaterMock) ComputeIncreaseValidator

func (rm *RaterMock) ComputeIncreaseValidator(shardId uint32, currentRating uint32) uint32

ComputeIncreaseValidator -

func (*RaterMock) GetChance

func (rm *RaterMock) GetChance(rating uint32) uint32

GetChance -

func (*RaterMock) GetRating

func (rm *RaterMock) GetRating(pk string) uint32

GetRating -

func (*RaterMock) GetSignedBlocksThreshold

func (rm *RaterMock) GetSignedBlocksThreshold() float32

GetSignedBlocksThreshold -

func (*RaterMock) GetStartRating

func (rm *RaterMock) GetStartRating() uint32

GetStartRating -

func (*RaterMock) IsInterfaceNil

func (rm *RaterMock) IsInterfaceNil() bool

IsInterfaceNil -

func (*RaterMock) RevertIncreaseValidator

func (rm *RaterMock) RevertIncreaseValidator(shardId uint32, currentRating uint32, nrReverts uint32) uint32

RevertIncreaseValidator -

type RatingsInfoMock

type RatingsInfoMock struct {
	StartRatingProperty           uint32
	MaxRatingProperty             uint32
	MinRatingProperty             uint32
	SignedBlocksThresholdProperty float32
	MetaRatingsStepDataProperty   process.RatingsStepHandler
	ShardRatingsStepDataProperty  process.RatingsStepHandler
	SelectionChancesProperty      []process.SelectionChance
}

RatingsInfoMock -

func (*RatingsInfoMock) IsInterfaceNil

func (rd *RatingsInfoMock) IsInterfaceNil() bool

IsInterfaceNil -

func (*RatingsInfoMock) MaxRating

func (rd *RatingsInfoMock) MaxRating() uint32

MaxRating -

func (*RatingsInfoMock) MetaChainRatingsStepHandler

func (rd *RatingsInfoMock) MetaChainRatingsStepHandler() process.RatingsStepHandler

MetaChainRatingsStepHandler -

func (*RatingsInfoMock) MinRating

func (rd *RatingsInfoMock) MinRating() uint32

MinRating -

func (*RatingsInfoMock) SelectionChances

func (rd *RatingsInfoMock) SelectionChances() []process.SelectionChance

SelectionChances -

func (*RatingsInfoMock) ShardChainRatingsStepHandler

func (rd *RatingsInfoMock) ShardChainRatingsStepHandler() process.RatingsStepHandler

ShardChainRatingsStepHandler -

func (*RatingsInfoMock) SignedBlocksThreshold

func (rd *RatingsInfoMock) SignedBlocksThreshold() float32

SignedBlocksThreshold -

func (*RatingsInfoMock) StartRating

func (rd *RatingsInfoMock) StartRating() uint32

StartRating -

type ReceiptsRepositoryStub

type ReceiptsRepositoryStub struct {
	SaveReceiptsCalled func(holder common.ReceiptsHolder, header data.HeaderHandler, headerHash []byte) error
	LoadReceiptsCalled func(header data.HeaderHandler, headerHash []byte) (common.ReceiptsHolder, error)
}

ReceiptsRepositoryStub -

func (*ReceiptsRepositoryStub) IsInterfaceNil

func (stub *ReceiptsRepositoryStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*ReceiptsRepositoryStub) LoadReceipts

func (stub *ReceiptsRepositoryStub) LoadReceipts(header data.HeaderHandler, headerHash []byte) (common.ReceiptsHolder, error)

LoadReceipts -

func (*ReceiptsRepositoryStub) SaveReceipts

func (stub *ReceiptsRepositoryStub) SaveReceipts(holder common.ReceiptsHolder, header data.HeaderHandler, headerHash []byte) error

SaveReceipts -

type RequestHandlerStub

type RequestHandlerStub struct {
	RequestShardHeaderCalled                 func(shardID uint32, hash []byte)
	RequestMetaHeaderCalled                  func(hash []byte)
	RequestMetaHeaderByNonceCalled           func(nonce uint64)
	RequestShardHeaderByNonceCalled          func(shardID uint32, nonce uint64)
	RequestTransactionHandlerCalled          func(destShardID uint32, txHashes [][]byte)
	RequestScrHandlerCalled                  func(destShardID uint32, txHashes [][]byte)
	RequestRewardTxHandlerCalled             func(destShardID uint32, txHashes [][]byte)
	RequestMiniBlockHandlerCalled            func(destShardID uint32, miniblockHash []byte)
	RequestMiniBlocksHandlerCalled           func(destShardID uint32, miniblocksHashes [][]byte)
	RequestTrieNodesCalled                   func(destShardID uint32, hashes [][]byte, topic string)
	RequestStartOfEpochMetaBlockCalled       func(epoch uint32)
	SetNumPeersToQueryCalled                 func(key string, intra int, cross int) error
	GetNumPeersToQueryCalled                 func(key string) (int, int, error)
	RequestTrieNodeCalled                    func(requestHash []byte, topic string, chunkIndex uint32)
	CreateTrieNodeIdentifierCalled           func(requestHash []byte, chunkIndex uint32) []byte
	RequestPeerAuthenticationsByHashesCalled func(destShardID uint32, hashes [][]byte)
}

RequestHandlerStub -

func (*RequestHandlerStub) CreateTrieNodeIdentifier

func (rhs *RequestHandlerStub) CreateTrieNodeIdentifier(requestHash []byte, chunkIndex uint32) []byte

CreateTrieNodeIdentifier -

func (*RequestHandlerStub) GetNumPeersToQuery

func (rhs *RequestHandlerStub) GetNumPeersToQuery(key string) (int, int, error)

GetNumPeersToQuery -

func (*RequestHandlerStub) IsInterfaceNil

func (rhs *RequestHandlerStub) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*RequestHandlerStub) RequestInterval

func (rhs *RequestHandlerStub) RequestInterval() time.Duration

RequestInterval -

func (*RequestHandlerStub) RequestMetaHeader

func (rhs *RequestHandlerStub) RequestMetaHeader(hash []byte)

RequestMetaHeader -

func (*RequestHandlerStub) RequestMetaHeaderByNonce

func (rhs *RequestHandlerStub) RequestMetaHeaderByNonce(nonce uint64)

RequestMetaHeaderByNonce -

func (*RequestHandlerStub) RequestMiniBlock

func (rhs *RequestHandlerStub) RequestMiniBlock(destShardID uint32, miniblockHash []byte)

RequestMiniBlock -

func (*RequestHandlerStub) RequestMiniBlocks

func (rhs *RequestHandlerStub) RequestMiniBlocks(destShardID uint32, miniblocksHashes [][]byte)

RequestMiniBlocks -

func (*RequestHandlerStub) RequestPeerAuthenticationsByHashes

func (rhs *RequestHandlerStub) RequestPeerAuthenticationsByHashes(destShardID uint32, hashes [][]byte)

RequestPeerAuthenticationsByHashes -

func (*RequestHandlerStub) RequestRewardTransactions

func (rhs *RequestHandlerStub) RequestRewardTransactions(destShardID uint32, txHashes [][]byte)

RequestRewardTransactions -

func (*RequestHandlerStub) RequestShardHeader

func (rhs *RequestHandlerStub) RequestShardHeader(shardID uint32, hash []byte)

RequestShardHeader -

func (*RequestHandlerStub) RequestShardHeaderByNonce

func (rhs *RequestHandlerStub) RequestShardHeaderByNonce(shardID uint32, nonce uint64)

RequestShardHeaderByNonce -

func (*RequestHandlerStub) RequestStartOfEpochMetaBlock

func (rhs *RequestHandlerStub) RequestStartOfEpochMetaBlock(epoch uint32)

RequestStartOfEpochMetaBlock -

func (*RequestHandlerStub) RequestTransaction

func (rhs *RequestHandlerStub) RequestTransaction(destShardID uint32, txHashes [][]byte)

RequestTransaction -

func (*RequestHandlerStub) RequestTrieNode

func (rhs *RequestHandlerStub) RequestTrieNode(requestHash []byte, topic string, chunkIndex uint32)

RequestTrieNode -

func (*RequestHandlerStub) RequestTrieNodes

func (rhs *RequestHandlerStub) RequestTrieNodes(destShardID uint32, hashes [][]byte, topic string)

RequestTrieNodes -

func (*RequestHandlerStub) RequestUnsignedTransactions

func (rhs *RequestHandlerStub) RequestUnsignedTransactions(destShardID uint32, txHashes [][]byte)

RequestUnsignedTransactions -

func (*RequestHandlerStub) SetEpoch

func (rhs *RequestHandlerStub) SetEpoch(_ uint32)

SetEpoch -

func (*RequestHandlerStub) SetNumPeersToQuery

func (rhs *RequestHandlerStub) SetNumPeersToQuery(key string, intra int, cross int) error

SetNumPeersToQuery -

type RequestedItemsHandlerStub

type RequestedItemsHandlerStub struct {
	AddCalled   func(key string) error
	HasCalled   func(key string) bool
	SweepCalled func()
}

RequestedItemsHandlerStub -

func (*RequestedItemsHandlerStub) Add

func (rihs *RequestedItemsHandlerStub) Add(key string) error

Add -

func (*RequestedItemsHandlerStub) Has

func (rihs *RequestedItemsHandlerStub) Has(key string) bool

Has -

func (*RequestedItemsHandlerStub) IsInterfaceNil

func (rihs *RequestedItemsHandlerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*RequestedItemsHandlerStub) Sweep

func (rihs *RequestedItemsHandlerStub) Sweep()

Sweep -

type RewardTxProcessorMock

type RewardTxProcessorMock struct {
	ProcessRewardTransactionCalled func(rTx *rewardTx.RewardTx) error
}

RewardTxProcessorMock -

func (*RewardTxProcessorMock) IsInterfaceNil

func (scrp *RewardTxProcessorMock) IsInterfaceNil() bool

IsInterfaceNil -

func (*RewardTxProcessorMock) ProcessRewardTransaction

func (scrp *RewardTxProcessorMock) ProcessRewardTransaction(rTx *rewardTx.RewardTx) error

ProcessRewardTransaction -

type RoundHandlerMock

type RoundHandlerMock struct {
	IndexCalled         func() int64
	TimeDurationCalled  func() time.Duration
	TimeStampCalled     func() time.Time
	UpdateRoundCalled   func(time.Time, time.Time)
	RemainingTimeCalled func(startTime time.Time, maxTime time.Duration) time.Duration
	BeforeGenesisCalled func() bool
	// contains filtered or unexported fields
}

RoundHandlerMock -

func (*RoundHandlerMock) BeforeGenesis

func (rndm *RoundHandlerMock) BeforeGenesis() bool

BeforeGenesis -

func (*RoundHandlerMock) Index

func (rndm *RoundHandlerMock) Index() int64

Index -

func (*RoundHandlerMock) IsInterfaceNil

func (rndm *RoundHandlerMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*RoundHandlerMock) RemainingTime

func (rndm *RoundHandlerMock) RemainingTime(startTime time.Time, maxTime time.Duration) time.Duration

RemainingTime -

func (*RoundHandlerMock) TimeDuration

func (rndm *RoundHandlerMock) TimeDuration() time.Duration

TimeDuration -

func (*RoundHandlerMock) TimeStamp

func (rndm *RoundHandlerMock) TimeStamp() time.Time

TimeStamp -

func (*RoundHandlerMock) UpdateRound

func (rndm *RoundHandlerMock) UpdateRound(genesisRoundTimeStamp time.Time, timeStamp time.Time)

UpdateRound -

type SCProcessorMock

type SCProcessorMock struct {
	ComputeTransactionTypeCalled          func(tx data.TransactionHandler) (process.TransactionType, process.TransactionType)
	ExecuteSmartContractTransactionCalled func(tx data.TransactionHandler, acntSrc, acntDst state.UserAccountHandler) (vmcommon.ReturnCode, error)
	ExecuteBuiltInFunctionCalled          func(tx data.TransactionHandler, acntSrc, acntDst state.UserAccountHandler) (vmcommon.ReturnCode, error)
	DeploySmartContractCalled             func(tx data.TransactionHandler, acntSrc state.UserAccountHandler) (vmcommon.ReturnCode, error)
	ProcessSmartContractResultCalled      func(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)
	ProcessIfErrorCalled                  func(acntSnd state.UserAccountHandler, txHash []byte, tx data.TransactionHandler, returnCode string, returnMessage []byte, snapshot int, gasLocked uint64) error
	IsPayableCalled                       func(sndAddress, recvAddress []byte) (bool, error)
}

SCProcessorMock -

func (*SCProcessorMock) ComputeTransactionType

ComputeTransactionType -

func (*SCProcessorMock) DeploySmartContract

func (sc *SCProcessorMock) DeploySmartContract(tx data.TransactionHandler, acntSrc state.UserAccountHandler) (vmcommon.ReturnCode, error)

DeploySmartContract -

func (*SCProcessorMock) ExecuteBuiltInFunction

func (sc *SCProcessorMock) ExecuteBuiltInFunction(
	tx data.TransactionHandler,
	acntSrc, acntDst state.UserAccountHandler,
) (vmcommon.ReturnCode, error)

ExecuteBuiltInFunction -

func (*SCProcessorMock) ExecuteSmartContractTransaction

func (sc *SCProcessorMock) ExecuteSmartContractTransaction(
	tx data.TransactionHandler,
	acntSrc, acntDst state.UserAccountHandler,
) (vmcommon.ReturnCode, error)

ExecuteSmartContractTransaction -

func (*SCProcessorMock) IsInterfaceNil

func (sc *SCProcessorMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*SCProcessorMock) IsPayable

func (sc *SCProcessorMock) IsPayable(sndAddress []byte, recvAddress []byte) (bool, error)

IsPayable -

func (*SCProcessorMock) ProcessIfError

func (sc *SCProcessorMock) ProcessIfError(
	acntSnd state.UserAccountHandler,
	txHash []byte,
	tx data.TransactionHandler,
	returnCode string,
	returnMessage []byte,
	snapshot int,
	gasLocked uint64,
) error

ProcessIfError -

func (*SCProcessorMock) ProcessSmartContractResult

func (sc *SCProcessorMock) ProcessSmartContractResult(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)

ProcessSmartContractResult -

type ScheduledTxsExecutionStub

type ScheduledTxsExecutionStub struct {
	InitCalled                                   func()
	AddScheduledTxCalled                         func([]byte, data.TransactionHandler) bool
	AddScheduledMiniBlocksCalled                 func(miniBlocks block.MiniBlockSlice)
	ExecuteCalled                                func([]byte) error
	ExecuteAllCalled                             func(func() time.Duration) error
	GetScheduledIntermediateTxsCalled            func() map[block.Type][]data.TransactionHandler
	GetScheduledMiniBlocksCalled                 func() block.MiniBlockSlice
	SetScheduledInfoCalled                       func(scheduledInfo *process.ScheduledInfo)
	GetScheduledRootHashForHeaderCalled          func(headerHash []byte) ([]byte, error)
	GetScheduledRootHashForHeaderWithEpochCalled func(headerHash []byte, epoch uint32) ([]byte, error)
	RollBackToBlockCalled                        func(headerHash []byte) error
	GetScheduledRootHashCalled                   func() []byte
	GetScheduledGasAndFeesCalled                 func() scheduled.GasAndFees
	SetScheduledRootHashCalled                   func([]byte)
	SetScheduledGasAndFeesCalled                 func(gasAndFees scheduled.GasAndFees)
	SetTransactionProcessorCalled                func(process.TransactionProcessor)
	SetTransactionCoordinatorCalled              func(process.TransactionCoordinator)
	HaveScheduledTxsCalled                       func() bool
	SaveStateIfNeededCalled                      func(headerHash []byte)
	SaveStateCalled                              func(headerHash []byte, scheduledInfo *process.ScheduledInfo)
	LoadStateCalled                              func(headerHash []byte)
	IsScheduledTxCalled                          func([]byte) bool
	IsMiniBlockExecutedCalled                    func([]byte) bool
}

ScheduledTxsExecutionStub -

func (*ScheduledTxsExecutionStub) AddScheduledMiniBlocks

func (stes *ScheduledTxsExecutionStub) AddScheduledMiniBlocks(miniBlocks block.MiniBlockSlice)

AddScheduledMiniBlocks -

func (*ScheduledTxsExecutionStub) AddScheduledTx

func (stes *ScheduledTxsExecutionStub) AddScheduledTx(txHash []byte, tx data.TransactionHandler) bool

AddScheduledTx -

func (*ScheduledTxsExecutionStub) Execute

func (stes *ScheduledTxsExecutionStub) Execute(txHash []byte) error

Execute -

func (*ScheduledTxsExecutionStub) ExecuteAll

func (stes *ScheduledTxsExecutionStub) ExecuteAll(haveTime func() time.Duration) error

ExecuteAll -

func (*ScheduledTxsExecutionStub) GetScheduledGasAndFees

func (stes *ScheduledTxsExecutionStub) GetScheduledGasAndFees() scheduled.GasAndFees

GetScheduledGasAndFees returns the scheduled SC calls gas and fees

func (*ScheduledTxsExecutionStub) GetScheduledIntermediateTxs

func (stes *ScheduledTxsExecutionStub) GetScheduledIntermediateTxs() map[block.Type][]data.TransactionHandler

GetScheduledIntermediateTxs -

func (*ScheduledTxsExecutionStub) GetScheduledMiniBlocks

func (stes *ScheduledTxsExecutionStub) GetScheduledMiniBlocks() block.MiniBlockSlice

GetScheduledMiniBlocks -

func (*ScheduledTxsExecutionStub) GetScheduledRootHash

func (stes *ScheduledTxsExecutionStub) GetScheduledRootHash() []byte

GetScheduledRootHash -

func (*ScheduledTxsExecutionStub) GetScheduledRootHashForHeader

func (stes *ScheduledTxsExecutionStub) GetScheduledRootHashForHeader(headerHash []byte) ([]byte, error)

GetScheduledRootHashForHeader -

func (*ScheduledTxsExecutionStub) GetScheduledRootHashForHeaderWithEpoch

func (stes *ScheduledTxsExecutionStub) GetScheduledRootHashForHeaderWithEpoch(headerHash []byte, epoch uint32) ([]byte, error)

GetScheduledRootHashForHeaderWithEpoch -

func (*ScheduledTxsExecutionStub) Init

func (stes *ScheduledTxsExecutionStub) Init()

Init -

func (*ScheduledTxsExecutionStub) IsInterfaceNil

func (stes *ScheduledTxsExecutionStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*ScheduledTxsExecutionStub) IsMiniBlockExecuted

func (stes *ScheduledTxsExecutionStub) IsMiniBlockExecuted(mbHash []byte) bool

IsMiniBlockExecuted -

func (*ScheduledTxsExecutionStub) IsScheduledTx

func (stes *ScheduledTxsExecutionStub) IsScheduledTx(txHash []byte) bool

IsScheduledTx -

func (*ScheduledTxsExecutionStub) RollBackToBlock

func (stes *ScheduledTxsExecutionStub) RollBackToBlock(headerHash []byte) error

RollBackToBlock -

func (*ScheduledTxsExecutionStub) SaveState

func (stes *ScheduledTxsExecutionStub) SaveState(
	headerHash []byte,
	scheduledInfo *process.ScheduledInfo,
)

SaveState -

func (*ScheduledTxsExecutionStub) SaveStateIfNeeded

func (stes *ScheduledTxsExecutionStub) SaveStateIfNeeded(headerHash []byte)

SaveStateIfNeeded -

func (*ScheduledTxsExecutionStub) SetScheduledGasAndFees

func (stes *ScheduledTxsExecutionStub) SetScheduledGasAndFees(gasAndFees scheduled.GasAndFees)

SetScheduledGasAndFees -

func (*ScheduledTxsExecutionStub) SetScheduledInfo

func (stes *ScheduledTxsExecutionStub) SetScheduledInfo(scheduledInfo *process.ScheduledInfo)

SetScheduledInfo -

func (*ScheduledTxsExecutionStub) SetScheduledRootHash

func (stes *ScheduledTxsExecutionStub) SetScheduledRootHash(rootHash []byte)

SetScheduledRootHash -

func (*ScheduledTxsExecutionStub) SetTransactionCoordinator

func (stes *ScheduledTxsExecutionStub) SetTransactionCoordinator(txCoordinator process.TransactionCoordinator)

SetTransactionCoordinator -

func (*ScheduledTxsExecutionStub) SetTransactionProcessor

func (stes *ScheduledTxsExecutionStub) SetTransactionProcessor(txProcessor process.TransactionProcessor)

SetTransactionProcessor -

type ShardStatisticsMock

type ShardStatisticsMock struct {
	// contains filtered or unexported fields
}

ShardStatisticsMock will hold the tps statistics for each shard

func (*ShardStatisticsMock) AverageBlockTxCount

func (ss *ShardStatisticsMock) AverageBlockTxCount() uint32

AverageBlockTxCount returns an average transaction count for

func (*ShardStatisticsMock) AverageTPS

func (ss *ShardStatisticsMock) AverageTPS() *big.Int

AverageTPS returns an average tps for all processed blocks in a shard

func (*ShardStatisticsMock) CurrentBlockNonce

func (ss *ShardStatisticsMock) CurrentBlockNonce() uint64

CurrentBlockNonce returns the block nounce of the last processed block in a shard

func (*ShardStatisticsMock) IsInterfaceNil

func (ss *ShardStatisticsMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*ShardStatisticsMock) LastBlockTxCount

func (ss *ShardStatisticsMock) LastBlockTxCount() uint32

LastBlockTxCount returns the number of transactions included in the last block

func (*ShardStatisticsMock) LiveTPS

func (ss *ShardStatisticsMock) LiveTPS() float64

LiveTPS returns tps for the last block

func (*ShardStatisticsMock) PeakTPS

func (ss *ShardStatisticsMock) PeakTPS() float64

PeakTPS returns peak tps for for all the blocks of the current shard

func (*ShardStatisticsMock) ShardID

func (ss *ShardStatisticsMock) ShardID() uint32

ShardID returns the shard id of the current statistic object

func (*ShardStatisticsMock) TotalProcessedTxCount

func (ss *ShardStatisticsMock) TotalProcessedTxCount() *big.Int

TotalProcessedTxCount returns the total number of processed transactions for this shard

type ShardedDataCacheNotifierMock

type ShardedDataCacheNotifierMock struct {
	// contains filtered or unexported fields
}

ShardedDataCacheNotifierMock -

func NewShardedDataCacheNotifierMock

func NewShardedDataCacheNotifierMock() *ShardedDataCacheNotifierMock

NewShardedDataCacheNotifierMock -

func (*ShardedDataCacheNotifierMock) AddData

func (mock *ShardedDataCacheNotifierMock) AddData(key []byte, data interface{}, sizeInBytes int, cacheId string)

AddData -

func (*ShardedDataCacheNotifierMock) Clear

func (mock *ShardedDataCacheNotifierMock) Clear()

Clear -

func (*ShardedDataCacheNotifierMock) ClearShardStore

func (mock *ShardedDataCacheNotifierMock) ClearShardStore(cacheId string)

ClearShardStore -

func (*ShardedDataCacheNotifierMock) GetCounts

GetCounts -

func (*ShardedDataCacheNotifierMock) ImmunizeSetOfDataAgainstEviction

func (mock *ShardedDataCacheNotifierMock) ImmunizeSetOfDataAgainstEviction(_ [][]byte, _ string)

ImmunizeSetOfDataAgainstEviction -

func (*ShardedDataCacheNotifierMock) IsInterfaceNil

func (mock *ShardedDataCacheNotifierMock) IsInterfaceNil() bool

IsInterfaceNil -

func (*ShardedDataCacheNotifierMock) Keys

func (mock *ShardedDataCacheNotifierMock) Keys() [][]byte

Keys -

func (*ShardedDataCacheNotifierMock) MergeShardStores

func (mock *ShardedDataCacheNotifierMock) MergeShardStores(_, _ string)

MergeShardStores -

func (*ShardedDataCacheNotifierMock) RegisterOnAdded

func (mock *ShardedDataCacheNotifierMock) RegisterOnAdded(_ func(key []byte, value interface{}))

RegisterOnAdded -

func (*ShardedDataCacheNotifierMock) RemoveData

func (mock *ShardedDataCacheNotifierMock) RemoveData(key []byte, cacheId string)

RemoveData -

func (*ShardedDataCacheNotifierMock) RemoveDataFromAllShards

func (mock *ShardedDataCacheNotifierMock) RemoveDataFromAllShards(key []byte)

RemoveDataFromAllShards -

func (*ShardedDataCacheNotifierMock) RemoveSetOfDataFromPool

func (mock *ShardedDataCacheNotifierMock) RemoveSetOfDataFromPool(keys [][]byte, cacheId string)

RemoveSetOfDataFromPool -

func (*ShardedDataCacheNotifierMock) SearchFirstData

func (mock *ShardedDataCacheNotifierMock) SearchFirstData(key []byte) (interface{}, bool)

SearchFirstData -

func (*ShardedDataCacheNotifierMock) ShardDataStore

func (mock *ShardedDataCacheNotifierMock) ShardDataStore(cacheId string) (c storage.Cacher)

ShardDataStore -

type ShardedDataStub

type ShardedDataStub struct {
	RegisterOnAddedCalled                  func(func(key []byte, value interface{}))
	ShardDataStoreCalled                   func(cacheID string) storage.Cacher
	AddDataCalled                          func(key []byte, data interface{}, sizeInBytes int, cacheID string)
	SearchFirstDataCalled                  func(key []byte) (value interface{}, ok bool)
	RemoveDataCalled                       func(key []byte, cacheID string)
	RemoveDataFromAllShardsCalled          func(key []byte)
	MergeShardStoresCalled                 func(sourceCacheID, destCacheID string)
	MoveDataCalled                         func(sourceCacheID, destCacheID string, key [][]byte)
	ClearCalled                            func()
	ClearShardStoreCalled                  func(cacheID string)
	RemoveSetOfDataFromPoolCalled          func(keys [][]byte, destCacheID string)
	ImmunizeSetOfDataAgainstEvictionCalled func(keys [][]byte, cacheID string)
	CreateShardStoreCalled                 func(destCacheID string)
	GetCountsCalled                        func() counting.CountsWithSize
	KeysCalled                             func() [][]byte
}

ShardedDataStub -

func NewShardedDataStub

func NewShardedDataStub() *ShardedDataStub

NewShardedDataStub -

func (*ShardedDataStub) AddData

func (sd *ShardedDataStub) AddData(key []byte, data interface{}, sizeInBytes int, cacheID string)

AddData -

func (*ShardedDataStub) Clear

func (sd *ShardedDataStub) Clear()

Clear -

func (*ShardedDataStub) ClearShardStore

func (sd *ShardedDataStub) ClearShardStore(cacheID string)

ClearShardStore -

func (*ShardedDataStub) GetCounts

func (sd *ShardedDataStub) GetCounts() counting.CountsWithSize

GetCounts -

func (*ShardedDataStub) ImmunizeSetOfDataAgainstEviction

func (sd *ShardedDataStub) ImmunizeSetOfDataAgainstEviction(keys [][]byte, cacheID string)

ImmunizeSetOfDataAgainstEviction -

func (*ShardedDataStub) IsInterfaceNil

func (sd *ShardedDataStub) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*ShardedDataStub) Keys

func (sd *ShardedDataStub) Keys() [][]byte

Keys -

func (*ShardedDataStub) MergeShardStores

func (sd *ShardedDataStub) MergeShardStores(sourceCacheID, destCacheID string)

MergeShardStores -

func (*ShardedDataStub) RegisterOnAdded

func (sd *ShardedDataStub) RegisterOnAdded(handler func(key []byte, value interface{}))

RegisterOnAdded -

func (*ShardedDataStub) RemoveData

func (sd *ShardedDataStub) RemoveData(key []byte, cacheID string)

RemoveData -

func (*ShardedDataStub) RemoveDataFromAllShards

func (sd *ShardedDataStub) RemoveDataFromAllShards(key []byte)

RemoveDataFromAllShards -

func (*ShardedDataStub) RemoveSetOfDataFromPool

func (sd *ShardedDataStub) RemoveSetOfDataFromPool(keys [][]byte, cacheID string)

RemoveSetOfDataFromPool -

func (*ShardedDataStub) SearchFirstData

func (sd *ShardedDataStub) SearchFirstData(key []byte) (value interface{}, ok bool)

SearchFirstData -

func (*ShardedDataStub) ShardDataStore

func (sd *ShardedDataStub) ShardDataStore(cacheID string) storage.Cacher

ShardDataStore -

type ShardsCoordinatorMock

type ShardsCoordinatorMock struct {
	NoShards        uint32
	CurrentShard    uint32
	ComputeIdCalled func(address []byte) uint32
	SelfIDCalled    func() uint32
}

ShardsCoordinatorMock -

func NewMultiShardsCoordinatorMock

func NewMultiShardsCoordinatorMock(numShards uint32) *ShardsCoordinatorMock

NewMultiShardsCoordinatorMock -

func (*ShardsCoordinatorMock) CommunicationIdentifier

func (scm *ShardsCoordinatorMock) CommunicationIdentifier(destShardID uint32) string

CommunicationIdentifier returns the identifier between current shard ID and destination shard ID identifier is generated such as the first shard from identifier is always smaller than the last

func (*ShardsCoordinatorMock) ComputeId

func (scm *ShardsCoordinatorMock) ComputeId(address []byte) uint32

ComputeId -

func (*ShardsCoordinatorMock) IsInterfaceNil

func (scm *ShardsCoordinatorMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*ShardsCoordinatorMock) NumberOfShards

func (scm *ShardsCoordinatorMock) NumberOfShards() uint32

NumberOfShards -

func (*ShardsCoordinatorMock) SameShard

func (scm *ShardsCoordinatorMock) SameShard(_, _ []byte) bool

SameShard -

func (*ShardsCoordinatorMock) SelfId

func (scm *ShardsCoordinatorMock) SelfId() uint32

SelfId -

func (*ShardsCoordinatorMock) SetNoShards

func (scm *ShardsCoordinatorMock) SetNoShards(noShards uint32)

SetNoShards -

func (*ShardsCoordinatorMock) SetSelfId

func (scm *ShardsCoordinatorMock) SetSelfId(_ uint32) error

SetSelfId -

type SimpleNFTStorageHandlerStub

type SimpleNFTStorageHandlerStub struct {
	GetESDTNFTTokenOnDestinationCalled   func(accnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64) (*esdt.ESDigitalToken, bool, error)
	SaveNFTMetaDataToSystemAccountCalled func(tx data.TransactionHandler) error
}

SimpleNFTStorageHandlerStub -

func (*SimpleNFTStorageHandlerStub) GetESDTNFTTokenOnDestination

func (s *SimpleNFTStorageHandlerStub) GetESDTNFTTokenOnDestination(accnt vmcommon.UserAccountHandler, esdtTokenKey []byte, nonce uint64) (*esdt.ESDigitalToken, bool, error)

GetESDTNFTTokenOnDestination -

func (*SimpleNFTStorageHandlerStub) IsInterfaceNil

func (s *SimpleNFTStorageHandlerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*SimpleNFTStorageHandlerStub) SaveNFTMetaDataToSystemAccount

func (s *SimpleNFTStorageHandlerStub) SaveNFTMetaDataToSystemAccount(tx data.TransactionHandler) error

SaveNFTMetaDataToSystemAccount -

type SmartContractResultsProcessorMock

type SmartContractResultsProcessorMock struct {
	ProcessSmartContractResultCalled func(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)
}

SmartContractResultsProcessorMock -

func (*SmartContractResultsProcessorMock) IsInterfaceNil

func (scrp *SmartContractResultsProcessorMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*SmartContractResultsProcessorMock) ProcessSmartContractResult

ProcessSmartContractResult -

type SnapshotPruningStorerMock

type SnapshotPruningStorerMock struct {
	*MemDbMock
}

SnapshotPruningStorerMock -

func NewSnapshotPruningStorerMock

func NewSnapshotPruningStorerMock() *SnapshotPruningStorerMock

NewSnapshotPruningStorerMock -

func (*SnapshotPruningStorerMock) GetFromCurrentEpoch

func (spsm *SnapshotPruningStorerMock) GetFromCurrentEpoch(key []byte) ([]byte, error)

GetFromCurrentEpoch -

func (*SnapshotPruningStorerMock) GetFromEpoch

func (spsm *SnapshotPruningStorerMock) GetFromEpoch(key []byte, _ uint32) ([]byte, error)

GetFromEpoch -

func (*SnapshotPruningStorerMock) GetFromLastEpoch

func (spsm *SnapshotPruningStorerMock) GetFromLastEpoch(key []byte) ([]byte, error)

GetFromLastEpoch -

func (*SnapshotPruningStorerMock) GetFromOldEpochsWithoutAddingToCache

func (spsm *SnapshotPruningStorerMock) GetFromOldEpochsWithoutAddingToCache(key []byte) ([]byte, error)

GetFromOldEpochsWithoutAddingToCache -

func (*SnapshotPruningStorerMock) GetLatestStorageEpoch

func (spsm *SnapshotPruningStorerMock) GetLatestStorageEpoch() (uint32, error)

GetLatestStorageEpoch -

func (*SnapshotPruningStorerMock) PutInEpoch

func (spsm *SnapshotPruningStorerMock) PutInEpoch(key []byte, data []byte, _ uint32) error

PutInEpoch -

func (*SnapshotPruningStorerMock) PutInEpochWithoutCache

func (spsm *SnapshotPruningStorerMock) PutInEpochWithoutCache(key []byte, data []byte, _ uint32) error

PutInEpochWithoutCache -

func (*SnapshotPruningStorerMock) RemoveFromCurrentEpoch

func (spsm *SnapshotPruningStorerMock) RemoveFromCurrentEpoch(key []byte) error

RemoveFromCurrentEpoch -

type StateComponentsMock

type StateComponentsMock struct {
	PeersAcc        state.AccountsAdapter
	Accounts        state.AccountsAdapter
	AccountsAPI     state.AccountsAdapter
	AccountsRepo    state.AccountsRepository
	Tries           common.TriesHolder
	StorageManagers map[string]common.StorageManager
}

StateComponentsMock -

func (*StateComponentsMock) AccountsAdapter

func (scm *StateComponentsMock) AccountsAdapter() state.AccountsAdapter

AccountsAdapter -

func (*StateComponentsMock) AccountsAdapterAPI

func (scm *StateComponentsMock) AccountsAdapterAPI() state.AccountsAdapter

AccountsAdapterAPI -

func (*StateComponentsMock) AccountsRepository

func (scm *StateComponentsMock) AccountsRepository() state.AccountsRepository

AccountsRepository -

func (*StateComponentsMock) CheckSubcomponents

func (scm *StateComponentsMock) CheckSubcomponents() error

CheckSubcomponents -

func (*StateComponentsMock) Close

func (scm *StateComponentsMock) Close() error

Close -

func (*StateComponentsMock) Create

func (scm *StateComponentsMock) Create() error

Create -

func (*StateComponentsMock) IsInterfaceNil

func (scm *StateComponentsMock) IsInterfaceNil() bool

IsInterfaceNil -

func (*StateComponentsMock) PeerAccounts

func (scm *StateComponentsMock) PeerAccounts() state.AccountsAdapter

PeerAccounts -

func (*StateComponentsMock) String

func (scm *StateComponentsMock) String() string

String -

func (*StateComponentsMock) TrieStorageManagers

func (scm *StateComponentsMock) TrieStorageManagers() map[string]common.StorageManager

TrieStorageManagers -

func (*StateComponentsMock) TriesContainer

func (scm *StateComponentsMock) TriesContainer() common.TriesHolder

TriesContainer -

type StatusMetricsStub

type StatusMetricsStub struct {
	StatusMetricsMapWithoutP2PCalled              func() (map[string]interface{}, error)
	StatusP2pMetricsMapCalled                     func() (map[string]interface{}, error)
	ConfigMetricsCalled                           func() (map[string]interface{}, error)
	NetworkMetricsCalled                          func() (map[string]interface{}, error)
	EconomicsMetricsCalled                        func() (map[string]interface{}, error)
	EnableEpochsMetricsCalled                     func() (map[string]interface{}, error)
	RatingsMetricsCalled                          func() (map[string]interface{}, error)
	StatusMetricsWithoutP2PPrometheusStringCalled func() (string, error)
}

StatusMetricsStub -

func (*StatusMetricsStub) ConfigMetrics

func (sms *StatusMetricsStub) ConfigMetrics() (map[string]interface{}, error)

ConfigMetrics -

func (*StatusMetricsStub) EconomicsMetrics

func (sms *StatusMetricsStub) EconomicsMetrics() (map[string]interface{}, error)

EconomicsMetrics -

func (*StatusMetricsStub) EnableEpochsMetrics

func (sms *StatusMetricsStub) EnableEpochsMetrics() (map[string]interface{}, error)

EnableEpochsMetrics -

func (*StatusMetricsStub) IsInterfaceNil

func (sms *StatusMetricsStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*StatusMetricsStub) NetworkMetrics

func (sms *StatusMetricsStub) NetworkMetrics() (map[string]interface{}, error)

NetworkMetrics -

func (*StatusMetricsStub) RatingsMetrics

func (sms *StatusMetricsStub) RatingsMetrics() (map[string]interface{}, error)

RatingsConfig -

func (*StatusMetricsStub) StatusMetricsMapWithoutP2P

func (sms *StatusMetricsStub) StatusMetricsMapWithoutP2P() (map[string]interface{}, error)

StatusMetricsMapWithoutP2P -

func (*StatusMetricsStub) StatusMetricsWithoutP2PPrometheusString

func (sms *StatusMetricsStub) StatusMetricsWithoutP2PPrometheusString() (string, error)

StatusMetricsWithoutP2PPrometheusString -

func (*StatusMetricsStub) StatusP2pMetricsMap

func (sms *StatusMetricsStub) StatusP2pMetricsMap() (map[string]interface{}, error)

StatusP2pMetricsMap -

type StorageManagerStub

type StorageManagerStub struct {
	PutCalled                              func([]byte, []byte) error
	PutInEpochCalled                       func([]byte, []byte, uint32) error
	PutInEpochWithoutCacheCalled           func([]byte, []byte, uint32) error
	GetCalled                              func([]byte) ([]byte, error)
	GetFromCurrentEpochCalled              func([]byte) ([]byte, error)
	TakeSnapshotCalled                     func([]byte, []byte, chan core.KeyValueHolder, chan error, common.SnapshotStatisticsHandler, uint32)
	SetCheckpointCalled                    func([]byte, []byte, chan core.KeyValueHolder, chan error, common.SnapshotStatisticsHandler)
	GetDbThatContainsHashCalled            func([]byte) common.DBWriteCacher
	IsPruningEnabledCalled                 func() bool
	IsPruningBlockedCalled                 func() bool
	EnterPruningBufferingModeCalled        func()
	ExitPruningBufferingModeCalled         func()
	AddDirtyCheckpointHashesCalled         func([]byte, common.ModifiedHashes) bool
	RemoveFromCurrentEpochCalled           func([]byte) error
	RemoveCalled                           func([]byte) error
	IsInterfaceNilCalled                   func() bool
	SetEpochForPutOperationCalled          func(uint32)
	ShouldTakeSnapshotCalled               func() bool
	GetLatestStorageEpochCalled            func() (uint32, error)
	IsClosedCalled                         func() bool
	RemoveFromCheckpointHashesHolderCalled func([]byte)
	GetBaseTrieStorageManagerCalled        func() common.StorageManager
}

StorageManagerStub -

func (*StorageManagerStub) AddDirtyCheckpointHashes

func (sms *StorageManagerStub) AddDirtyCheckpointHashes(rootHash []byte, hashes common.ModifiedHashes) bool

AddDirtyCheckpointHashes -

func (*StorageManagerStub) Close

func (sms *StorageManagerStub) Close() error

Close -

func (*StorageManagerStub) EnterPruningBufferingMode

func (sms *StorageManagerStub) EnterPruningBufferingMode()

EnterPruningBufferingMode -

func (*StorageManagerStub) ExitPruningBufferingMode

func (sms *StorageManagerStub) ExitPruningBufferingMode()

ExitPruningBufferingMode -

func (*StorageManagerStub) Get

func (sms *StorageManagerStub) Get(key []byte) ([]byte, error)

Get -

func (*StorageManagerStub) GetBaseTrieStorageManager

func (sms *StorageManagerStub) GetBaseTrieStorageManager() common.StorageManager

GetBaseTrieStorageManager -

func (*StorageManagerStub) GetFromCurrentEpoch

func (sms *StorageManagerStub) GetFromCurrentEpoch(key []byte) ([]byte, error)

GetFromCurrentEpoch -

func (*StorageManagerStub) GetLatestStorageEpoch

func (sms *StorageManagerStub) GetLatestStorageEpoch() (uint32, error)

GetLatestStorageEpoch -

func (*StorageManagerStub) IsClosed

func (sms *StorageManagerStub) IsClosed() bool

IsClosed -

func (*StorageManagerStub) IsInterfaceNil

func (sms *StorageManagerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*StorageManagerStub) IsPruningBlocked

func (sms *StorageManagerStub) IsPruningBlocked() bool

IsPruningBlocked -

func (*StorageManagerStub) IsPruningEnabled

func (sms *StorageManagerStub) IsPruningEnabled() bool

IsPruningEnabled -

func (*StorageManagerStub) Put

func (sms *StorageManagerStub) Put(key []byte, val []byte) error

Put -

func (*StorageManagerStub) PutInEpoch

func (sms *StorageManagerStub) PutInEpoch(key []byte, val []byte, epoch uint32) error

PutInEpoch -

func (*StorageManagerStub) PutInEpochWithoutCache

func (sms *StorageManagerStub) PutInEpochWithoutCache(key []byte, val []byte, epoch uint32) error

PutInEpochWithoutCache -

func (*StorageManagerStub) Remove

func (sms *StorageManagerStub) Remove(hash []byte) error

Remove -

func (*StorageManagerStub) RemoveFromCheckpointHashesHolder

func (sms *StorageManagerStub) RemoveFromCheckpointHashesHolder(hash []byte)

RemoveFromCheckpointHashesHolder -

func (*StorageManagerStub) RemoveFromCurrentEpoch

func (sms *StorageManagerStub) RemoveFromCurrentEpoch(hash []byte) error

RemoveFromCurrentEpoch -

func (*StorageManagerStub) SetCheckpoint

func (sms *StorageManagerStub) SetCheckpoint(
	rootHash []byte,
	mainTrieRootHash []byte,
	leavesChan chan core.KeyValueHolder,
	errChan chan error,
	stats common.SnapshotStatisticsHandler,
)

SetCheckpoint -

func (*StorageManagerStub) SetEpochForPutOperation

func (sms *StorageManagerStub) SetEpochForPutOperation(epoch uint32)

SetEpochForPutOperation -

func (*StorageManagerStub) ShouldTakeSnapshot

func (sms *StorageManagerStub) ShouldTakeSnapshot() bool

ShouldTakeSnapshot -

func (*StorageManagerStub) TakeSnapshot

func (sms *StorageManagerStub) TakeSnapshot(
	rootHash []byte,
	mainTrieRootHash []byte,
	leavesChan chan core.KeyValueHolder,
	errChan chan error,
	stats common.SnapshotStatisticsHandler,
	epoch uint32,
)

TakeSnapshot -

type SyncTimerStub

type SyncTimerStub struct {
}

SyncTimerStub -

func (*SyncTimerStub) ClockOffset

func (sts *SyncTimerStub) ClockOffset() time.Duration

ClockOffset -

func (*SyncTimerStub) Close

func (sts *SyncTimerStub) Close() error

Close -

func (*SyncTimerStub) CurrentTime

func (sts *SyncTimerStub) CurrentTime() time.Time

CurrentTime -

func (*SyncTimerStub) FormattedCurrentTime

func (sts *SyncTimerStub) FormattedCurrentTime() string

FormattedCurrentTime -

func (*SyncTimerStub) IsInterfaceNil

func (sts *SyncTimerStub) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*SyncTimerStub) StartSyncingTime

func (sts *SyncTimerStub) StartSyncingTime()

StartSyncingTime -

type TimeCacheStub

type TimeCacheStub struct {
	AddCalled    func(key string) error
	UpsertCalled func(key string, span time.Duration) error
	HasCalled    func(key string) bool
	SweepCalled  func()
	LenCalled    func() int
}

TimeCacheStub -

func (*TimeCacheStub) Add

func (tcs *TimeCacheStub) Add(key string) error

Add -

func (*TimeCacheStub) Has

func (tcs *TimeCacheStub) Has(key string) bool

Has -

func (*TimeCacheStub) IsInterfaceNil

func (tcs *TimeCacheStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*TimeCacheStub) Len

func (tcs *TimeCacheStub) Len() int

Len -

func (*TimeCacheStub) Sweep

func (tcs *TimeCacheStub) Sweep()

Sweep -

func (*TimeCacheStub) Upsert

func (tcs *TimeCacheStub) Upsert(key string, span time.Duration) error

Upsert -

type TxProcessorMock

type TxProcessorMock struct {
	ProcessTransactionCalled         func(transaction *transaction.Transaction) (vmcommon.ReturnCode, error)
	VerifyTransactionCalled          func(tx *transaction.Transaction) error
	SetBalancesToTrieCalled          func(accBalance map[string]*big.Int) (rootHash []byte, err error)
	ProcessSmartContractResultCalled func(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)
}

TxProcessorMock -

func (*TxProcessorMock) IsInterfaceNil

func (etm *TxProcessorMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*TxProcessorMock) ProcessSmartContractResult

func (etm *TxProcessorMock) ProcessSmartContractResult(scr *smartContractResult.SmartContractResult) (vmcommon.ReturnCode, error)

ProcessSmartContractResult -

func (*TxProcessorMock) ProcessTransaction

func (etm *TxProcessorMock) ProcessTransaction(transaction *transaction.Transaction) (vmcommon.ReturnCode, error)

ProcessTransaction -

func (*TxProcessorMock) SetBalancesToTrie

func (etm *TxProcessorMock) SetBalancesToTrie(accBalance map[string]*big.Int) (rootHash []byte, err error)

SetBalancesToTrie -

func (*TxProcessorMock) VerifyTransaction

func (etm *TxProcessorMock) VerifyTransaction(tx *transaction.Transaction) error

VerifyTransaction -

type TxProcessorStub

type TxProcessorStub struct {
	ProcessTransactionCalled func(transaction *transaction.Transaction) (vmcommon.ReturnCode, error)
	VerifyTransactionCalled  func(tx *transaction.Transaction) error
}

TxProcessorStub -

func (*TxProcessorStub) IsInterfaceNil

func (tps *TxProcessorStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*TxProcessorStub) ProcessTransaction

func (tps *TxProcessorStub) ProcessTransaction(transaction *transaction.Transaction) (vmcommon.ReturnCode, error)

ProcessTransaction -

func (*TxProcessorStub) VerifyTransaction

func (tps *TxProcessorStub) VerifyTransaction(tx *transaction.Transaction) error

VerifyTransaction -

type TxTypeHandlerMock

type TxTypeHandlerMock struct {
	ComputeTransactionTypeCalled func(tx data.TransactionHandler) (process.TransactionType, process.TransactionType)
}

TxTypeHandlerMock -

func (*TxTypeHandlerMock) ComputeTransactionType

ComputeTransactionType -

func (*TxTypeHandlerMock) IsInterfaceNil

func (th *TxTypeHandlerMock) IsInterfaceNil() bool

IsInterfaceNil -

type UnsignedTxHandlerStub

type UnsignedTxHandlerStub struct {
	CleanProcessedUtxsCalled                 func()
	ProcessTransactionFeeCalled              func(cost *big.Int, fee *big.Int, hash []byte)
	ProcessTransactionFeeRelayedUserTxCalled func(cost *big.Int, devFee *big.Int, userTxHash []byte, originalTxHash []byte)
	CreateAllUTxsCalled                      func() []data.TransactionHandler
	VerifyCreatedUTxsCalled                  func() error
	AddTxFeeFromBlockCalled                  func(tx data.TransactionHandler)
	GetAccumulatedFeesCalled                 func() *big.Int
	GetDeveloperFeesCalled                   func() *big.Int
	RevertFeesCalled                         func(txHashes [][]byte)
}

UnsignedTxHandlerStub -

func (*UnsignedTxHandlerStub) AddRewardTxFromBlock

func (ut *UnsignedTxHandlerStub) AddRewardTxFromBlock(tx data.TransactionHandler)

AddRewardTxFromBlock -

func (*UnsignedTxHandlerStub) CleanProcessedUTxs

func (ut *UnsignedTxHandlerStub) CleanProcessedUTxs()

CleanProcessedUTxs -

func (*UnsignedTxHandlerStub) CreateAllUTxs

func (ut *UnsignedTxHandlerStub) CreateAllUTxs() []data.TransactionHandler

CreateAllUTxs -

func (*UnsignedTxHandlerStub) CreateBlockStarted

func (ut *UnsignedTxHandlerStub) CreateBlockStarted(_ scheduled.GasAndFees)

CreateBlockStarted -

func (*UnsignedTxHandlerStub) GetAccumulatedFees

func (ut *UnsignedTxHandlerStub) GetAccumulatedFees() *big.Int

GetAccumulatedFees -

func (*UnsignedTxHandlerStub) GetDeveloperFees

func (ut *UnsignedTxHandlerStub) GetDeveloperFees() *big.Int

GetDeveloperFees -

func (*UnsignedTxHandlerStub) IsInterfaceNil

func (ut *UnsignedTxHandlerStub) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*UnsignedTxHandlerStub) ProcessTransactionFee

func (ut *UnsignedTxHandlerStub) ProcessTransactionFee(cost *big.Int, devFee *big.Int, txHash []byte)

ProcessTransactionFee -

func (*UnsignedTxHandlerStub) ProcessTransactionFeeRelayedUserTx

func (ut *UnsignedTxHandlerStub) ProcessTransactionFeeRelayedUserTx(cost *big.Int, devFee *big.Int, userTxHash []byte, originalTxHash []byte)

ProcessTransactionFeeRelayedUserTx -

func (*UnsignedTxHandlerStub) RevertFees

func (ut *UnsignedTxHandlerStub) RevertFees(txHashes [][]byte)

RevertFees -

func (*UnsignedTxHandlerStub) VerifyCreatedUTxs

func (ut *UnsignedTxHandlerStub) VerifyCreatedUTxs() error

VerifyCreatedUTxs -

type VersionedHeaderFactoryStub

type VersionedHeaderFactoryStub struct {
	CreateCalled func(epoch uint32) data.HeaderHandler
}

VersionedHeaderFactoryStub -

func (*VersionedHeaderFactoryStub) Create

Create -

func (*VersionedHeaderFactoryStub) IsInterfaceNil

func (vhfs *VersionedHeaderFactoryStub) IsInterfaceNil() bool

IsInterfaceNil -

type WatchdogMock

type WatchdogMock struct {
}

WatchdogMock -

func (*WatchdogMock) IsInterfaceNil

func (w *WatchdogMock) IsInterfaceNil() bool

IsInterfaceNil -

func (*WatchdogMock) Reset

func (w *WatchdogMock) Reset(_ string)

Reset -

func (*WatchdogMock) Set

func (w *WatchdogMock) Set(_ func(alarmID string), _ time.Duration, _ string)

Set -

func (*WatchdogMock) SetDefault

func (w *WatchdogMock) SetDefault(_ time.Duration, _ string)

SetDefault -

func (*WatchdogMock) Stop

func (w *WatchdogMock) Stop(_ string)

Stop -

type WhiteListHandlerStub

type WhiteListHandlerStub struct {
	RemoveCalled                  func(keys [][]byte)
	AddCalled                     func(keys [][]byte)
	IsWhiteListedCalled           func(interceptedData process.InterceptedData) bool
	IsWhiteListedAtLeastOneCalled func(identifiers [][]byte) bool
	IsForCurrentShardCalled       func(interceptedData process.InterceptedData) bool
}

WhiteListHandlerStub -

func (*WhiteListHandlerStub) Add

func (w *WhiteListHandlerStub) Add(keys [][]byte)

Add -

func (*WhiteListHandlerStub) IsForCurrentShard

func (w *WhiteListHandlerStub) IsForCurrentShard(interceptedData process.InterceptedData) bool

IsForCurrentShard -

func (*WhiteListHandlerStub) IsInterfaceNil

func (w *WhiteListHandlerStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*WhiteListHandlerStub) IsWhiteListed

func (w *WhiteListHandlerStub) IsWhiteListed(interceptedData process.InterceptedData) bool

IsWhiteListed -

func (*WhiteListHandlerStub) IsWhiteListedAtLeastOne

func (w *WhiteListHandlerStub) IsWhiteListedAtLeastOne(identifiers [][]byte) bool

IsWhiteListedAtLeastOne -

func (*WhiteListHandlerStub) Remove

func (w *WhiteListHandlerStub) Remove(keys [][]byte)

Remove -

Source Files

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL