Documentation ¶
Index ¶
- Constants
- Variables
- func SetEpochHandlerToHdrResolver(resolversContainer ResolversContainer, epochHandler EpochHandler) error
- type ChainStorer
- func (bc *ChainStorer) AddStorer(key UnitType, s storage.Storer)
- func (bc *ChainStorer) CloseAll() error
- func (bc *ChainStorer) Destroy() error
- func (bc *ChainStorer) Get(unitType UnitType, key []byte) ([]byte, error)
- func (bc *ChainStorer) GetAll(unitType UnitType, keys [][]byte) (map[string][]byte, error)
- func (bc *ChainStorer) GetAllStorers() map[UnitType]storage.Storer
- func (bc *ChainStorer) GetStorer(unitType UnitType) (storage.Storer, error)
- func (bc *ChainStorer) Has(unitType UnitType, key []byte) error
- func (bc *ChainStorer) IsInterfaceNil() bool
- func (bc *ChainStorer) Put(unitType UnitType, key []byte, value []byte) error
- func (bc *ChainStorer) SetEpochForPutOperation(epoch uint32)
- type CurrentNetworkEpochProviderHandler
- type DataPacker
- type EpochHandler
- type HeaderResolver
- type HeadersPool
- type IntRandomizer
- type ManualEpochStartNotifier
- type MessageHandler
- type Messenger
- type MiniBlocksResolver
- type NodesCoordinator
- type P2PAntifloodHandler
- type PeerAuthenticationPayloadValidator
- type PeerAuthenticationResolver
- type PeerListCreator
- type PeersRatingHandler
- type PoolsHolder
- type PreferredPeersHolderHandler
- type RequestData
- func (*RequestData) Descriptor() ([]byte, []int)
- func (this *RequestData) Equal(that interface{}) bool
- func (m *RequestData) GetChunkIndex() uint32
- func (m *RequestData) GetEpoch() uint32
- func (m *RequestData) GetType() RequestDataType
- func (m *RequestData) GetValue() []byte
- func (this *RequestData) GoString() string
- func (m *RequestData) Marshal() (dAtA []byte, err error)
- func (m *RequestData) MarshalTo(dAtA []byte) (int, error)
- func (m *RequestData) MarshalToSizedBuffer(dAtA []byte) (int, error)
- func (*RequestData) ProtoMessage()
- func (m *RequestData) Reset()
- func (m *RequestData) Size() (n int)
- func (this *RequestData) String() string
- func (m *RequestData) Unmarshal(dAtA []byte) error
- func (rd *RequestData) UnmarshalWith(marshalizer marshal.Marshalizer, message p2p.MessageP2P) error
- func (m *RequestData) XXX_DiscardUnknown()
- func (m *RequestData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
- func (m *RequestData) XXX_Merge(src proto.Message)
- func (m *RequestData) XXX_Size() int
- func (m *RequestData) XXX_Unmarshal(b []byte) error
- type RequestDataType
- type RequestedItemsHandler
- type Resolver
- type ResolverDebugHandler
- type ResolverThrottler
- type ResolversContainer
- type ResolversContainerFactory
- type ResolversFinder
- type SelfShardIDProvider
- type ShardIdHashMap
- type ShardedDataCacherNotifier
- type StorageService
- type StorageType
- type TopicHandler
- type TopicMessageHandler
- type TopicResolverSender
- type TransactionCacher
- type TrieDataGetter
- type TrieNodesResolver
- type UnitType
- type ValidatorInfoCacher
- type ValidatorInfoResolver
- type WhiteListHandler
Constants ¶
const RewardTxPoolName = "rewardTxPool"
RewardTxPoolName defines the name of the reward transactions pool
const TxPoolNumSendersToPreemptivelyEvict = uint32(100)
TxPoolNumSendersToPreemptivelyEvict instructs tx pool eviction algorithm to remove this many senders when eviction takes place
const UnsignedTxPoolName = "uTxPool"
UnsignedTxPoolName defines the name of the unsigned transactions pool
const ValidatorsInfoPoolName = "validatorsInfoPool"
ValidatorsInfoPoolName defines the name of the validators info pool
Variables ¶
var ( ErrInvalidLengthRequestData = fmt.Errorf("proto: negative length found during unmarshaling") ErrIntOverflowRequestData = fmt.Errorf("proto: integer overflow") ErrUnexpectedEndOfGroupRequestData = fmt.Errorf("proto: unexpected end of group") )
var ErrBadRequest = errors.New("request should not be done as it doesn't follow the protocol")
ErrBadRequest signals that the request should not have happened
var ErrCacheConfigInvalidEconomics = errors.New("cache-economics parameter is not valid")
ErrCacheConfigInvalidEconomics signals that an economics parameter required by the cache is invalid
var ErrCacheConfigInvalidSharding = errors.New("cache-sharding parameter is not valid")
ErrCacheConfigInvalidSharding signals that a sharding parameter required by the cache is invalid
var ErrCacheConfigInvalidShards = errors.New("cache parameter [shards] is not valid, it must be a positive number")
ErrCacheConfigInvalidShards signals that the cache parameter "shards" is invalid
var ErrCacheConfigInvalidSize = errors.New("cache parameter [size] is not valid, it must be a positive number")
ErrCacheConfigInvalidSize signals that the cache parameter "size" is invalid
var ErrCacheConfigInvalidSizeInBytes = errors.New("cache parameter [sizeInBytes] is not valid, it must be a positive, and large enough number")
ErrCacheConfigInvalidSizeInBytes signals that the cache parameter "sizeInBytes" is invalid
var ErrContainerKeyAlreadyExists = errors.New("provided key already exists in container")
ErrContainerKeyAlreadyExists signals that an element was already set in the container's map
var ErrEmptyString = errors.New("empty string")
ErrEmptyString signals that an empty string has been provided
var ErrInvalidContainerKey = errors.New("element does not exist in container")
ErrInvalidContainerKey signals that an element does not exist in the container's map
var ErrInvalidMaxTxRequest = errors.New("max tx request number is invalid")
ErrInvalidMaxTxRequest signals that max tx request is too small
var ErrInvalidNonceByteSlice = errors.New("invalid nonce byte slice")
ErrInvalidNonceByteSlice signals that an invalid byte slice has been provided and an uint64 can not be decoded from that byte slice
var ErrInvalidValue = errors.New("invalid value")
ErrInvalidValue signals that an invalid value has been provided
var ErrLenMismatch = errors.New("lengths mismatch")
ErrLenMismatch signals that 2 or more slices have different lengths
var ErrMissingData = errors.New("missing data")
ErrMissingData signals that the required data is missing
var ErrNilAntifloodHandler = errors.New("nil antiflood handler")
ErrNilAntifloodHandler signals that a nil antiflood handler has been provided
var ErrNilConfig = errors.New("nil config provided")
ErrNilConfig signals that a nil config has been provided
var ErrNilContainerElement = errors.New("element cannot be nil")
ErrNilContainerElement signals when trying to add a nil element in the container
var ErrNilCurrBlockTxs = errors.New("nil current block txs holder")
ErrNilCurrBlockTxs signals that nil current block txs holder was provided
var ErrNilCurrentEpochValidatorInfo = errors.New("nil current epoch validator info holder")
ErrNilCurrentEpochValidatorInfo signals that nil current epoch validator info holder was provided
var ErrNilCurrentNetworkEpochProvider = errors.New("nil current network epoch provider")
ErrNilCurrentNetworkEpochProvider signals that a nil CurrentNetworkEpochProvider handler has been provided
var ErrNilDataPacker = errors.New("nil data packer provided")
ErrNilDataPacker signals that a nil data packer has been provided
var ErrNilDataPoolHolder = errors.New("nil data pool holder")
ErrNilDataPoolHolder signals that the data pool holder is nil
var ErrNilDataToProcess = errors.New("nil data to process")
ErrNilDataToProcess signals that nil data was provided
var ErrNilEconomicsData = errors.New("nil economics data provided")
ErrNilEconomicsData signals that a nil economics data handler has been provided
var ErrNilEpochHandler = errors.New("nil epoch handler")
ErrNilEpochHandler signals that epoch handler is nil
var ErrNilEpochNotifier = errors.New("nil EpochNotifier")
ErrNilEpochNotifier signals that the provided EpochNotifier is nil
var ErrNilGracefullyCloseChannel = errors.New("nil gracefully close channel")
ErrNilGracefullyCloseChannel signals that a nil gracefully close channel has been provided
var ErrNilHasher = errors.New("nil hasher")
ErrNilHasher signals that a nil hasher has been provided
var ErrNilHeadersDataPool = errors.New("nil headers data pool")
ErrNilHeadersDataPool signals that a nil header pool has been provided
var ErrNilHeadersNoncesStorage = errors.New("nil headers nonces storage")
ErrNilHeadersNoncesStorage signals that a nil header-nonce storage has been provided
var ErrNilHeadersStorage = errors.New("nil headers storage")
ErrNilHeadersStorage signals that a nil header storage has been provided
var ErrNilHeartbeatPool = errors.New("nil heartbeat pool")
ErrNilHeartbeatPool signals that a nil heartbeat pool has been provided
var ErrNilManualEpochStartNotifier = errors.New("nil manual epoch start notifier")
ErrNilManualEpochStartNotifier signals that a nil manual epoch start notifier has been provided
var ErrNilMarshalizer = errors.New("nil Marshalizer")
ErrNilMarshalizer signals that an operation has been attempted to or with a nil Marshalizer implementation
var ErrNilMessage = errors.New("nil message")
ErrNilMessage signals that a nil message has been received
var ErrNilMessenger = errors.New("nil Messenger")
ErrNilMessenger signals that a nil Messenger object was provided
var ErrNilMiniblocksPool = errors.New("nil miniblocks pool")
ErrNilMiniblocksPool signals that a nil miniblocks pool has been provided
var ErrNilMiniblocksStorage = errors.New("nil miniblocks storage")
ErrNilMiniblocksStorage signals that a nil miniblocks storage has been provided
var ErrNilNodesCoordinator = errors.New("nil nodes coordinator")
ErrNilNodesCoordinator signals a nil nodes coordinator has been provided
var ErrNilPathManager = errors.New("nil path manager")
ErrNilPathManager signals that a nil path manager has been provided
var ErrNilPayloadValidator = errors.New("nil payload validator")
ErrNilPayloadValidator signals that a nil payload validator was provided
var ErrNilPeerAuthenticationPool = errors.New("nil peer authentication pool")
ErrNilPeerAuthenticationPool signals that a nil peer authentication pool has been provided
var ErrNilPeerChangeBlockDataPool = errors.New("nil peer change block data pool")
ErrNilPeerChangeBlockDataPool signals that a nil peer change pool has been provided
var ErrNilPeerListCreator = errors.New("nil peer list creator provided")
ErrNilPeerListCreator signals that a nil peer list creator implementation has been provided
var ErrNilPeersRatingHandler = errors.New("nil peers rating handler")
ErrNilPeersRatingHandler signals that a nil peers rating handler implementation has been provided
var ErrNilPreferredPeersHolder = errors.New("nil preferred peers holder")
ErrNilPreferredPeersHolder signals that a nil preferred peers holder handler has been provided
var ErrNilRandomizer = errors.New("nil randomizer")
ErrNilRandomizer signals that a nil randomizer has been provided
var ErrNilRequestedItemsHandler = errors.New("nil requested items handler")
ErrNilRequestedItemsHandler signals that a nil requested items handler was provided
var ErrNilResolverContainer = errors.New("nil resolver container")
ErrNilResolverContainer signals that a nil resolver container was provided
var ErrNilResolverDebugHandler = errors.New("nil resolver debug handler")
ErrNilResolverDebugHandler signals that a nil resolver debug handler has been provided
var ErrNilResolverFinder = errors.New("nil resolvers finder")
ErrNilResolverFinder signals that a nil resolver finder has been provided
var ErrNilResolverSender = errors.New("nil resolver sender")
ErrNilResolverSender signals that a nil resolver sender object has been provided
var ErrNilRewardTransactionPool = errors.New("nil reward transaction data pool")
ErrNilRewardTransactionPool signals that a nil reward transactions pool has been provided
var ErrNilSelfShardIDProvider = errors.New("nil self shard ID provider")
ErrNilSelfShardIDProvider signals that a nil self shard ID provider has been provided
var ErrNilShardCoordinator = errors.New("nil shard coordinator")
ErrNilShardCoordinator signals that an operation has been attempted to or with a nil shard coordinator
var ErrNilSmartContractsPool = errors.New("nil smart contracts pool")
ErrNilSmartContractsPool signals that a nil smart contracts pool has been provided
var ErrNilStore = errors.New("nil data storage service")
ErrNilStore signals that the provided storage service is nil
var ErrNilThrottler = errors.New("nil throttler")
ErrNilThrottler signals that a nil throttler has been provided
var ErrNilTrieDataGetter = errors.New("nil trie data getter provided")
ErrNilTrieDataGetter signals that a nil trie data getter has been provided
var ErrNilTrieNodesChunksPool = errors.New("nil trie nodes chunks data pool")
ErrNilTrieNodesChunksPool signals that a nil trie nodes chunks data pool was provided
var ErrNilTrieNodesPool = errors.New("nil trie nodes data pool")
ErrNilTrieNodesPool signals that a nil trie nodes data pool was provided
var ErrNilTrieStorageManager = errors.New("nil trie storage manager")
ErrNilTrieStorageManager signals that a nil trie storage manager has been provided
var ErrNilTxBlockDataPool = errors.New("nil tx block data pool")
ErrNilTxBlockDataPool signals that a nil tx block body pool has been provided
var ErrNilTxDataPool = errors.New("nil transaction data pool")
ErrNilTxDataPool signals that a nil transaction pool has been provided
var ErrNilTxGasHandler = errors.New("nil tx gas handler provided")
ErrNilTxGasHandler signals that a nil tx gas handler was provided
var ErrNilTxStorage = errors.New("nil transaction storage")
ErrNilTxStorage signals that a nil transaction storage has been provided
var ErrNilUint64ByteSliceConverter = errors.New("nil byte slice converter")
ErrNilUint64ByteSliceConverter signals that a nil byte slice converter was provided
var ErrNilUnsignedTransactionPool = errors.New("nil unsigned transactions data pool")
ErrNilUnsignedTransactionPool signals that a nil unsigned transactions pool has been provided
var ErrNilValidatorInfoPool = errors.New("nil validator info pool")
ErrNilValidatorInfoPool signals that a nil validator info pool has been provided
var ErrNilValidatorInfoStorage = errors.New("nil validator info storage")
ErrNilValidatorInfoStorage signals that a nil validator info storage has been provided
var ErrNilValue = errors.New("nil value")
ErrNilValue signals the value is nil
var ErrNilWhiteListHandler = errors.New("nil white list handler")
ErrNilWhiteListHandler signals that white list handler is nil
var ErrNoSuchStorageUnit = errors.New("no such unit type")
ErrNoSuchStorageUnit defines the error for using an invalid storage unit
var ErrPeerAuthNotFound = errors.New("peer authentication not found")
ErrPeerAuthNotFound signals that no peer authentication found
var ErrRequestIntervalTooSmall = errors.New("request interval is too small")
ErrRequestIntervalTooSmall signals that request interval is too small
var ErrRequestTypeNotImplemented = errors.New("request type is not implemented")
ErrRequestTypeNotImplemented signals that a not implemented type of request has been received
var ErrResolveTypeUnknown = errors.New("unknown resolve type")
ErrResolveTypeUnknown signals that an unknown resolve type was provided
var ErrSendRequest = errors.New("cannot send request: peer list is empty or errors during the sending")
ErrSendRequest signals that the connected peers list is empty or errors appeared when sending requests
var ErrStorerNotFound = errors.New("storer not found")
ErrStorerNotFound signals that the storer was not found
var ErrSystemBusy = errors.New("system busy")
ErrSystemBusy signals that the system is busy and can not process more requests
var ErrTxNotFoundInBlockPool = errors.New("transaction was not found in the current block pool")
ErrTxNotFoundInBlockPool signals that transaction was not found in the current block pool
var ErrValidatorInfoNotFound = errors.New("validator info not found")
ErrValidatorInfoNotFound signals that no validator info was found
var ErrValidatorInfoNotFoundInEpochPool = errors.New("validator info was not found in the current epoch pool")
ErrValidatorInfoNotFoundInEpochPool signals that validator info was not found in the current epoch pool
var ErrWrongTypeAssertion = errors.New("wrong type assertion")
ErrWrongTypeAssertion signals that a type assertion failed
var ErrWrongTypeInContainer = errors.New("wrong type of object inside container")
ErrWrongTypeInContainer signals that a wrong type of object was found in container
var RequestDataType_name = map[int32]string{
0: "InvalidType",
1: "HashType",
2: "HashArrayType",
3: "NonceType",
4: "EpochType",
5: "ChunkType",
}
var RequestDataType_value = map[string]int32{
"InvalidType": 0,
"HashType": 1,
"HashArrayType": 2,
"NonceType": 3,
"EpochType": 4,
"ChunkType": 5,
}
Functions ¶
func SetEpochHandlerToHdrResolver ¶
func SetEpochHandlerToHdrResolver( resolversContainer ResolversContainer, epochHandler EpochHandler, ) error
SetEpochHandlerToHdrResolver sets the epoch handler to the metablock hdr resolver
Types ¶
type ChainStorer ¶
type ChainStorer struct {
// contains filtered or unexported fields
}
ChainStorer is a StorageService implementation that can hold multiple storages
grouped by storage unit type
func NewChainStorer ¶
func NewChainStorer() *ChainStorer
NewChainStorer returns a new initialised ChainStorer
func (*ChainStorer) AddStorer ¶
func (bc *ChainStorer) AddStorer(key UnitType, s storage.Storer)
AddStorer will add a new storer to the chain map
func (*ChainStorer) CloseAll ¶
func (bc *ChainStorer) CloseAll() error
CloseAll will close all the active units
func (*ChainStorer) Destroy ¶
func (bc *ChainStorer) Destroy() error
Destroy removes the underlying files/resources used by the storage service
func (*ChainStorer) Get ¶
func (bc *ChainStorer) Get(unitType UnitType, key []byte) ([]byte, error)
Get returns the value for the given key if found in the selected storage unit, nil otherwise. It can return an error if the provided unit type is not supported or if the storage unit underlying implementation reports an error
func (*ChainStorer) GetAll ¶
GetAll gets all the elements with keys in the keys array, from the selected storage unit It can report an error if the provided unit type is not supported, if there is a missing key in the unit, or if the underlying implementation of the storage unit reports an error.
func (*ChainStorer) GetAllStorers ¶ added in v1.2.4
func (bc *ChainStorer) GetAllStorers() map[UnitType]storage.Storer
GetAllStorers returns all the available storers
func (*ChainStorer) GetStorer ¶
func (bc *ChainStorer) GetStorer(unitType UnitType) (storage.Storer, error)
GetStorer returns the storer from the chain map or nil if the storer was not found with error
func (*ChainStorer) Has ¶
func (bc *ChainStorer) Has(unitType UnitType, key []byte) error
Has returns true if the key is found in the selected Unit or false otherwise It can return an error if the provided unit type is not supported or if the underlying implementation of the storage unit reports an error.
func (*ChainStorer) IsInterfaceNil ¶
func (bc *ChainStorer) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ChainStorer) Put ¶
func (bc *ChainStorer) Put(unitType UnitType, key []byte, value []byte) error
Put stores the key, value pair in the selected storage unit It can return an error if the provided unit type is not supported or if the storage unit underlying implementation reports an error
func (*ChainStorer) SetEpochForPutOperation ¶ added in v1.0.109
func (bc *ChainStorer) SetEpochForPutOperation(epoch uint32)
SetEpochForPutOperation will set the epoch to be used in all persisters for the put operation
type CurrentNetworkEpochProviderHandler ¶ added in v1.2.0
type CurrentNetworkEpochProviderHandler interface { EpochIsActiveInNetwork(epoch uint32) bool EpochConfirmed(newEpoch uint32, newTimestamp uint64) IsInterfaceNil() bool }
CurrentNetworkEpochProviderHandler is an interface able to compute if the provided epoch is active on the network or not
type DataPacker ¶
type DataPacker interface { PackDataInChunks(data [][]byte, limit int) ([][]byte, error) IsInterfaceNil() bool }
DataPacker can split a large slice of byte slices in smaller packets
type EpochHandler ¶
EpochHandler defines the functionality to get the current epoch
type HeaderResolver ¶
type HeaderResolver interface { Resolver RequestDataFromNonce(nonce uint64, epoch uint32) error RequestDataFromEpoch(identifier []byte) error SetEpochHandler(epochHandler EpochHandler) error }
HeaderResolver defines what a block header resolver should do
type HeadersPool ¶
type HeadersPool interface { Clear() AddHeader(headerHash []byte, header data.HeaderHandler) RemoveHeaderByHash(headerHash []byte) RemoveHeaderByNonceAndShardId(headerNonce uint64, shardId uint32) GetHeadersByNonceAndShardId(headerNonce uint64, shardId uint32) ([]data.HeaderHandler, [][]byte, error) GetHeaderByHash(hash []byte) (data.HeaderHandler, error) RegisterHandler(handler func(headerHandler data.HeaderHandler, headerHash []byte)) Nonces(shardId uint32) []uint64 Len() int MaxSize() int IsInterfaceNil() bool GetNumHeaders(shardId uint32) int }
HeadersPool defines what a headers pool structure can perform
type IntRandomizer ¶
IntRandomizer interface provides functionality over generating integer numbers
type ManualEpochStartNotifier ¶ added in v1.1.1
type ManualEpochStartNotifier interface { NewEpoch(epoch uint32) CurrentEpoch() uint32 IsInterfaceNil() bool }
ManualEpochStartNotifier can manually notify an epoch change
type MessageHandler ¶
type MessageHandler interface { ConnectedPeersOnTopic(topic string) []core.PeerID ConnectedFullHistoryPeersOnTopic(topic string) []core.PeerID SendToConnectedPeer(topic string, buff []byte, peerID core.PeerID) error ID() core.PeerID IsInterfaceNil() bool }
MessageHandler defines the functionality needed by structs to send data to other peers
type Messenger ¶ added in v1.2.0
type Messenger interface { MessageHandler TopicHandler UnregisterMessageProcessor(topic string, identifier string) error UnregisterAllMessageProcessors() error UnjoinAllTopics() error ConnectedPeers() []core.PeerID }
Messenger defines which methods a p2p messenger should implement
type MiniBlocksResolver ¶
type MiniBlocksResolver interface { Resolver RequestDataFromHashArray(hashes [][]byte, epoch uint32) error }
MiniBlocksResolver defines what a mini blocks resolver should do
type NodesCoordinator ¶ added in v1.3.37
type NodesCoordinator interface { GetAllEligibleValidatorsPublicKeys(epoch uint32) (map[uint32][][]byte, error) IsInterfaceNil() bool }
NodesCoordinator provides Validator methods needed for the peer processing
type P2PAntifloodHandler ¶
type P2PAntifloodHandler interface { CanProcessMessage(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error CanProcessMessagesOnTopic(peer core.PeerID, topic string, numMessages uint32, _ uint64, sequence []byte) error BlacklistPeer(peer core.PeerID, reason string, duration time.Duration) IsInterfaceNil() bool }
P2PAntifloodHandler defines the behavior of a component able to signal that the system is too busy (or flooded) processing p2p messages
type PeerAuthenticationPayloadValidator ¶ added in v1.3.38
type PeerAuthenticationPayloadValidator interface { ValidateTimestamp(payloadTimestamp int64) error IsInterfaceNil() bool }
PeerAuthenticationPayloadValidator defines the operations supported by an entity able to validate timestamps found in peer authentication messages
type PeerAuthenticationResolver ¶ added in v1.3.37
type PeerAuthenticationResolver interface { Resolver RequestDataFromHashArray(hashes [][]byte, epoch uint32) error }
PeerAuthenticationResolver defines what a peer authentication resolver should do
type PeerListCreator ¶
type PeerListCreator interface { CrossShardPeerList() []core.PeerID IntraShardPeerList() []core.PeerID FullHistoryList() []core.PeerID IsInterfaceNil() bool }
PeerListCreator is used to create a peer list
type PeersRatingHandler ¶ added in v1.3.29
type PeersRatingHandler interface { AddPeer(pid core.PeerID) IncreaseRating(pid core.PeerID) DecreaseRating(pid core.PeerID) GetTopRatedPeersFromList(peers []core.PeerID, minNumOfPeersExpected int) []core.PeerID IsInterfaceNil() bool }
PeersRatingHandler represent an entity able to handle peers ratings
type PoolsHolder ¶
type PoolsHolder interface { Transactions() ShardedDataCacherNotifier UnsignedTransactions() ShardedDataCacherNotifier RewardTransactions() ShardedDataCacherNotifier Headers() HeadersPool MiniBlocks() storage.Cacher PeerChangesBlocks() storage.Cacher TrieNodes() storage.Cacher TrieNodesChunks() storage.Cacher SmartContracts() storage.Cacher CurrentBlockTxs() TransactionCacher CurrentEpochValidatorInfo() ValidatorInfoCacher PeerAuthentications() storage.Cacher Heartbeats() storage.Cacher ValidatorsInfo() ShardedDataCacherNotifier Close() error IsInterfaceNil() bool }
PoolsHolder defines getters for data pools
type PreferredPeersHolderHandler ¶ added in v1.2.3
type PreferredPeersHolderHandler interface { Get() map[uint32][]core.PeerID Contains(peerID core.PeerID) bool IsInterfaceNil() bool }
PreferredPeersHolderHandler defines the behavior of a component able to handle preferred peers operations
type RequestData ¶
type RequestData struct { Type RequestDataType `protobuf:"varint,1,opt,name=Type,proto3,enum=proto.RequestDataType" json:"type"` Value []byte `protobuf:"bytes,2,opt,name=Value,proto3" json:"value"` Epoch uint32 `protobuf:"varint,3,opt,name=Epoch,proto3" json:"epoch"` ChunkIndex uint32 `protobuf:"varint,4,opt,name=ChunkIndex,proto3" json:"chunkIndex"` }
RequestData holds the requested data This struct will be serialized and sent to the other peers
func (*RequestData) Descriptor ¶
func (*RequestData) Descriptor() ([]byte, []int)
func (*RequestData) Equal ¶
func (this *RequestData) Equal(that interface{}) bool
func (*RequestData) GetChunkIndex ¶ added in v1.2.4
func (m *RequestData) GetChunkIndex() uint32
func (*RequestData) GetEpoch ¶
func (m *RequestData) GetEpoch() uint32
func (*RequestData) GetType ¶
func (m *RequestData) GetType() RequestDataType
func (*RequestData) GetValue ¶
func (m *RequestData) GetValue() []byte
func (*RequestData) GoString ¶
func (this *RequestData) GoString() string
func (*RequestData) Marshal ¶
func (m *RequestData) Marshal() (dAtA []byte, err error)
func (*RequestData) MarshalToSizedBuffer ¶
func (m *RequestData) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*RequestData) ProtoMessage ¶
func (*RequestData) ProtoMessage()
func (*RequestData) Reset ¶
func (m *RequestData) Reset()
func (*RequestData) Size ¶
func (m *RequestData) Size() (n int)
func (*RequestData) String ¶
func (this *RequestData) String() string
func (*RequestData) Unmarshal ¶
func (m *RequestData) Unmarshal(dAtA []byte) error
func (*RequestData) UnmarshalWith ¶
func (rd *RequestData) UnmarshalWith(marshalizer marshal.Marshalizer, message p2p.MessageP2P) error
UnmarshalWith sets the fields according to p2p.MessageP2P.Data() contents Errors if something went wrong
func (*RequestData) XXX_DiscardUnknown ¶
func (m *RequestData) XXX_DiscardUnknown()
func (*RequestData) XXX_Marshal ¶
func (m *RequestData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
func (*RequestData) XXX_Merge ¶
func (m *RequestData) XXX_Merge(src proto.Message)
func (*RequestData) XXX_Size ¶
func (m *RequestData) XXX_Size() int
func (*RequestData) XXX_Unmarshal ¶
func (m *RequestData) XXX_Unmarshal(b []byte) error
type RequestDataType ¶
type RequestDataType int32
RequestDataType represents the data type for the requested data
const ( // Invalid InvalidType RequestDataType = 0 // HashType indicates that the request data object is of type hash HashType RequestDataType = 1 // HashArrayType that the request data object contains a serialised array of hashes HashArrayType RequestDataType = 2 // NonceType indicates that the request data object is of type nonce (uint64) NonceType RequestDataType = 3 // EpochType indicates that the request data object is of type epoch EpochType RequestDataType = 4 // ChunkType indicates that the request data object is of type chunk ChunkType RequestDataType = 5 )
func (RequestDataType) EnumDescriptor ¶
func (RequestDataType) EnumDescriptor() ([]byte, []int)
func (RequestDataType) String ¶
func (x RequestDataType) String() string
type RequestedItemsHandler ¶
type RequestedItemsHandler interface { Add(key string) error Has(key string) bool Sweep() IsInterfaceNil() bool }
RequestedItemsHandler can determine if a certain key has or not been requested
type Resolver ¶
type Resolver interface { RequestDataFromHash(hash []byte, epoch uint32) error ProcessReceivedMessage(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error SetResolverDebugHandler(handler ResolverDebugHandler) error SetNumPeersToQuery(intra int, cross int) NumPeersToQuery() (int, int) Close() error IsInterfaceNil() bool }
Resolver defines what a data resolver should do
type ResolverDebugHandler ¶ added in v1.0.110
type ResolverDebugHandler interface { LogRequestedData(topic string, hashes [][]byte, numReqIntra int, numReqCross int) LogFailedToResolveData(topic string, hash []byte, err error) LogSucceededToResolveData(topic string, hash []byte) IsInterfaceNil() bool }
ResolverDebugHandler defines an interface for debugging the reqested-resolved data
type ResolverThrottler ¶
type ResolverThrottler interface { CanProcess() bool StartProcessing() EndProcessing() IsInterfaceNil() bool }
ResolverThrottler can monitor the number of the currently running resolver go routines
type ResolversContainer ¶
type ResolversContainer interface { Get(key string) (Resolver, error) Add(key string, val Resolver) error AddMultiple(keys []string, resolvers []Resolver) error Replace(key string, val Resolver) error Remove(key string) Len() int ResolverKeys() string Iterate(handler func(key string, resolver Resolver) bool) Close() error IsInterfaceNil() bool }
ResolversContainer defines a resolvers holder data type with basic functionality
type ResolversContainerFactory ¶
type ResolversContainerFactory interface { Create() (ResolversContainer, error) IsInterfaceNil() bool }
ResolversContainerFactory defines the functionality to create a resolvers container
type ResolversFinder ¶
type ResolversFinder interface { ResolversContainer IntraShardResolver(baseTopic string) (Resolver, error) MetaChainResolver(baseTopic string) (Resolver, error) CrossShardResolver(baseTopic string, crossShard uint32) (Resolver, error) MetaCrossShardResolver(baseTopic string, crossShard uint32) (Resolver, error) }
ResolversFinder extends a container resolver and have 2 additional functionality
type SelfShardIDProvider ¶ added in v1.2.3
SelfShardIDProvider defines the behavior of a component able to provide the self shard ID
type ShardIdHashMap ¶
type ShardIdHashMap interface { Load(shardId uint32) ([]byte, bool) Store(shardId uint32, hash []byte) Range(f func(shardId uint32, hash []byte) bool) Delete(shardId uint32) IsInterfaceNil() bool }
ShardIdHashMap represents a map for shardId and hash
type ShardedDataCacherNotifier ¶
type ShardedDataCacherNotifier interface { RegisterOnAdded(func(key []byte, value interface{})) ShardDataStore(cacheId string) (c storage.Cacher) AddData(key []byte, data interface{}, sizeInBytes int, cacheId string) SearchFirstData(key []byte) (value interface{}, ok bool) RemoveData(key []byte, cacheId string) RemoveSetOfDataFromPool(keys [][]byte, cacheId string) ImmunizeSetOfDataAgainstEviction(keys [][]byte, cacheId string) RemoveDataFromAllShards(key []byte) MergeShardStores(sourceCacheID, destCacheID string) Clear() ClearShardStore(cacheId string) GetCounts() counting.CountsWithSize Keys() [][]byte IsInterfaceNil() bool }
ShardedDataCacherNotifier defines what a sharded-data structure can perform
type StorageService ¶
type StorageService interface { // GetStorer returns the storer from the chain map // If the unit is missing, it returns an error GetStorer(unitType UnitType) (storage.Storer, error) // AddStorer will add a new storer to the chain map AddStorer(key UnitType, s storage.Storer) // Has returns true if the key is found in the selected Unit or false otherwise Has(unitType UnitType, key []byte) error // Get returns the value for the given key if found in the selected storage unit, nil otherwise Get(unitType UnitType, key []byte) ([]byte, error) // Put stores the key, value pair in the selected storage unit Put(unitType UnitType, key []byte, value []byte) error // SetEpochForPutOperation will set the epoch which will be used for the put operation SetEpochForPutOperation(epoch uint32) // GetAll gets all the elements with keys in the keys array, from the selected storage unit // If there is a missing key in the unit, it returns an error GetAll(unitType UnitType, keys [][]byte) (map[string][]byte, error) // GetAllStorers returns all the storers GetAllStorers() map[UnitType]storage.Storer // Destroy removes the underlying files/resources used by the storage service Destroy() error // CloseAll will close all the units CloseAll() error // IsInterfaceNil returns true if there is no value under the interface IsInterfaceNil() bool }
StorageService is the interface for data storage unit provided services
type TopicHandler ¶
type TopicHandler interface { HasTopic(name string) bool CreateTopic(name string, createChannelForTopic bool) error RegisterMessageProcessor(topic string, identifier string, handler p2p.MessageProcessor) error }
TopicHandler defines the functionality needed by structs to manage topics and message processors
type TopicMessageHandler ¶
type TopicMessageHandler interface { MessageHandler TopicHandler }
TopicMessageHandler defines the functionality needed by structs to manage topics, message processors and to send data to other peers
type TopicResolverSender ¶
type TopicResolverSender interface { SendOnRequestTopic(rd *RequestData, originalHashes [][]byte) error Send(buff []byte, peer core.PeerID) error RequestTopic() string TargetShardID() uint32 SetNumPeersToQuery(intra int, cross int) SetResolverDebugHandler(handler ResolverDebugHandler) error ResolverDebugHandler() ResolverDebugHandler NumPeersToQuery() (int, int) IsInterfaceNil() bool }
TopicResolverSender defines what sending operations are allowed for a topic resolver
type TransactionCacher ¶
type TransactionCacher interface { Clean() GetTx(txHash []byte) (data.TransactionHandler, error) AddTx(txHash []byte, tx data.TransactionHandler) IsInterfaceNil() bool }
TransactionCacher defines the methods for the local transaction cacher, needed for the current block
type TrieDataGetter ¶
type TrieDataGetter interface { GetSerializedNodes([]byte, uint64) ([][]byte, uint64, error) GetSerializedNode([]byte) ([]byte, error) IsInterfaceNil() bool }
TrieDataGetter returns requested data from the trie
type TrieNodesResolver ¶ added in v1.0.110
type TrieNodesResolver interface { Resolver RequestDataFromHashArray(hashes [][]byte, epoch uint32) error }
TrieNodesResolver defines what a trie nodes resolver should do
type UnitType ¶
type UnitType uint8
UnitType is the type for Storage unit identifiers
const ( // TransactionUnit is the transactions storage unit identifier TransactionUnit UnitType = 0 // MiniBlockUnit is the transaction block body storage unit identifier MiniBlockUnit UnitType = 1 // PeerChangesUnit is the peer change block body storage unit identifier PeerChangesUnit UnitType = 2 // BlockHeaderUnit is the Block Headers Storage unit identifier BlockHeaderUnit UnitType = 3 // MetaBlockUnit is the metachain blocks storage unit identifier MetaBlockUnit UnitType = 4 // UnsignedTransactionUnit is the unsigned transaction unit identifier UnsignedTransactionUnit UnitType = 5 // RewardTransactionUnit is the reward transaction unit identifier RewardTransactionUnit UnitType = 6 // MetaHdrNonceHashDataUnit is the meta header nonce-hash pair data unit identifier MetaHdrNonceHashDataUnit UnitType = 7 // HeartbeatUnit is the heartbeat storage unit identifier HeartbeatUnit UnitType = 8 // BootstrapUnit is the bootstrap storage unit identifier BootstrapUnit UnitType = 9 //StatusMetricsUnit is the status metrics storage unit identifier StatusMetricsUnit UnitType = 10 // TxLogsUnit is the transactions logs storage unit identifier TxLogsUnit UnitType = 11 // MiniblocksMetadataUnit is the miniblocks metadata storage unit identifier MiniblocksMetadataUnit UnitType = 12 // EpochByHashUnit is the epoch by hash storage unit identifier EpochByHashUnit UnitType = 13 // MiniblockHashByTxHashUnit is the miniblocks hash by tx hash storage unit identifier MiniblockHashByTxHashUnit UnitType = 14 // ReceiptsUnit is the receipts storage unit identifier ReceiptsUnit UnitType = 15 // ResultsHashesByTxHashUnit is the results hashes by transaction storage unit identifier ResultsHashesByTxHashUnit UnitType = 16 // TrieEpochRootHashUnit is the trie epoch <-> root hash storage unit identifier TrieEpochRootHashUnit UnitType = 17 // ESDTSuppliesUnit is the ESDT supplies storage unit identifier ESDTSuppliesUnit UnitType = 18 // RoundHdrHashDataUnit is the round- block header hash storage data unit identifier RoundHdrHashDataUnit UnitType = 19 // UserAccountsUnit is the user accounts storage unit identifier UserAccountsUnit UnitType = 20 // UserAccountsCheckpointsUnit is the user accounts checkpoints storage unit identifier UserAccountsCheckpointsUnit UnitType = 21 // PeerAccountsUnit is the peer accounts storage unit identifier PeerAccountsUnit UnitType = 22 // PeerAccountsCheckpointsUnit is the peer accounts checkpoints storage unit identifier PeerAccountsCheckpointsUnit UnitType = 23 // ScheduledSCRsUnit is the scheduled SCRs storage unit identifier ScheduledSCRsUnit UnitType = 24 // ShardHdrNonceHashDataUnit is the header nonce-hash pair data unit identifier //TODO: Add only unit types lower than 100 ShardHdrNonceHashDataUnit UnitType = 100 )
func GetHdrNonceHashDataUnit ¶ added in v1.1.1
GetHdrNonceHashDataUnit gets the HdrNonceHashDataUnit by shard
func GetHeadersDataUnit ¶ added in v1.3.37
GetHeadersDataUnit gets the unit for block headers, by shard
type ValidatorInfoCacher ¶ added in v1.4.0
type ValidatorInfoCacher interface { Clean() GetValidatorInfo(validatorInfoHash []byte) (*state.ShardValidatorInfo, error) AddValidatorInfo(validatorInfoHash []byte, validatorInfo *state.ShardValidatorInfo) IsInterfaceNil() bool }
ValidatorInfoCacher defines the methods for the local validator info cacher, needed for the current epoch
type ValidatorInfoResolver ¶ added in v1.4.0
type ValidatorInfoResolver interface { Resolver RequestDataFromHashArray(hashes [][]byte, epoch uint32) error }
ValidatorInfoResolver defines what a validator info resolver should do
type WhiteListHandler ¶ added in v1.0.102
WhiteListHandler is the interface needed to add whitelisted data