Versions in this module Expand all Collapse all v1 v1.999.0 Nov 17, 2022 Changes in this version + type APIPackageConfig struct + Routes []RouteConfig + type ActivationRoundByName struct + Name string + Round uint64 + type AdditionalConnectionsConfig struct + MaxFullHistoryObservers uint32 + type AntifloodConfig struct + Cache CacheConfig + Enabled bool + FastReacting FloodPreventerConfig + NumConcurrentResolverJobs int32 + OutOfSpecs FloodPreventerConfig + PeerMaxOutput AntifloodLimitsConfig + SlowReacting FloodPreventerConfig + Topic TopicAntifloodConfig + TxAccumulator TxAccumulatorConfig + WebServer WebServerAntifloodConfig + type AntifloodDebugConfig struct + CacheSize int + Enabled bool + IntervalAutoPrintInSeconds int + type AntifloodLimitsConfig struct + BaseMessagesPerInterval uint32 + IncreaseFactor IncreaseFactorConfig + TotalSizePerInterval uint64 + type ApiLoggingConfig struct + LoggingEnabled bool + ThresholdInMicroSeconds int + type ApiRoutesConfig struct + APIPackages map[string]APIPackageConfig + Logging ApiLoggingConfig + type ArwenVersionByEpoch struct + StartEpoch uint32 + Version string + type BlackListConfig struct + NumFloodingRounds uint32 + PeerBanDurationInSeconds uint32 + ThresholdNumMessagesPerInterval uint32 + ThresholdSizePerInterval uint64 + type BlockSizeThrottleConfig struct + MaxSizeInBytes uint32 + MinSizeInBytes uint32 + type BuiltInFunctionsConfig struct + AutomaticCrawlerAddresses []string + MaxNumAddressesInTransferRole uint32 + type CacheConfig struct + Capacity uint32 + Name string + Shards uint32 + SizeInBytes uint64 + SizeInBytesPerSender uint32 + SizePerSender uint32 + Type string + type Config struct + AccountsTrieCheckpointsStorage StorageConfig + AccountsTrieStorage StorageConfig + AddressPubkeyConverter PubkeyConfig + Antiflood AntifloodConfig + BadBlocksCache CacheConfig + BlockHeaderStorage StorageConfig + BlockSizeThrottleConfig BlockSizeThrottleConfig + BootstrapStorage StorageConfig + BuiltInFunctions BuiltInFunctionsConfig + Consensus ConsensusConfig + DbLookupExtensions DbLookupExtensionsConfig + Debug DebugConfig + EpochStartConfig EpochStartConfig + EvictionWaitingList EvictionWaitingListConfig + GeneralSettings GeneralSettingsConfig + Hardfork HardforkConfig + Hasher TypeConfig + HeadersPoolConfig HeadersPoolConfig + Health HealthServiceConfig + Heartbeat HeartbeatConfig + HeartbeatV2 HeartbeatV2Config + Logs LogsConfig + LogsAndEvents LogsAndEventsConfig + Marshalizer MarshalizerConfig + MetaBlockStorage StorageConfig + MetaHdrNonceHashStorage StorageConfig + MiniBlocksStorage StorageConfig + MultisigHasher TypeConfig + NTPConfig NTPConfig + PeerAccountsTrieCheckpointsStorage StorageConfig + PeerAccountsTrieStorage StorageConfig + PeerBlockBodyDataPool CacheConfig + PeerBlockBodyStorage StorageConfig + PeerHonesty CacheConfig + PeerIdShardId CacheConfig + PeersRatingConfig PeersRatingConfig + PublicKeyPIDSignature CacheConfig + PublicKeyPeerId CacheConfig + PublicKeyShardId CacheConfig + ReceiptsStorage StorageConfig + Resolvers ResolverConfig + ResourceStats ResourceStatsConfig + RewardTransactionDataPool CacheConfig + RewardTxStorage StorageConfig + ScheduledSCRsStorage StorageConfig + ShardHdrNonceHashStorage StorageConfig + SmartContractDataPool CacheConfig + SmartContractsStorage StorageConfig + SmartContractsStorageForSCQuery StorageConfig + SmartContractsStorageSimulate StorageConfig + SoftwareVersionConfig SoftwareVersionConfig + StateTriesConfig StateTriesConfig + StatusMetricsStorage StorageConfig + StoragePruning StoragePruningConfig + TrieEpochRootHashStorage StorageConfig + TrieNodesChunksDataPool CacheConfig + TrieStorageManagerConfig TrieStorageManagerConfig + TrieSync TrieSyncConfig + TrieSyncStorage TrieSyncStorageConfig + TxBlockBodyDataPool CacheConfig + TxDataPool CacheConfig + TxSignHasher TypeConfig + TxSignMarshalizer TypeConfig + TxStorage StorageConfig + UnsignedTransactionDataPool CacheConfig + UnsignedTransactionStorage StorageConfig + VMOutputCacher CacheConfig + ValidatorPubkeyConverter PubkeyConfig + ValidatorStatistics ValidatorStatisticsConfig + Versions VersionsConfig + VirtualMachine VirtualMachineServicesConfig + VmMarshalizer TypeConfig + WhiteListPool CacheConfig + WhiteListerVerifiedTxs CacheConfig + type Configs struct + ApiRoutesConfig *ApiRoutesConfig + ConfigurationPathsHolder *ConfigurationPathsHolder + EconomicsConfig *EconomicsConfig + EpochConfig *EpochConfig + ExternalConfig *ExternalConfig + FlagsConfig *ContextFlagsConfig + GeneralConfig *Config + ImportDbConfig *ImportDbConfig + P2pConfig *P2PConfig + PreferencesConfig *Preferences + RatingsConfig *RatingsConfig + RoundConfig *RoundConfig + SystemSCConfig *SystemSmartContractsConfig + type ConfigurationPathsHolder struct + ApiRoutes string + Economics string + Epoch string + External string + GasScheduleDirectoryName string + Genesis string + MainConfig string + Nodes string + P2p string + Preferences string + Ratings string + RoundActivation string + SmartContracts string + SystemSC string + ValidatorKey string + type ConsensusConfig struct + Type string + type ContextFlagsConfig struct + BootstrapRoundIndex uint64 + CleanupStorage bool + DisableAnsiColor bool + DisableConsensusWatchdog bool + EnableGops bool + EnableLogCorrelation bool + EnableLogName bool + EnablePprof bool + EnableRestAPIServerDebugMode bool + EnableTxIndexing bool + ForceStartFromNetwork bool + LogLevel string + RestApiInterface string + SaveLogFile bool + SerializeSnapshots bool + SessionInfoFileOutput string + UseHealthService bool + UseLogView bool + ValidatorKeyIndex int + Version string + WorkingDir string + type CovalentConfig struct + Enabled bool + RouteAcknowledgeData string + RouteSendData string + URL string + type DBConfig struct + BatchDelaySeconds int + FilePath string + MaxBatchSize int + MaxOpenFiles int + Type string + UseTmpAsFilePath bool + type DbLookupExtensionsConfig struct + DbLookupMaxActivePersisters uint32 + ESDTSuppliesStorageConfig StorageConfig + Enabled bool + EpochByHashStorageConfig StorageConfig + MiniblockHashByTxHashStorageConfig StorageConfig + MiniblocksMetadataStorageConfig StorageConfig + ResultsHashesByTxHashStorageConfig StorageConfig + RoundHashStorageConfig StorageConfig + type DebugConfig struct + Antiflood AntifloodDebugConfig + EpochStart EpochStartDebugConfig + InterceptorResolver InterceptorResolverDebugConfig + ShuffleOut ShuffleOutDebugConfig + type DelegationManagerSystemSCConfig struct + ConfigChangeAddress string + MinCreationDeposit string + MinStakeAmount string + type DelegationSystemSCConfig struct + AddTokensWhitelistedAddress string + MaxServiceFee uint64 + MinServiceFee uint64 + type ESDTSystemSCConfig struct + BaseIssuingCost string + OwnerAddress string + type EconomicsConfig struct + FeeSettings FeeSettings + GlobalSettings GlobalSettings + RewardsSettings RewardsSettings + type ElasticSearchConfig struct + BulkRequestMaxSizeInBytes int + Enabled bool + EnabledIndexes []string + IndexerCacheSize int + Password string + URL string + UseKibana bool + Username string + type EnableEpochs struct + AddFailedRelayedTxToInvalidMBsDisableEpoch uint32 + AddTokensToDelegationEnableEpoch uint32 + AheadOfTimeGasUsageEnableEpoch uint32 + BackwardCompSaveKeyValueEnableEpoch uint32 + BalanceWaitingListsEnableEpoch uint32 + BelowSignedThresholdEnableEpoch uint32 + BlockGasAndFeesReCheckEnableEpoch uint32 + BuiltInFunctionOnMetaEnableEpoch uint32 + BuiltInFunctionsEnableEpoch uint32 + CheckCorrectTokenIDForTransferRoleEnableEpoch uint32 + CheckExecuteOnReadOnlyEnableEpoch uint32 + CheckFunctionArgumentEnableEpoch uint32 + CleanUpInformativeSCRsEnableEpoch uint32 + ComputeRewardCheckpointEnableEpoch uint32 + CorrectFirstQueuedEpoch uint32 + CorrectJailedNotUnstakedEmptyQueueEpoch uint32 + CorrectLastUnjailedEnableEpoch uint32 + CreateNFTThroughExecByCallerEnableEpoch uint32 + DelegationManagerEnableEpoch uint32 + DelegationSmartContractEnableEpoch uint32 + DeleteDelegatorAfterClaimRewardsEnableEpoch uint32 + DisableExecByCallerEnableEpoch uint32 + DoNotReturnOldBlockInBlockchainHookEnableEpoch uint32 + DoubleKeyProtectionEnableEpoch uint32 + ESDTEnableEpoch uint32 + ESDTMetadataContinuousCleanupEnableEpoch uint32 + ESDTMultiTransferEnableEpoch uint32 + ESDTNFTCreateOnMultiShardEnableEpoch uint32 + ESDTRegisterAndSetAllRolesEnableEpoch uint32 + ESDTTransferRoleEnableEpoch uint32 + FailExecutionOnEveryAPIErrorEnableEpoch uint32 + FixAsyncCallBackArgsListEnableEpoch uint32 + FixOOGReturnCodeEnableEpoch uint32 + FixOldTokenLiquidityEnableEpoch uint32 + FrontRunningProtectionEnableEpoch uint32 + GasPriceModifierEnableEpoch uint32 + GlobalMintBurnDisableEpoch uint32 + GovernanceEnableEpoch uint32 + HeartbeatDisableEpoch uint32 + IncrementSCRNonceInMultiTransferEnableEpoch uint32 + IsPayableBySCEnableEpoch uint32 + ManagedCryptoAPIsEnableEpoch uint32 + MaxNodesChangeEnableEpoch []MaxNodesChangeConfig + MetaESDTSetEnableEpoch uint32 + MetaProtectionEnableEpoch uint32 + MiniBlockPartialExecutionEnableEpoch uint32 + MultiESDTTransferFixOnCallBackOnEnableEpoch uint32 + OptimizeGasUsedInCrossMiniBlocksEnableEpoch uint32 + OptimizeNFTStoreEnableEpoch uint32 + PenalizedTooMuchGasEnableEpoch uint32 + ReDelegateBelowMinCheckEnableEpoch uint32 + RefactorContextEnableEpoch uint32 + RelayedTransactionsEnableEpoch uint32 + RelayedTransactionsV2EnableEpoch uint32 + RemoveNonUpdatedStorageEnableEpoch uint32 + RepairCallbackEnableEpoch uint32 + ReturnDataToLastTransferEnableEpoch uint32 + SCDeployEnableEpoch uint32 + SCRSizeInvariantCheckEnableEpoch uint32 + SCRSizeInvariantOnBuiltInResultEnableEpoch uint32 + SaveJailedAlwaysEnableEpoch uint32 + ScheduledMiniBlocksEnableEpoch uint32 + SenderInOutTransferEnableEpoch uint32 + StakeEnableEpoch uint32 + StakingV2EnableEpoch uint32 + StopDecreasingValidatorRatingWhenStuckEnableEpoch uint32 + StorageAPICostOptimizationEnableEpoch uint32 + SwitchHysteresisForMinNodesEnableEpoch uint32 + SwitchJailWaitingEnableEpoch uint32 + TransactionSignedWithTxHashEnableEpoch uint32 + TransformToMultiShardCreateEnableEpoch uint32 + UnbondTokensV2EnableEpoch uint32 + ValidatorToDelegationEnableEpoch uint32 + WaitingListFixEnableEpoch uint32 + type EndpointsThrottlersConfig struct + Endpoint string + MaxNumGoRoutines int32 + type EpochConfig struct + EnableEpochs EnableEpochs + GasSchedule GasScheduleConfig + type EpochRewardSettings struct + DeveloperPercentage float64 + EpochEnable uint32 + LeaderPercentage float64 + ProtocolSustainabilityAddress string + ProtocolSustainabilityPercentage float64 + TopUpFactor float64 + TopUpGradientPoint string + type EpochStartConfig struct + MaxShuffledOutRestartThreshold float64 + MinNumConnectedPeersToStart int + MinNumOfPeersToConsiderBlockValid int + MinRoundsBetweenEpochs int64 + MinShuffledOutRestartThreshold float64 + RoundsPerEpoch int64 + type EpochStartDebugConfig struct + GoRoutineAnalyserEnabled bool + ProcessDataTrieOnCommitEpoch bool + type EventNotifierConfig struct + Enabled bool + Password string + ProxyUrl string + UseAuthorization bool + Username string + type EvictionWaitingListConfig struct + DB DBConfig + HashesSize uint + RootHashesSize uint + type ExternalConfig struct + CovalentConnector CovalentConfig + ElasticSearchConnector ElasticSearchConfig + EventNotifierConnector EventNotifierConfig + type FacadeConfig struct + PprofEnabled bool + RestApiInterface string + type FeeSettings struct + GasLimitSettings []GasLimitSetting + GasPerDataByte string + GasPriceModifier float64 + MinGasPrice string + type FloodPreventerConfig struct + BlackList BlackListConfig + IntervalInSeconds uint32 + PeerMaxInput AntifloodLimitsConfig + ReservedPercent float32 + type GasLimitSetting struct + EnableEpoch uint32 + MaxGasLimitPerBlock string + MaxGasLimitPerMetaBlock string + MaxGasLimitPerMetaMiniBlock string + MaxGasLimitPerMiniBlock string + MaxGasLimitPerTx string + MinGasLimit string + type GasScheduleByEpochs struct + FileName string + StartEpoch uint32 + type GasScheduleConfig struct + GasScheduleByEpochs []GasScheduleByEpochs + type General struct + MaxRating uint32 + MinRating uint32 + SelectionChances []*SelectionChance + SignedBlocksThreshold float32 + StartRating uint32 + type GeneralSettingsConfig struct + ChainID string + GenesisMaxNumberOfShards uint32 + GenesisString string + MaxComputableRounds uint64 + MaxConsecutiveRoundsOfRatingDecrease uint64 + MinTransactionVersion uint32 + StartInEpochEnabled bool + StatusPollingIntervalSec int + SyncProcessTimeInMillis uint32 + type GlobalSettings struct + Denomination int + GenesisMintingSenderAddress string + GenesisTotalSupply string + MinimumInflation float64 + YearSettings []*YearSetting + type GovernanceSystemSCConfig struct + Active GovernanceSystemSCConfigActive + FirstWhitelistedAddress string + V1 GovernanceSystemSCConfigV1 + type GovernanceSystemSCConfigActive struct + MinPassThreshold string + MinQuorum string + MinVetoThreshold string + ProposalCost string + type GovernanceSystemSCConfigV1 struct + MinPassThreshold int32 + MinQuorum int32 + MinVetoThreshold int32 + NumNodes int64 + ProposalCost string + type HardforkConfig struct + AfterHardFork bool + CloseAfterExportInMinutes uint32 + EnableTrigger bool + EnableTriggerFromP2P bool + ExportKeysStorageConfig StorageConfig + ExportStateStorageConfig StorageConfig + ExportTriesStorageConfig StorageConfig + GenesisTime int64 + ImportFolder string + ImportKeysStorageConfig StorageConfig + ImportStateStorageConfig StorageConfig + MustImport bool + PublicKeyToListenFrom string + StartEpoch uint32 + StartNonce uint64 + StartRound uint64 + ValidatorGracePeriodInEpochs uint32 + type HeadersPoolConfig struct + MaxHeadersPerShard int + NumElementsToRemoveOnEviction int + type HealthServiceConfig struct + FolderPath string + IntervalDiagnoseComponentsDeeplyInSeconds int + IntervalDiagnoseComponentsInSeconds int + IntervalVerifyMemoryInSeconds int + MemoryUsageToCreateProfiles int + NumMemoryUsageRecordsToKeep int + type HeartbeatConfig struct + DurationToConsiderUnresponsiveInSec int + HeartbeatRefreshIntervalInSec uint32 + HeartbeatStorage StorageConfig + HideInactiveValidatorIntervalInSec uint32 + MaxTimeToWaitBetweenBroadcastsInSec int + MinTimeToWaitBetweenBroadcastsInSec int + type HeartbeatV2Config struct + DelayBetweenRequestsInSec int64 + HardforkTimeBetweenSendsInSec int64 + HeartbeatExpiryTimespanInSec int64 + HeartbeatPool CacheConfig + HeartbeatThresholdBetweenSends float64 + HeartbeatTimeBetweenSendsInSec int64 + HeartbeatTimeBetweenSendsWhenErrorInSec int64 + HideInactiveValidatorIntervalInSec int64 + MaxDurationPeerUnresponsiveInSec int64 + MaxMissingKeysInRequest uint32 + MaxTimeoutInSec int64 + MinPeersThreshold float32 + PeerAuthenticationThresholdBetweenSends float64 + PeerAuthenticationTimeBetweenSendsInSec int64 + PeerAuthenticationTimeBetweenSendsWhenErrorInSec int64 + PeerShardThresholdBetweenSends float64 + PeerShardTimeBetweenSendsInSec int64 + TimeBetweenConnectionsMetricsUpdateInSec int64 + TimeToReadDirectConnectionsInSec int64 + type ImportDbConfig struct + ImportDBStartInEpoch uint32 + ImportDBTargetShardID uint32 + ImportDBWorkingDir string + ImportDbNoSigCheckFlag bool + ImportDbSaveTrieEpochRootHash bool + IsImportDBMode bool + type IncreaseFactorConfig struct + Factor float32 + Threshold uint32 + type InterceptorResolverDebugConfig struct + CacheSize int + DebugLineExpiration int + EnablePrint bool + Enabled bool + IntervalAutoPrintInSeconds int + NumRequestsThreshold int + NumResolveFailureThreshold int + type KadDhtPeerDiscoveryConfig struct + BucketSize uint32 + Enabled bool + InitialPeerList []string + ProtocolID string + RefreshIntervalInSec uint32 + RoutingTableRefreshIntervalInSec uint32 + Type string + type LogsAndEventsConfig struct + SaveInStorageEnabled bool + TxLogsStorage StorageConfig + type LogsConfig struct + LogFileLifeSpanInMB int + LogFileLifeSpanInSec int + type MarshalizerConfig struct + SizeCheckDelta uint32 + Type string + type MaxNodesChangeConfig struct + EpochEnable uint32 + MaxNumNodes uint32 + NodesToShufflePerShard uint32 + type MetaChain struct + type NTPConfig struct + Hosts []string + Port int + SyncPeriodSeconds int + TimeoutMilliseconds int + Version int + type NodeConfig struct + MaximumExpectedPeerCount uint64 + MinNumPeersToWaitForOnBootstrap uint32 + Port string + Seed string + ThresholdMinConnectedPeers uint32 + type P2PConfig struct + KadDhtPeerDiscovery KadDhtPeerDiscoveryConfig + Node NodeConfig + Sharding ShardingConfig + type PeerHonestyConfig struct + BadPeerThreshold float64 + DecayCoefficient float64 + DecayUpdateIntervalInSeconds uint32 + MaxScore float64 + MinScore float64 + UnitValue float64 + type PeersRatingConfig struct + BadRatedCacheCapacity int + TopRatedCacheCapacity int + type Preferences struct + Preferences PreferencesConfig + type PreferencesConfig struct + ConnectionWatcherType string + DestinationShardAsObserver string + FullArchive bool + Identity string + NodeDisplayName string + PreferredConnections []string + RedundancyLevel int64 + type PubkeyConfig struct + Length int + SignatureLength int + Type string + type QueryVirtualMachineConfig struct + NumConcurrentVMs int + type RatingSteps struct + ConsecutiveMissedBlocksPenalty float32 + HoursToMaxRatingFromStartRating uint32 + ProposerDecreaseFactor float32 + ProposerValidatorImportance float32 + ValidatorDecreaseFactor float32 + type RatingValue struct + Name string + Value int32 + type RatingsConfig struct + General General + MetaChain MetaChain + PeerHonesty PeerHonestyConfig + ShardChain ShardChain + type ResolverConfig struct + NumCrossShardPeers uint32 + NumFullHistoryPeers uint32 + NumTotalPeers uint32 + type ResourceStatsConfig struct + Enabled bool + RefreshIntervalInSec int + type RewardsSettings struct + RewardsConfigByEpoch []EpochRewardSettings + type RoundConfig struct + type RouteConfig struct + Name string + Open bool + type SelectionChance struct + ChancePercent uint32 + MaxThreshold uint32 + type ShardChain struct + type ShardingConfig struct + AdditionalConnections AdditionalConnectionsConfig + MaxCrossShardObservers uint32 + MaxCrossShardValidators uint32 + MaxIntraShardObservers uint32 + MaxIntraShardValidators uint32 + MaxSeeders uint32 + TargetPeerCount uint32 + Type string + type ShuffleOutDebugConfig struct + CallGCWhenShuffleOut bool + DoProfileOnShuffleOut bool + ExtraPrintsOnShuffleOut bool + type SoftwareVersionConfig struct + PollingIntervalInMinutes int + StableTagLocation string + type StakingSystemSCConfig struct + ActivateBLSPubKeyMessageVerification bool + BleedPercentagePerRound float64 + GenesisNodePrice string + MaxNumberOfNodesForStake uint64 + MaximumPercentageToBleed float64 + MinStakeValue string + MinStepValue string + MinUnstakeTokensValue string + NumRoundsWithoutBleed uint64 + UnBondPeriod uint64 + UnBondPeriodInEpochs uint32 + UnJailValue string + type StateTriesConfig struct + AccountsStatePruningEnabled bool + CheckpointRoundsModulus uint + CheckpointsEnabled bool + MaxPeerTrieLevelInMemory uint + MaxStateTrieLevelInMemory uint + PeerStatePruningEnabled bool + PeerStatePruningQueueSize uint + SnapshotsEnabled bool + UserStatePruningQueueSize uint + type StorageConfig struct + Cache CacheConfig + DB DBConfig + type StoragePruningConfig struct + AccountsTrieCleanOldEpochsData bool + AccountsTrieSkipRemovalCustomPattern string + Enabled bool + FullArchiveNumActivePersisters uint32 + NumActivePersisters uint64 + NumEpochsToKeep uint64 + ObserverCleanOldEpochsData bool + ValidatorCleanOldEpochsData bool + type SystemSmartContractsConfig struct + DelegationManagerSystemSCConfig DelegationManagerSystemSCConfig + DelegationSystemSCConfig DelegationSystemSCConfig + ESDTSystemSCConfig ESDTSystemSCConfig + GovernanceSystemSCConfig GovernanceSystemSCConfig + StakingSystemSCConfig StakingSystemSCConfig + type TopicAntifloodConfig struct + DefaultMaxMessagesPerSec uint32 + MaxMessages []TopicMaxMessagesConfig + type TopicMaxMessagesConfig struct + NumMessagesPerSec uint32 + Topic string + type TrieStorageManagerConfig struct + CheckpointHashesHolderMaxSize uint64 + PruningBufferLen uint32 + SnapshotsBufferLen uint32 + SnapshotsGoroutineNum uint32 + type TrieSyncConfig struct + CheckNodesOnDisk bool + MaxHardCapForMissingNodes int + NumConcurrentTrieSyncers int + TrieSyncerVersion int + type TrieSyncStorageConfig struct + Capacity uint32 + DB DBConfig + EnableDB bool + SizeInBytes uint64 + type TxAccumulatorConfig struct + MaxAllowedTimeInMilliseconds uint32 + MaxDeviationTimeInMilliseconds uint32 + type TypeConfig struct + Type string + type ValidatorStatisticsConfig struct + CacheRefreshIntervalInSec uint32 + type VersionByEpochs struct + StartEpoch uint32 + Version string + type VersionsConfig struct + Cache CacheConfig + DefaultVersion string + VersionsByEpochs []VersionByEpochs + type VirtualMachineConfig struct + ArwenVersions []ArwenVersionByEpoch + TimeOutForSCExecutionInMilliseconds uint32 + WasmerSIGSEGVPassthrough bool + type VirtualMachineGasConfig struct + MetaMaxGasPerVmQuery uint64 + ShardMaxGasPerVmQuery uint64 + type VirtualMachineServicesConfig struct + Execution VirtualMachineConfig + GasConfig VirtualMachineGasConfig + Querying QueryVirtualMachineConfig + type WebServerAntifloodConfig struct + EndpointsThrottlers []EndpointsThrottlersConfig + SameSourceRequests uint32 + SameSourceResetIntervalInSec uint32 + SimultaneousRequests uint32 + TrieOperationsDeadlineMilliseconds uint32 + type YearSetting struct + MaximumInflation float64 + Year uint32