# Packages
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
# Functions
AddHeaderToBlackList adds a hash to black list handler.
CheckIfIndexesAreOutOfBound checks if the given indexes are out of bound for the given mini block.
DisplayProcessTxDetails displays information related to the tx which should be executed.
GetFinalCrossMiniBlockHashes returns all the finalized miniblocks hashes, from the given header and with the given destination.
GetHeaderFromStorage method returns a block header from storage.
GetHeaderFromStorageWithNonce method returns a block header from storage with a given nonce and shardId.
GetHeaderHashFromStorageWithNonce gets a header hash, given a nonce.
GetMarshalizedHeaderFromStorage gets the marshalized header, which is associated with the given hash, from storage.
GetMetaHeader gets the header, which is associated with the given hash, from pool or storage.
GetMetaHeaderFromPool gets the header, which is associated with the given hash, from pool.
GetMetaHeaderFromPoolWithNonce method returns a meta block header from pool with a given nonce.
GetMetaHeaderFromStorage gets the header, which is associated with the given hash, from storage.
GetMetaHeaderFromStorageWithNonce method returns a meta block header from storage with a given nonce.
GetMetaHeaderWithNonce method returns a meta block header with a given nonce.
GetMiniBlockHeaderWithHash returns the miniblock header with the given hash.
GetShardHeader gets the header, which is associated with the given hash, from pool or storage.
GetShardHeaderFromPool gets the header, which is associated with the given hash, from pool.
GetShardHeaderFromPoolWithNonce method returns a shard block header from pool with a given nonce and shardId.
GetShardHeaderFromStorage gets the header, which is associated with the given hash, from storage.
GetShardHeaderFromStorageWithNonce method returns a shard block header from storage with a given nonce and shardId.
GetShardHeaderWithNonce method returns a shard block header with a given nonce and shardId.
GetSortedStorageUpdates returns the storage updates as a sorted list.
GetTransactionHandler gets the transaction with a given sender/receiver shardId and txHash.
GetTransactionHandlerFromPool gets the transaction from pool with a given sender/receiver shardId and txHash.
GetTransactionHandlerFromStorage gets the transaction from storage with a given sender/receiver shardId and txHash.
GetZeroGasAndFees returns a zero value structure for the gas and fees.
HaveAdditionalTime returns if the additional time allocated for scheduled mini blocks is elapsed.
IsAllowedToSaveUnderKey returns if saving key-value in data tries under given key is allowed.
IsBuiltinFuncCallWithParam checks if the given transaction data represents a builtin function call with parameters.
IsInProperRound checks if the given round index satisfies the round modulus trigger.
IsScheduledMode returns true if the first mini block from the given body is marked as a scheduled.
IsSetGuardianCall checks if the given transaction data represents the set guardian builtin function call.
IsShardCacherIdentifierForSourceMe checks whether the specified cache is for the pair (sender = me, destination = *).
NewForkInfo creates a new ForkInfo object.
ParseShardCacherIdentifier parses an identifier into its components: sender shard, destination shard.
ShardCacherIdentifier generates a string identifier between 2 shards.
SortHeadersByNonce will sort a given list of headers by nonce.
SortVMOutputInsideData returns the output accounts as a sorted list.
UnmarshalHeader unmarshalls a block header.
UnmarshalMetaHeader unmarshalls a meta header.
UnmarshalShardHeader unmarshalls a shard header.
UnmarshalShardHeaderV1 unmarshalls a header with version 1.
UnmarshalShardHeaderV2 unmarshalls a header with version 2.
# Constants
BHNotarized defines ID of a notarized block header.
BHProcessed defines ID of a processed block header.
BHProposed defines ID of a proposed block header.
BHReceived defines ID of a received block header.
BHReceivedTooLate defines ID of a late received block header.
BlockFinality defines the block finality which is used in meta-chain/shards (the real finality in shards is given by meta-chain).
BuiltInFunctionCall defines ID of a builtin function call.
EpochChangeGracePeriod defines the allowed round numbers till the shard has to change the epoch.
InvalidTransaction defines unknown transaction type.
MaxGasBandwidthPerBatchPerSender defines the maximum gas bandwidth that should be selected for a sender per batch from the cache.
MaxGasFeeHigherFactorAccepted defines the maximum higher factor of gas fee put inside a transaction compared with the real gas used, after which the transaction will be considered an attack and all the gas will be consumed and nothing will be refunded to the sender.
MaxHeaderRequestsAllowed defines the maximum number of missing cross-shard headers (gaps) which could be requested in one round, when node processes a received block.
MaxHeadersToRequestInAdvance defines the maximum number of headers which will be requested in advance, if they are missing.
MaxHeadersToWhitelistInAdvance defines the maximum number of headers whose miniblocks will be whitelisted in advance.
MaxMetaHeadersAllowedInOneShardBlock defines the maximum number of meta headers allowed to be included in one shard block.
MaxMetaNoncesBehind defines the maximum difference between the current meta block nonce and the processed meta block nonce before a shard is considered stuck.
MaxMetaNoncesBehindForGlobalStuck defines the maximum difference between the current meta block nonce and the processed meta block nonce for any shard, where the chain is considered stuck and enters recovery.
MaxNumOfTxsToSelect defines the maximum number of transactions that should be selected from the cache.
MaxRoundsWithoutCommittedBlock defines the maximum rounds to wait for a new block to be committed, before a special action to be applied.
MaxRoundsWithoutNewBlockReceived defines the maximum number of rounds to wait for a new block to be received, before a special action to be applied.
MaxShardHeadersAllowedInOneMetaBlock defines the maximum number of shard headers allowed to be included in one meta block.
MaxShardNoncesBehind defines the maximum difference between the current shard block nonce and the last notarized shard block nonce by meta, before meta is considered stuck.
MaxSyncWithErrorsAllowed defines the maximum allowed number of sync with errors, before a special action to be applied.
MetaBlockValidity defines the block validity which is when checking a metablock.
MinForkRound represents the minimum fork round set by a notarized header received.
MinShardHeadersFromSameShardInOneMetaBlock defines the minimum number of shard headers from the same shard, which would be included in one meta block if they are available.
MoveBalance defines ID of a payment transaction - moving balances.
NonceDifferenceWhenSynced defines the difference between probable highest nonce seen from network and node's last committed block nonce, after which, node is considered himself not synced.
NumTxPerSenderBatchForFillingMiniblock defines the number of transactions to be drawn from the transactions pool, for a specific sender, in a single pass.
RelayedTx defines ID of a transaction of type relayed.
RelayedTxV2 defines the ID of a slim relayed transaction version.
RelayedTxV3 defines the ID of a relayed v3 transaction.
RewardTx defines ID of a reward transaction.
RoundModulusTrigger defines a round modulus on which a trigger for an action will be released.
RoundModulusTriggerWhenSyncIsStuck defines a round modulus on which a trigger for an action when sync is stuck will be released.
SCDeployment defines ID of a transaction to store a smart contract.
SCInvoking defines ID of a transaction of type smart contract call.
SearchMethodJustPeek will make the algorithm invoke just Peek method.
SearchMethodPeekWithFallbackSearchFirst will first try a Peek method.
SearchMethodSearchFirst will make the algorithm invoke just SearchFirst method.
No description provided by the author
# Variables
ErrAccountHasNoActiveGuardian signals that the account has no active guardian.
ErrAccountHasNoGuardianSet signals that the account has no guardians set.
ErrAccountHasNoPendingGuardian signals that the account has no pending guardian.
ErrAccountNotFound signals that the account was not found for the provided address.
ErrAccountNotPayable will be sent when trying to send money to a non-payable account.
ErrAccountStateDirty signals that the accounts were modified before starting the current modification.
ErrAccumulatedFeesDoNotMatch signals that accumulated fees do not match.
ErrAccumulatedFeesInEpochDoNotMatch signals that accumulated fees in epoch do not match.
ErrAsyncCallsDisabled signals that async calls are disabled.
ErrBlockBodyHashMismatch signals that block body hashes does not match.
ErrBlockHashDoesNotMatch signals that header hash does not match with the previous one.
ErrBlockProposerSignatureMissing signals that block proposer signature is missing from the block aggregated sig.
ErrBuiltinFunctionMismatch signals that a builtin function mismatch was detected.
ErrBuiltinFunctionNotExecutable signals that a builtin function is not executable.
ErrBuiltInFunctionsAreDisabled signals that built-in functions are disabled.
ErrCannotReplaceGuardedAccountPendingGuardian signals that a pending guardian on a guarded account cannot be replaced.
ErrConsecutiveMissedBlocksPenaltyLowerThanOne signals that the ConsecutiveMissedBlocksPenalty is lower than 1.
ErrConsumedFeesMismatch signals that the fees consumed from relayer do not match the inner transactions fees.
ErrContainerKeyAlreadyExists signals that an element was already set in the container's map.
ErrCrossShardMBWithoutConfirmationFromMeta signals that miniblock was not yet notarized by metachain.
ErrDecreaseRatingsStepMoreThanMinusOne signals that the decrease rating step has a vale greater than -1.
ErrDeveloperFeesDoNotMatch signals that developer fees do not match.
ErrDevFeesInEpochDoNotMatch signals that developer fees in epoch do not match.
ErrDuplicateThreshold signals that two thresholds are the same.
ErrEmptyConsensusGroup is raised when an operation is attempted with an empty consensus group.
ErrEmptyEpochRewardsConfig signals that the epoch rewards config is empty.
ErrEmptyFloodPreventerList signals that an empty flood preventer list has been provided.
ErrEmptyFunctionName signals that an empty function name has been provided.
ErrEmptyGasLimitSettings signals that the gas limit settings is empty.
ErrEmptyInnerTransactions signals that the inner transactions slice is empty.
ErrEmptyPeerID signals that an empty peer ID has been provided.
ErrEmptyTopic signals that an empty topic has been provided.
ErrEmptyYearSettings signals that the year settings is empty.
ErrEpochDoesNotMatch signals that epoch does not match between headers.
ErrEpochStartDataDoesNotMatch signals that EpochStartData is not the same as the leader created.
ErrFailedTransaction signals that transaction is of type failed.
ErrGasPriceTooHigh signals a too high gas price.
ErrGettingShardDataFromEpochStartData signals that could not get shard data from previous epoch start block.
ErrGuardedTransactionNotExpected signals that a guarded transaction was received for processing but the account is not guarded.
ErrGuardianAddressNotExpected signals that the guardian address is not expected.
ErrGuardianSignatureNotExpected signals that the guardian signature is not expected.
ErrHeaderBodyMismatch signals that the header does not attest all data from the block.
ErrHeaderIsBlackListed signals that the header provided is black listed.
ErrHeaderNotFinal signals that header is not final, and it should be.
ErrHeaderShardDataMismatch signals that shard header does not match created shard info.
ErrHigherNonceInBlock signals that a block with higher nonce than permitted has been provided.
ErrHigherNonceInTransaction signals the nonce in transaction is higher than the account's nonce.
ErrHigherRoundInBlock signals that a block with higher round than permitted has been provided.
ErrHoursToMaxRatingFromStartRatingZero signals that the number of hours to reach max rating step is zero.
ErrIncompatibleReference signals that an incompatible reference was provided when processing a batch.
ErrIncreaseStepLowerThanOne signals that an increase step lower than one has been provided.
ErrIndexDoesNotMatchWithFullyExecutedMiniBlock signals that the given index does not match with a fully executed mini block.
ErrIndexDoesNotMatchWithPartialExecutedMiniBlock signals that the given index does not match with a partial executed mini block.
ErrIndexIsOutOfBound signals that the given index is out of bound.
ErrInsufficientFee signals that the current balance doesn't have the required transaction fee.
ErrInsufficientFunds signals the funds are insufficient for the move balance operation but the transaction fee is covered by the current balance.
ErrInsufficientGasLimitInTx signals that a lower gas limit than required was provided.
ErrInsufficientGasPriceInTx signals that a lower gas price than required was provided.
ErrInterceptedDataNotForCurrentShard signals that intercepted data is not for current shard.
ErrInvalidArguments signals that invalid arguments were given to process built-in function.
ErrInvalidAsyncArguments signals that invalid arguments were given for async/callBack processing.
ErrInvalidBadPeerThreshold signals that an invalid bad peer threshold has been provided.
ErrInvalidBlockRequestOldEpoch signals that invalid block was requested from old epoch.
ErrInvalidBody signals that an invalid body has been provided.
ErrInvalidCacheRefreshIntervalInSec signals that the cacheRefreshIntervalInSec is invalid - zero or less.
ErrInvalidChainID signals that an invalid chain ID was provided.
ErrInvalidContainerKey signals that an element does not exist in the container's map.
ErrInvalidDecayCoefficient signals that the provided decay coefficient is invalid.
ErrInvalidDecayIntervalInSeconds signals that an invalid interval in seconds was provided.
ErrInvalidEpochStartMetaBlockConsensusPercentage signals that a small epoch start meta block consensus percentage has been provided.
ErrInvalidExpiryTimespan signals that an invalid expiry timespan was provided.
ErrInvalidExtraGasLimitGuardedTx signals that an invalid gas limit has been provided in the config file.
ErrInvalidGasModifier signals that provided gas modifier is invalid.
ErrInvalidGasPerDataByte signals that an invalid gas per data byte has been read from config file.
ErrInvalidGenesisTotalSupply signals that invalid genesis total supply was provided.
ErrInvalidInflationPercentages signals that inflation percentages are not correct.
ErrInvalidMaxGasLimitPerBlock signals that an invalid max gas limit per block has been read from config file.
ErrInvalidMaxGasLimitPerMetaBlock signals that an invalid max gas limit per meta block has been read from config file.
ErrInvalidMaxGasLimitPerMetaMiniBlock signals that an invalid max gas limit per meta mini block has been read from config file.
ErrInvalidMaxGasLimitPerMiniBlock signals that an invalid max gas limit per mini block has been read from config file.
ErrInvalidMaxGasLimitPerTx signals that an invalid max gas limit per tx has been read from config file.
ErrInvalidMaxGasPriceSetGuardian signals that an invalid maximum gas price has been provided in the config file.
ErrInvalidMaxScore signals that an invalid maximum score was provided.
ErrInvalidMetaHeader signals that a wrong implementation of HeaderHandler was provided.
ErrInvalidMetaTransaction signals that meta transaction is invalid.
ErrInvalidMiniBlockType signals that an invalid miniblock type has been provided.
ErrInvalidMinimumGasLimitForTx signals that an invalid minimum gas limit for transactions has been read from config file.
ErrInvalidMinimumGasPrice signals that an invalid gas price has been read from config file.
ErrInvalidMinScore signals that an invalid minimum score was provided.
ErrInvalidNonceRequest signals that invalid nonce was requested.
ErrInvalidPeerAccount signals that a peer account is invalid.
ErrInvalidPeerSubType signals that an invalid peer subtype was provided.
ErrInvalidProcessWaitTime signals that an invalid process wait time was provided.
ErrInvalidRcvAddr signals that an invalid receiver address was provided.
ErrInvalidRewardsPercentages signals that rewards percentages are not correct.
ErrInvalidRewardsTopUpGradientPoint signals that the top-up gradient point is invalid.
ErrInvalidSetGuardianEpochsDelay signals an invalid configuration for the epochs delay.
ErrInvalidShardCacherIdentifier signals an invalid identifier.
ErrInvalidShardId signals that the shard id is invalid.
ErrInvalidSndAddr signals that an invalid sender address was provided.
ErrInvalidTransactionVersion signals that an invalid transaction version has been provided.
ErrInvalidTxInPool signals an invalid transaction in the transactions pool.
ErrInvalidUnitValue signals that an invalid unit value was provided.
ErrInvalidUserNameLength signals that provided username length is invalid.
ErrInvalidValue signals that an invalid value was provided.
ErrInvalidVMInputGasComputation signals that invalid vm input gas computation was provided.
ErrLenMismatch signals that 2 or more slices have different lengths.
ErrLogNotFound is the error returned when a transaction has no logs.
ErrLowerNonceInBlock signals that a block with lower nonce than permitted has been provided.
ErrLowerNonceInTransaction signals the nonce in transaction is lower than the account's nonce.
ErrLowerRoundInBlock signals that a header round is too low for processing it.
ErrMarshalWithoutSuccess signals that marshal some data was not done with success.
ErrMaxAccumulatedFeesExceeded signals that max accumulated fees has been exceeded.
ErrMaxBlockSizeReached signals that max block size has been reached.
ErrMaxCallsReached signals that the allowed max number of calls was reached.
ErrMaxDeveloperFeesExceeded signals that max developer fees has been exceeded.
ErrMaxGasLimitPerBlockInSelfShardIsReached signals that max gas limit per block in self shard has been reached.
ErrMaxGasLimitPerMiniBlockInReceiverShardIsReached signals that max gas limit per mini block in receiver shard has been reached.
ErrMaxGasLimitPerOneTxInReceiverShardIsReached signals that max gas limit per one transaction in receiver shard has been reached.
ErrMaxGasLimitUsedForDestMeTxsIsReached signals that max gas limit used for dest me txs has been reached.
ErrMaxRatingIsSmallerThanMinRating signals that the max rating is smaller than the min rating value.
ErrMaxRatingZero signals that maxrating with a value of zero has been provided.
ErrMessageExpired signals that a received message is expired.
ErrMetaHeaderEpochOutOfRange signals that the given header is out of accepted range.
ErrMiniBlockHashMismatch signals that miniblock hashes does not match.
ErrMiniBlockNumMissMatch signals that number of miniblocks does not match.
ErrMiniBlocksInWrongOrder signals the miniblocks are in wrong order.
ErrMinRatingSmallerThanOne signals that the min rating is smaller than the min value of 1.
ErrMissingBody signals that body of the block is missing.
ErrMissingHashForHeaderNonce signals that hash of the block is missing.
ErrMissingHeader signals that header of the block is missing.
ErrMissingMiniBlock signals that mini block is missing.
ErrMissingMiniBlockHeader signals that mini block header is missing.
ErrMissingPreProcessor signals that required pre-processor is missing.
ErrMissingTransaction signals that one transaction is missing.
ErrMoreGasConsumedThanProvided signals that VM used more gas than provided.
ErrMoreGasThanGasLimitPerBlock signals that more gas was provided than gas limit per block.
ErrMoreGasThanGasLimitPerMiniBlockForSafeCrossShard signals that more gas was provided than gas limit per mini block for safe cross shard.
ErrMultipleRelayedTxTypesIsNotAllowed signals that multiple types of relayed tx is not allowed.
ErrNegativeBalanceDeltaOnCrossShardAccount signals that negative balance delta was given on cross shard account.
ErrNegativeValue signals that a negative value has been detected, and it is not allowed.
ErrNilAccountsAdapter defines the error when trying to use a nil AccountsAddapter.
ErrNilAccountsDBSyncer signals that a nil accounts db syncer has been provided.
ErrNilAccountTxsPerShard signals a nil mapping for account transactions to shard.
ErrNilAdditionalData signals that additional data is nil.
ErrNilAddressContainer signals that an operation has been attempted to or with a nil AddressContainer implementation.
ErrNilAllowExternalQueriesChan signals that a nil channel for signaling the allowance of external queries provided is nil.
ErrNilAntifloodHandler signals that a nil antiflood handler has been provided.
ErrNilAppStatusHandler defines the error for setting a nil AppStatusHandler.
ErrNilArgumentParser signals that the argument parser is nil.
ErrNilArgumentStruct signals that a function has received nil instead of an instantiated Arg..
ErrNilBadTxHandler signals that bad tx handler is nil.
ErrNilBalanceComputationHandler signals that a nil balance computation handler has been provided.
ErrNilBlackListCacher signals that a nil black list cacher was provided.
ErrNilBlackListedPkCache signals that a nil black listed public key cache has been provided.
ErrNilBlockBody signals that an operation has been attempted to or with a nil block body.
ErrNilBlockChain signals that an operation has been attempted to or with a nil blockchain.
ErrNilBlockChainHook signals that nil blockchain hook has been provided.
ErrNilBlockHeader signals that an operation has been attempted to or with a nil block header.
ErrNilBlockProcessingCutoffHandler signals that a nil block processing cutoff handler has been provided.
ErrNilBlockProcessor signals that an operation has been attempted to or with a nil BlockProcessor implementation.
ErrNilBlockSizeComputationHandler signals that a nil block size computation handler has been provided.
ErrNilBlockSizeThrottler signals that block size throttler si nil.
ErrNilBlockTracker signals that a nil block tracker was provided.
ErrNilBootStorer signals that the provided boot storer is bil.
ErrNilBootstrapComponentsHolder signals that a nil bootstrap components holder was provided.
ErrNilBootstrapper signals that a nil bootstraper has been provided.
ErrNilBuffer signals that a provided byte buffer is nil.
ErrNilBuiltInFunction signals that built-in function is nil.
ErrNilCacher signals that a nil cache has been provided.
ErrNilChunksProcessor signals that a nil chunks processor has been provided.
ErrNilContainerElement signals when trying to add a nil element in the container.
ErrNilCoreComponentsHolder signals that a nil core components holder was provided.
ErrNilCrawlerAllowedAddress signals that no crawler allowed address was found.
ErrNilCryptoComponentsHolder signals that a nil crypto components holder was provided.
ErrNilCurrentNetworkEpochProvider signals that a nil CurrentNetworkEpochProvider handler has been provided.
ErrNilDataComponentsHolder signals that a nil data components holder was provided.
ErrNilDataPoolHolder signals that the data pool holder is nil.
ErrNilDataToProcess signals that nil data was provided.
ErrNilDebugger signals that a nil debug handler has been provided.
ErrNilDnsAddresses signals that nil dns addresses map was provided.
ErrNilDoubleTransactionsDetector signals that a nil double transactions detector has been provided.
ErrNilEconomicsData signals that nil economics data has been provided.
ErrNilEconomicsFeeHandler signals that fee handler is nil.
ErrNilEnableEpochsHandler signals that a nil enable epochs handler has been provided.
ErrNilEnableRoundsHandler signals a nil enable rounds handler has been provided.
ErrNilEpochEconomics signals that nil end of epoch econimics was provided.
ErrNilEpochHandler signals that a nil epoch handler was provided.
ErrNilEpochNotifier signals that the provided EpochNotifier is nil.
ErrNilEpochStartDataCreator signals that nil epoch start data creator was provided.
ErrNilEpochStartNotifier signals that the provided epochStartNotifier is nil.
ErrNilEpochStartSystemSCProcessor signals that nil epoch start system sc processor was provided.
ErrNilEpochStartTrigger signals that a nil start of epoch trigger was provided.
ErrNilEpochStartValidatorInfoCreator signals that nil epoch start validator info creator was provided.
ErrNilESDTGlobalSettingsHandler signals that nil global settings handler was provided.
ErrNilESDTTransferParser signals that a nil ESDT transfer parser has been provided.
ErrNilFailedTxLogsAccumulator signals that a nil failed transaction logs accumulator has been provided.
ErrNilFallbackHeaderValidator signals that a nil fallback header validator has been provided.
ErrNilForkDetector signals that the fork detector is nil.
ErrNilGasHandler signals that gas handler is nil.
ErrNilGasSchedule signals that an operation has been attempted with a nil gas schedule.
ErrNilGuardedAccountHandler signals that a nil guarded account handler was provided.
ErrNilGuardianChecker signals that a nil guardian checker was provided.
ErrNilGuardianServiceUID signals that a nil guardian service identifier was provided.
ErrNilHardforkTrigger signals that a nil hardfork trigger has been provided.
ErrNilHasher signals that an operation has been attempted to or with a nil hasher implementation.
ErrNilHaveTimeHandler signals that a nil have time handler func was provided.
ErrNilHeaderHandler signals that a nil header handler has been provided.
ErrNilHeaderIntegrityVerifier signals that a nil header integrity verifier has been provided.
ErrNilHeadersDataPool signals that a nil headers pool has been provided.
ErrNilHeaderSigVerifier signals that a nil header sig verifier has been provided.
ErrNilHeaderValidator signals that nil header validator has been provided.
ErrNilHeartbeatCacher signals that a nil heartbeat cacher was provided.
ErrNilHistoryRepository signals that history processor is nil.
ErrNilInterceptedDataFactory signals that a nil intercepted data factory was provided.
ErrNilInterceptedDataProcessor signals that a nil intercepted data processor was provided.
ErrNilInterceptorContainer signals that nil interceptor container has been provided.
ErrNilInterceptorThrottler signals that a nil interceptor throttler was provided.
ErrNilIntermediateProcessor signals that intermediate processors is nil.
ErrNilIntermediateProcessorContainer signals that intermediate processors container is nil.
ErrNilIntermediateTransactionHandler signals that nil intermediate transaction handler was provided.
ErrNilIsMaxBlockSizeReachedHandler signals a nil max block size reached handler.
ErrNilIsShardStuckHandler signals a nil shard stuck handler.
ErrNilKeyGen signals that an operation has been attempted to or with a nil single sign key generator.
ErrNilLocker signals that a nil locker was provided.
ErrNilManagedPeersHolder signals that a nil managed peers holder has been provided.
ErrNilMarshalizer signals that an operation has been attempted to or with a nil Marshalizer implementation.
ErrNilMessage signals that a nil message has been received.
ErrNilMessenger signals that a nil Messenger object was provided.
ErrNilMetaBlockHeader signals that an operation has been attempted to or with a nil metablock.
ErrNilMetaBlocksPool signals that a nil meta blocks pool was used.
ErrNilMinChanceIfZero signals that there was no min chance provided if a chance is still needed.
ErrNilMiniBlock signals that an operation has been attempted with a nil miniblock.
ErrNilMiniBlockPool signals that a nil mini blocks pool was used.
ErrNilMiniBlocks signals that an operation has been attempted with a nil mini-block.
ErrNilMiniBlocksProvider signals that a nil miniblocks data provider has been passed over.
ErrNilMultiSignerContainer signals that the given multisigner container is nil.
ErrNilMultiSigVerifier signals that a nil multi-signature verifier is used.
ErrNilNetworkWatcher signals that a nil network watcher has been provided.
ErrNilNFTStorageHandler signals that nil NFT storage handler has been provided.
ErrNilNodesConfigProvider signals that an operation has been attempted to or with a nil nodes config provider.
ErrNilNodesCoordinator signals that an operation has been attempted to or with a nil nodes coordinator.
ErrNilNodesSetup signals that nil nodes setup has been provided.
ErrNilNumConnectedPeersProvider signals that a nil number of connected peers provider has been provided.
ErrNilOrEmptyList signals that a nil or empty list was provided.
ErrNilOutportDataProvider signals that a nil outport data provider has been given.
ErrNilOutportHandler signals that outport is nil.
ErrNilPayloadValidator signals that a nil payload validator was provided.
ErrNilPeerAccountsAdapter signals that a nil peer accounts database was provided.
ErrNilPeerAuthenticationCacher signals that a nil peer authentication cacher was provided.
ErrNilPeerShardMapper signals that a nil peer shard mapper has been provided.
ErrNilPeerSignatureHandler signals that a nil peer signature handler was provided.
ErrNilPeerValidatorMapper signals that nil peer validator mapper has been provided.
ErrNilPendingMiniBlocksHandler signals that a nil pending miniblocks handler has been provided.
ErrNilPoolsHolder signals that an operation has been attempted to or with a nil pools holder object.
ErrNilPreferredPeersHolder signals that preferred peers holder is nil.
ErrNilPreProcessor signals that preprocessors is nil.
ErrNilPreProcessorsContainer signals that preprocessors container is nil.
ErrNilPreviousBlockHash signals that an operation has been attempted with a nil previous block header hash.
ErrNilPrevRandSeed signals that a nil previous rand seed has been provided.
ErrNilProcessDebugger signals that a nil process debugger was provided.
ErrNilProcessedMiniBlocksTracker signals that a nil processed mini blocks tracker has been provided.
ErrNilProtocolSustainabilityAddress signals that a nil protocol sustainability address was provided.
ErrNilPubkeyConverter signals that an operation has been attempted to or with a nil public key converter implementation.
ErrNilPubKeysBitmap signals that an operation has been attempted with a nil public keys bitmap.
ErrNilQuotaStatusHandler signals that a nil quota status handler has been provided.
ErrNilRandSeed signals that a nil rand seed has been provided.
ErrNilRater signals that nil rater has been provided.
ErrNilRatingsInfoHandler signals that nil ratings info handler has been provided.
ErrNilRcvAddr signals that an operation has been attempted to or with a nil receiver address.
ErrNilReceiptHandler signals that receipt handler is nil.
ErrNilReceiptsRepository signals that a nil receipts repository has been provided.
ErrNilRelayedTxV3Processor signals that a nil relayed tx v3 processor has been provided.
ErrNilRelayerAccount signals that a nil relayer accouont has been provided.
ErrNilRequestHandler signals that a nil request handler interface was provided.
ErrNilRewardsCreator signals that nil epoch start rewards creator was provided.
ErrNilRewardsHandler signals that rewards handler is nil.
ErrNilRewardsTxProcessor signals that the rewards transaction processor is nil.
ErrNilRewardTransaction signals that the reward transaction is nil.
ErrNilRewardTxDataPool signals that the reward transactions pool is nil.
ErrNilRootHash signals that an operation has been attempted with a nil root hash.
ErrNilRoundHandler signals that an operation has been attempted to or with a nil RoundHandler implementation.
ErrNilRoundNotifier signals that the provided EpochNotifier is nil.
ErrNilRoundTimeDurationHandler signals that an operation has been attempted to or with a nil RoundTimeDurationHandler implementation.
ErrNilScAddress signals that a nil smart contract address has been provided.
ErrNilSCDestAccount signals that destination account is nil.
ErrNilScheduledTxsExecutionHandler signals that scheduled txs execution handler is nil.
ErrNilScQueryElement signals that a nil sc query service element was provided.
ErrNilSCToProtocol signals that nil smart contract to protocol handler has been provided.
ErrNilSentSignatureTracker defines the error for setting a nil SentSignatureTracker.
ErrNilShardCoordinator signals that an operation has been attempted to or with a nil shard coordinator.
ErrNilShardedDataCacherNotifier signals that a nil sharded data cacher notifier has been provided.
ErrNilSignature signals that an operation has been attempted with a nil signature.
ErrNilSignaturesHandler signals that a nil signatures handler was provided.
ErrNilSingleSigner signals that a nil single signer is used.
ErrNilSmartContractProcessor signals that smart contract call executor is nil.
ErrNilSmartContractResult signals that the smart contract result is nil.
ErrNilSmartContractResultProcessor signals that smart contract result processor is nil.
ErrNilSndAddr signals that an operation has been attempted to or with a nil sender address.
ErrNilStakingDataProvider signals that a nil staking data provider was used.
ErrNilStatusComponentsHolder signals that a nil status components holder was provided.
ErrNilStatusCoreComponentsHolder signals that a nil status core components holder was provided.
ErrNilStorage signals that a nil storage has been provided.
ErrNilStorageService signals that a nil storage service has been provided.
ErrNilStore signals that the provided storage service is nil.
ErrNilSyncTimer signals that the sync timer is nil.
ErrNilSystemSCConfig signals that nil system sc config was provided.
ErrNilTemporaryAccountsHandler signals that temporary accounts handler is nil.
ErrNilTopicFloodPreventer signals that a nil topic flood preventer has been provided.
ErrNilTransaction signals that an operation has been attempted to or with a nil transaction.
ErrNilTransactionCoordinator signals that transaction coordinator is nil.
ErrNilTransactionPool signals that a nil transaction pool was used.
ErrNilTransactionVersionChecker signals that provided transaction version checker is nil.
ErrNilTxBlockBody signals that an operation has been attempted to or with a nil tx block body.
ErrNilTxDataPool signals that a nil transaction pool has been provided.
ErrNilTxExecutionOrderHandler signals that a nil transaction execution order handler was provided.
ErrNilTxForCurrentBlockHandler signals that nil tx for current block handler has been provided.
ErrNilTxHash signals that an operation has been attempted with a nil hash.
ErrNilTxLogsProcessor is the error returned when a transaction has no logs.
ErrNilTxMaxTotalCostHandler signals a nil transaction max total cost.
ErrNilTxProcessor signals that a nil transactions processor was used.
ErrNilTxStorage signals that a nil transaction storage has been provided.
ErrNilTxTypeHandler signals that tx type handler is nil.
ErrNilTxValidator signals that a nil tx validator has been provided.
ErrNilUint64Converter signals that uint64converter is nil.
ErrNilUnsignedTxDataPool signals that the unsigned transactions pool is nil.
ErrNilUnsignedTxHandler signals that the unsigned tx handler is nil.
ErrNilUserAccount signals that nil user account was provided.
ErrNilUTxDataPool signals that unsigned transaction pool is nil.
ErrNilUTxStorage signals that unsigned transaction storage is nil.
ErrNilValidatorInfoPool signals that a nil validator info pool has been provided.
ErrNilValidatorInfos signals that a nil validator infos has been provided.
ErrNilValidatorStatistics signals that a nil validator statistics has been provided.
ErrNilValidityAttester signals that a nil validity attester has been provided.
ErrNilValue signals the value is nil.
ErrNilValueFromRewardTransaction signals that the transfered value is nil.
ErrNilVersionedHeaderFactory signals that the versioned header factory is nil.
ErrNilVMContainer defines the error when trying to use a nil vm container.
ErrNilVmInput signals that provided vm input is nil.
ErrNilVMOutput signals that vmoutput is nil.
ErrNilWhiteListHandler signals that white list handler is nil.
ErrNoChancesForMaxThreshold signals that the max threshold has no chance defined.
ErrNoChancesProvided signals that there were no chances provided.
ErrNoDataInMessage signals that no data was found after parsing received p2p message.
ErrNodeIsNotSynced signals that the VM query cannot be executed because the node is not synced and the request required this.
ErrNotAllowedToWriteUnderProtectedKey signals that writing under protected key is not allowed.
ErrNotarizedHeadersSliceForShardIsNil signals that the slice holding notarized headers for shard is nil.
ErrNotarizedHeadersSliceIsNil signals that the slice holding notarized headers is nil.
ErrNotEnoughGas signals that not enough gas has been provided.
ErrNotEnoughGasInUserTx signals that not enough gas was provided in user tx.
ErrNotEnoughValidBlocksInStorage signals that bootstrap from storage failed due to not enough valid blocks stored.
ErrNotEpochStartBlock signals that block is not of type epoch start.
ErrNoTxToProcess signals that no transaction were sent for processing.
ErrNoVM signals that no SCHandler has been set.
ErrNumOfMiniBlocksAndMiniBlocksHeadersMismatch signals that number of mini blocks and mini blocks headers does not match.
ErrOnlyValidatorsCanUseThisTopic signals that topic can be used by validator only.
ErrOriginatorIsBlacklisted signals that a message originator is blacklisted on the current node.
ErrOverallBalanceChangeFromSC signals that all sumed balance changes are not zero.
ErrOverflow signals that an overflow occured.
ErrProcessClosed signals that an incomplete processing occurred due to the early process closing.
ErrPropertyTooLong signals that a heartbeat property was too long.
ErrPropertyTooShort signals that a heartbeat property was too short.
ErrQueriesNotAllowedYet signals that the node is not ready yet to process VM Queries.
ErrRandSeedDoesNotMatch signals that random seed does not match with the previous one.
ErrReceiptsHashMissmatch signals that overall receipts has does not match.
ErrRecursiveRelayedTxIsNotAllowed signals that recursive relayed tx is not allowed.
ErrRelayedGasPriceMissmatch signals that relayed gas price is not equal with user tx.
ErrRelayedTxBeneficiaryDoesNotMatchReceiver signals that an invalid address was provided in the relayed tx.
ErrRelayedTxDisabled signals that relayed tx are disabled.
ErrRelayedTxGasLimitMissmatch signals that relayed tx gas limit is higher than user tx gas limit.
ErrRelayedTxV2Disabled signals that the v2 version of relayed tx is disabled.
ErrRelayedTxV2ZeroVal signals that the v2 version of relayed tx should be created with 0 as value.
ErrRelayedTxV3Disabled signals that the v3 version of relayed tx is disabled.
ErrRelayedTxV3GasLimitMismatch signals that relayed tx v3 gas limit is higher than user tx gas limit.
ErrRelayedTxV3InvalidDataField signals that the data field is invalid.
ErrRelayedTxV3RelayerMismatch signals that the relayer address of the inner tx does not match the real relayer.
ErrRelayedTxV3SenderDoesNotMatchReceiver signals that the sender of relayed tx v3 does not match the receiver.
ErrRelayedTxV3SenderShardMismatch signals that the sender from inner transaction is from a different shard than relayer.
ErrRelayedTxV3TooManyInnerTransactions signals that too many inner transactions were provided.
ErrRelayedTxV3ZeroVal signals that the v3 version of relayed tx should be created with 0 as value.
ErrRelayedTxValueHigherThenUserTxValue signals that relayed tx value is higher than user tx value.
ErrRelayedV3GasPriceMismatch signals that relayed v3 gas price is not equal with inner tx.
ErrReservedFieldInvalid signals that reserved field has an invalid content.
ErrResultingSCRIsTooBig signals that resulting smart contract result is too big.
ErrRewardMiniBlockNotFromMeta signals that miniblock has a different sender shard than meta.
ErrRootStateDoesNotMatch signals that root state does not match.
ErrSCDeployFromSCRIsNotPermitted signals that operation is not permitted.
ErrScheduledMiniBlocksMismatch signals that scheduled mini blocks created and executed in the last block, which are not yet final, do not match with the ones received in the next proposed body.
ErrScheduledRootHashDoesNotMatch signals that scheduled root hash does not match.
ErrShardIdMissmatch signals shard ID does not match expectations.
ErrShardIsStuck signals that a shard is stuck.
ErrSignedBlocksThresholdNotBetweenZeroAndOne signals that the signed blocks threshold is not between 0 and 1.
ErrSmartContractDeploymentIsDisabled signals that smart contract deployment was disabled.
ErrStartRatingNotBetweenMinAndMax signals that the start rating is not between min and max rating.
ErrStateChangedWhileExecutingVmQuery signals that the state has been changed while executing a vm query and the request required not to.
ErrSystemBusy signals that the system is busy.
ErrTimeIsOut signals that time is out.
ErrTooManyReceiptsMiniBlocks signals that there were too many receipts miniblocks created.
ErrTransactionAndAccountGuardianMismatch signals a mismatch between the guardian on the account and the one on the transaction.
ErrTransactionIsNotWhitelisted signals that a transaction is not whitelisted.
ErrTransactionNotExecutable signals that a transaction is not executable and gas will not be consumed.
ErrTransactionSignedWithHashIsNotEnabled signals that a transaction signed with hash is not enabled.
ErrTransferAndExecuteByUserAddressesAreNil signals that transfer and execute by user addresses are nil.
ErrTrieNodeIsNotWhitelisted signals that a trie node is not whitelisted.
ErrTxNotFound signals that a transaction has not found.
ErrTxValueOutOfBounds signals that transaction value is out of bounds.
ErrTxValueTooBig signals that transaction value is too big.
ErrUnknownBlockType signals that block type is not correct.
ErrUnmarshalWithoutSuccess signals that unmarshal some data was not done with success.
ErrUpgradeNotAllowed signals that upgrade is not allowed.
ErrUserNameDoesNotMatch signals that username does not match.
ErrUserNameDoesNotMatchInCrossShardTx signals that username does not match in case of cross shard tx.
ErrValidatorInfoMiniBlockNotFromMeta signals that miniblock has a different sender shard than meta.
ErrValidatorStatsRootHashDoesNotMatch signals that the root hash for the validator statistics does not match.
ErrWrongNonceInBlock signals the nonce in block is different from expected nonce.
ErrWrongNonceInVMOutput signals that nonce in vm output is wrong.
ErrWrongTransaction signals that transaction is invalid.
ErrWrongTransactionType signals that transaction is invalid.
ErrWrongTypeAssertion signals that a type assertion failed.
ErrWrongTypeInContainer signals that a wrong type of object was found in container.
ErrWrongTypeInMiniBlock signals that type is not correct for processing.
ErrZeroMaxComputableRounds signals that a value of zero was provided on the maxComputableRounds.
ErrZeroMaxConsecutiveRoundsOfRatingDecrease signals that a value of zero was provided on the MaxConsecutiveRoundsOfRatingDecrease.
# Structs
BaseOperationCost defines cost for base operation cost.
BuiltInCost defines cost for built-in methods.
CheckedChunkResult is the DTO used to hold the results after checking a chunk of intercepted data.
ForkInfo hold the data related to a detected fork.
GasCost holds all the needed gas costs for system smart contracts.
RequiredDataPool represents a structure that can hold a list of required data.
ScheduledInfo holds all the info needed for scheduled SC execution.
SCQuery represents a prepared query for executing a function of the smart contract.
# Interfaces
AccountsDBSyncer defines the methods for the accounts db syncer.
AntifloodDebugger defines an interface for debugging the antiflood behavior.
ArgumentsParser defines the functionality to parse transaction data into arguments and code for smart contracts.
BlockChainHookHandler defines the actions which should be performed by implementation.
BlockChainHookWithAccountsAdapter defines an extension of BlockChainHookHandler with the AccountsAdapter exposed.
BlockProcessor is the main interface for block execution engine.
BlockSizeThrottler defines the functionality of adapting the node to the network speed/latency when it should send a block to its peers which should be received in a limited time frame.
BlockTracker defines the functionality for node to track the blocks which are received from network.
BootStorer is the interface needed by bootstrapper to read/write data in storage.
Bootstrapper is an interface that defines the behaviour of a struct that is able to synchronize the node.
BootstrapperFromStorage is the interface needed by boot component to load data from storage.
CallArgumentsParser defines the functionality to parse transaction data into call arguments.
Checker provides functionality to checks the integrity and validity of a data structure.
CoreComponentsHolder holds the core components needed by the interceptors.
CryptoComponentsHolder holds the crypto components needed by the interceptors.
CurrentNetworkEpochProviderHandler is an interface able to compute if the provided epoch is active on the network or not.
DataMarshalizer defines the behavior of a structure that is able to marshalize containing data.
DataPacker can split a large slice of byte slices in smaller packets.
Debugger defines what a process debugger implementation should do.
DeployArgumentsParser defines the functionality to parse transaction data into call arguments.
DoubleTransactionDetector is able to detect if a transaction hash is present more than once in a block body.
EconomicsDataHandler provides some economics related computation and read access to economics data.
EnableRoundsHandler is an interface which can be queried to check for round activation features/fixes.
EndOfEpochEconomics defines the functionality that is needed to compute end of epoch economics data.
EpochBootstrapper defines the actions needed by bootstrapper.
EpochHandler defines what a component which handles current epoch should be able to do.
EpochNotifier can notify upon an epoch change and provide the current epoch.
EpochStartDataCreator defines the functionality for node to create epoch start data.
EpochStartEventNotifier provides Register and Unregister functionality for the end of epoch events.
EpochStartSystemSCProcessor defines the functionality for the metachain to process system smart contract and end of epoch.
EpochStartTriggerHandler defines that actions which are needed by processor for start of epoch.
EpochStartValidatorInfoCreator defines the functionality for the metachain to create validator statistics at end of epoch.
ESDTPauseHandler provides IsPaused function for an ESDT token.
ESDTRoleHandler provides IsAllowedToExecute function for an ESDT.
FailedTxLogsAccumulator defines a component able to accumulate logs during a relayed tx execution.
FallbackHeaderValidator defines the behaviour of a component able to signal when a fallback header validation could be applied.
FeeHandler is able to perform some economics calculation on a provided transaction.
FloodPreventer defines the behavior of a component that is able to signal that too many events occurred on a provided identifier between Reset calls.
ForkDetector is an interface that defines the behaviour of a struct that is able to detect forks.
GasHandler is able to perform some gas calculation.
GuardedAccountHandler allows setting and getting the configured account guardian.
GuardianChecker can check an account guardian.
HashAccesser interface provides functionality over hashable objects.
HdrValidatorHandler defines the functionality that is needed for a HdrValidator to validate a header.
HeaderConstructionValidator provides functionality to verify header construction.
HeaderIntegrityVerifier encapsulates methods useful to check that a header's integrity is correct.
InterceptedChunksProcessor defines the component that is able to process chunks of intercepted data.
InterceptedData represents the interceptor's view of the received data.
InterceptedDataFactory can create new instances of InterceptedData.
InterceptedDebugger defines an interface for debugging the intercepted data.
InterceptedHeaderSigVerifier is the interface needed at interceptors level to check that a header's signature is correct.
InterceptedSignedTransactionHandler provides additional handling for signed transactions.
InterceptedTransactionHandler defines an intercepted data wrapper over transaction handler that has receiver and sender shard getters.
Interceptor defines what a data interceptor should do It should also adhere to the p2p.MessageProcessor interface so it can wire to a p2p.Messenger.
InterceptorProcessor further validates and saves received data.
InterceptorsContainer defines an interceptors holder data type with basic functionality.
InterceptorsContainerFactory defines the functionality to create an interceptors container.
InterceptorThrottler can monitor the number of the currently running interceptor go routines.
IntermediateProcessorContainer defines an IntermediateProcessor holder data type with basic functionality.
IntermediateProcessorsContainerFactory defines the functionality to create an IntermediateProcessors container.
IntermediateTransactionHandler handles transactions which are not resolved in only one step.
MiniBlockProvider defines what a miniblock data provider should do.
NetworkConnectionWatcher defines a watchdog functionality used to specify if the current node is still connected to the rest of the network.
NetworkShardingCollector defines the updating methods used by the network sharding component.
NodesCoordinator provides Validator methods needed for the peer processing.
NumConnectedPeersProvider defines the actions that a component that provides the number of connected peers should do.
P2PAntifloodHandler defines the behavior of a component able to signal that the system is too busy (or flooded) processing p2p messages.
PayableHandler provides IsPayable function which returns if an account is payable or not.
PeerAuthenticationPayloadValidator defines the operations supported by an entity able to validate timestamps found in peer authentication messages.
PeerBlackListCacher can determine if a certain peer id is or not blacklisted.
PeerChangesHandler will create the peer changes data for current block and will verify them.
PeerShardMapper can return the public key of a provided peer ID.
PeerValidatorMapper can determine the peer info from a peer id.
PendingMiniBlocksHandler is an interface to keep unfinalized miniblocks.
PoolsCleaner defines the functionality to clean pools for old records.
PreferredPeersHolderHandler defines the behavior of a component able to handle preferred peers operations.
PreProcessor is an interface used to prepare and process transaction data.
PreProcessorExecutionInfoHandler handles pre processor execution info needed by the transactions preprocessors.
PreProcessorsContainer defines an PreProcessors holder data type with basic functionality.
PreProcessorsContainerFactory defines the functionality to create an PreProcessors container.
ProcessedMiniBlocksTracker handles tracking of processed mini blocks.
RatingChanceHandler provides the methods needed for the computation of chances from the Rating.
RatingsInfoHandler defines the information needed for the rating computation.
RatingsStepHandler defines the information needed for the rating computation on shards or meta.
RelayedTxV3Processor defines a component able to check and process relayed transactions v3.
RequestBlockBodyHandler is the interface needed by process block.
RequestHandler defines the methods through which request to data can be made.
RewardsCreator defines the functionality for the metachain to create rewards at end of epoch.
RewardsHandler will return information about rewards.
RewardTransactionPreProcessor prepares the processing of reward transactions.
RewardTransactionProcessor is the interface for reward transaction execution engine.
RoundHandler defines the actions which should be handled by a round implementation.
RoundNotifier can notify upon an epoch change and provide the current epoch.
RoundTimeDurationHandler defines the methods to get the time duration of a round.
ScheduledBlockProcessor is the interface for the scheduled miniBlocks execution part of the block processor.
ScheduledTxsExecutionHandler defines the functionality for execution of scheduled transactions.
SCQueryService defines how data should be get from a SC account.
SelectionChance defines the actions which should be handled by a round implementation.
SentSignaturesTracker defines a component able to handle sent signature from self.
ShardedPool is a perspective of the sharded data pool.
SignaturesHandler defines the behavior of a struct able to handle signatures.
SignedDataValidator provides functionality to check the validity and signature of a data structure.
SigVerifier provides functionality to verify a signature of a signed data structure that holds also the verifying parameters.
SmartContractProcessor is the main interface for the smart contract caller engine.
SmartContractProcessorFacade is the main interface for smart contract result execution engine.
SmartContractProcessorFull is the main interface for smart contract result execution engine.
SmartContractResultProcessor is the main interface for smart contract result execution engine.
SmartContractToProtocolHandler is able to translate data from smart contract state into protocol changes.
StatusCoreComponentsHolder holds the status core components.
StorageArgumentsParser defines the functionality to parse transaction data into call arguments.
TimeCacher defines the cache that can keep a record for a bounded time.
TopicFloodPreventer defines the behavior of a component that is able to signal that too many events occurred on a provided identifier between Reset calls, on a given topic.
TopicHandler defines the functionality needed by structs to manage topics and message processors.
TransactionCoordinator is an interface to coordinate transaction processing using multiple processors.
TransactionFeeHandler processes the transaction fee.
TransactionLogProcessor is the main interface for saving logs generated by smart contract calls.
TransactionLogProcessorDatabase is interface the for saving logs also in RAM.
TransactionProcessor is the main interface for transaction execution engine.
TransactionVerifier interface validates if the transaction is good and if it should be processed.
TxGasHandler handles a transaction gas and gas cost.
TxsSenderHandler handles transactions sending.
TxTypeHandler is an interface to calculate the transaction type.
TxValidator can determine if a provided transaction handler is valid or not from the process point of view.
TxValidatorHandler defines the functionality that is needed for a TxValidator to validate a transaction.
TxVersionCheckerHandler defines the functionality that is needed for a TxVersionChecker to validate transaction version.
ValidatorInfoSyncer defines the method needed for validatorInfoProcessing.
ValidatorsProvider is the main interface for validators' provider.
ValidatorStatisticsProcessor is the main interface for validators' consensus participation statistics.
ValidityAttester is able to manage the valid blocks.
VirtualMachinesContainer defines a virtual machine holder data type with basic functionality.
VirtualMachinesContainerFactory defines the functionality to create a virtual machine container.
WhiteListHandler is the interface needed to add whitelisted data.
# Type aliases
BlockHeaderState specifies which is the state of the block header received.
ShardedCacheSearchMethod defines the algorithm for searching through a sharded cache.
TransactionType specifies the type of the transaction.