Documentation ¶
Index ¶
- Constants
- func ApplicationLayerSpamRecordCacheMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
- func ApplicationLayerSpamRecordQueueMetricsFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
- func DialConfigCacheMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
- func DisallowListCacheMetricsFactory(f HeroCacheMetricsFactory, networkingType network.NetworkingType) module.HeroCacheMetrics
- func GossipSubAppSpecificScoreUpdateQueueMetricFactory(f HeroCacheMetricsFactory, networkingType network.NetworkingType) module.HeroCacheMetrics
- func GossipSubRPCInspectorClusterPrefixedCacheMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
- func GossipSubRPCInspectorQueueMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
- func GossipSubRPCSentTrackerMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
- func GossipSubRPCSentTrackerQueueMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
- func GossipSubSpamRecordCacheMetricsFactory(f HeroCacheMetricsFactory, networkingType network.NetworkingType) module.HeroCacheMetrics
- func NetworkReceiveCacheMetricsFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
- func NewExecutionDataRequesterCollector() module.ExecutionDataRequesterMetrics
- func NewExecutionStateIndexerCollector() module.ExecutionStateIndexerMetrics
- func NewGossipSubApplicationSpecificScoreCacheMetrics(f HeroCacheMetricsFactory, networkingType network.NetworkingType) module.HeroCacheMetrics
- func NewRateLimitedBlockstoreCollector(prefix string) module.RateLimitedBlockstoreMetrics
- func NewSubscriptionRecordCacheMetricsFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
- func PrependPublicPrefix(str string) string
- func RegisterBadgerMetrics() error
- func RpcInspectorNotificationQueueMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
- type AccessCollector
- func (ac *AccessCollector) ConnectionAddedToPool()
- func (ac *AccessCollector) ConnectionFromPoolEvicted()
- func (ac *AccessCollector) ConnectionFromPoolInvalidated()
- func (ac *AccessCollector) ConnectionFromPoolReused()
- func (ac *AccessCollector) ConnectionFromPoolUpdated()
- func (ac *AccessCollector) NewConnectionEstablished()
- func (ac *AccessCollector) TotalConnectionsInPool(connectionCount uint, connectionPoolSize uint)
- func (ac *AccessCollector) UpdateExecutionReceiptMaxHeight(height uint64)
- func (ac *AccessCollector) UpdateLastFullBlockHeight(height uint64)
- type AccessCollectorOpts
- type AlspMetrics
- type BitswapCollector
- func (bc *BitswapCollector) BlobsReceived(prefix string, n uint64)
- func (bc *BitswapCollector) BlobsSent(prefix string, n uint64)
- func (bc *BitswapCollector) DataReceived(prefix string, n uint64)
- func (bc *BitswapCollector) DataSent(prefix string, n uint64)
- func (bc *BitswapCollector) DupBlobsReceived(prefix string, n uint64)
- func (bc *BitswapCollector) DupDataReceived(prefix string, n uint64)
- func (bc *BitswapCollector) MessagesReceived(prefix string, n uint64)
- func (bc *BitswapCollector) Peers(prefix string, n int)
- func (bc *BitswapCollector) Wantlist(prefix string, n int)
- type CacheCollector
- type ChainSyncCollector
- func (c *ChainSyncCollector) BatchRequested(batch chainsync.Batch)
- func (c *ChainSyncCollector) PrunedBlockByHeight(status *chainsync.Status)
- func (c *ChainSyncCollector) PrunedBlockById(status *chainsync.Status)
- func (c *ChainSyncCollector) PrunedBlocks(totalByHeight, totalById, storedByHeight, storedById int)
- func (c *ChainSyncCollector) RangeRequested(ran chainsync.Range)
- type CleanerCollector
- type CollectionCollector
- type ComplianceCollector
- func (cc *ComplianceCollector) BlockFinalized(block *flow.Block)
- func (cc *ComplianceCollector) BlockSealed(block *flow.Block)
- func (cc *ComplianceCollector) CommittedEpochFinalView(view uint64)
- func (cc *ComplianceCollector) CurrentDKGPhase1FinalView(view uint64)
- func (cc *ComplianceCollector) CurrentDKGPhase2FinalView(view uint64)
- func (cc *ComplianceCollector) CurrentDKGPhase3FinalView(view uint64)
- func (cc *ComplianceCollector) CurrentEpochCounter(counter uint64)
- func (cc *ComplianceCollector) CurrentEpochFinalView(view uint64)
- func (cc *ComplianceCollector) CurrentEpochPhase(phase flow.EpochPhase)
- func (cc *ComplianceCollector) EpochEmergencyFallbackTriggered()
- func (cc *ComplianceCollector) EpochTransitionHeight(height uint64)
- func (cc *ComplianceCollector) FinalizedHeight(height uint64)
- func (cc *ComplianceCollector) SealedHeight(height uint64)
- type ConsensusCollector
- func (cc *ConsensusCollector) CheckSealingDuration(duration time.Duration)
- func (cc *ConsensusCollector) EmergencySeal()
- func (cc *ConsensusCollector) FinishBlockToSeal(blockID flow.Identifier)
- func (cc *ConsensusCollector) FinishCollectionToFinalized(collectionID flow.Identifier)
- func (cc *ConsensusCollector) OnApprovalProcessingDuration(duration time.Duration)
- func (cc *ConsensusCollector) OnReceiptProcessingDuration(duration time.Duration)
- func (cc *ConsensusCollector) StartBlockToSeal(blockID flow.Identifier)
- func (cc *ConsensusCollector) StartCollectionToFinalized(collectionID flow.Identifier)
- type CruiseCtlMetrics
- type EngineCollector
- func (ec *EngineCollector) InboundMessageDropped(engine string, message string)
- func (ec *EngineCollector) MessageHandled(engine string, message string)
- func (ec *EngineCollector) MessageReceived(engine string, message string)
- func (ec *EngineCollector) MessageSent(engine string, message string)
- func (ec *EngineCollector) OutboundMessageDropped(engine string, message string)
- type ExecutionCollector
- func (ec *ExecutionCollector) ChunkDataPackRequestProcessed()
- func (ec *ExecutionCollector) ExecutionBlockCachedPrograms(programs int)
- func (ec *ExecutionCollector) ExecutionBlockDataUploadFinished(dur time.Duration)
- func (ec *ExecutionCollector) ExecutionBlockDataUploadStarted()
- func (ec *ExecutionCollector) ExecutionBlockExecuted(dur time.Duration, stats module.ExecutionResultStats)
- func (ec *ExecutionCollector) ExecutionBlockExecutionEffortVectorComponent(compKind string, value uint)
- func (ec *ExecutionCollector) ExecutionCheckpointSize(bytes uint64)
- func (ec *ExecutionCollector) ExecutionChunkDataPackGenerated(proofSize, numberOfTransactions int)
- func (ec *ExecutionCollector) ExecutionCollectionExecuted(dur time.Duration, stats module.ExecutionResultStats)
- func (ec *ExecutionCollector) ExecutionCollectionRequestRetried()
- func (ec *ExecutionCollector) ExecutionCollectionRequestSent()
- func (ec *ExecutionCollector) ExecutionComputationResultUploadRetried()
- func (ec *ExecutionCollector) ExecutionComputationResultUploaded()
- func (ec *ExecutionCollector) ExecutionLastExecutedBlockHeight(height uint64)
- func (ec *ExecutionCollector) ExecutionLastFinalizedExecutedBlockHeight(height uint64)
- func (ec *ExecutionCollector) ExecutionScriptExecuted(dur time.Duration, compUsed, memoryUsed, memoryEstimated uint64)
- func (ec *ExecutionCollector) ExecutionStateStorageDiskTotal(bytes int64)
- func (ec *ExecutionCollector) ExecutionStorageStateCommitment(bytes int64)
- func (ec *ExecutionCollector) ExecutionSync(syncing bool)
- func (ec *ExecutionCollector) ExecutionTransactionExecuted(dur time.Duration, numConflictRetries int, compUsed uint64, memoryUsed uint64, ...)
- func (ec *ExecutionCollector) FinishBlockReceivedToExecuted(blockID flow.Identifier)
- func (ec *ExecutionCollector) ForestApproxMemorySize(bytes uint64)
- func (ec *ExecutionCollector) ForestNumberOfTrees(number uint64)
- func (ec *ExecutionCollector) LatestTrieMaxDepthTouched(maxDepth uint16)
- func (ec *ExecutionCollector) LatestTrieRegCount(number uint64)
- func (ec *ExecutionCollector) LatestTrieRegCountDiff(number int64)
- func (ec *ExecutionCollector) LatestTrieRegSize(size uint64)
- func (ec *ExecutionCollector) LatestTrieRegSizeDiff(size int64)
- func (ec *ExecutionCollector) ProofSize(bytes uint32)
- func (ec *ExecutionCollector) ReadDuration(duration time.Duration)
- func (ec *ExecutionCollector) ReadDurationPerItem(duration time.Duration)
- func (ec *ExecutionCollector) ReadValuesNumber(number uint64)
- func (ec *ExecutionCollector) ReadValuesSize(bytes uint64)
- func (ec *ExecutionCollector) RuntimeSetNumberOfAccounts(count uint64)
- func (ec *ExecutionCollector) RuntimeTransactionChecked(dur time.Duration)
- func (ec *ExecutionCollector) RuntimeTransactionInterpreted(dur time.Duration)
- func (ec *ExecutionCollector) RuntimeTransactionParsed(dur time.Duration)
- func (ec *ExecutionCollector) RuntimeTransactionProgramsCacheHit()
- func (ec *ExecutionCollector) RuntimeTransactionProgramsCacheMiss()
- func (ec *ExecutionCollector) StartBlockReceivedToExecuted(blockID flow.Identifier)
- func (ec *ExecutionCollector) UpdateCollectionMaxHeight(height uint64)
- func (ec *ExecutionCollector) UpdateCount()
- func (ec *ExecutionCollector) UpdateDuration(duration time.Duration)
- func (ec *ExecutionCollector) UpdateDurationPerItem(duration time.Duration)
- func (ec *ExecutionCollector) UpdateValuesNumber(number uint64)
- func (ec *ExecutionCollector) UpdateValuesSize(bytes uint64)
- type ExecutionDataProviderCollector
- type ExecutionDataPrunerCollector
- type ExecutionDataRequesterCollector
- func (ec *ExecutionDataRequesterCollector) ExecutionDataFetchFinished(duration time.Duration, success bool, height uint64)
- func (ec *ExecutionDataRequesterCollector) ExecutionDataFetchStarted()
- func (ec *ExecutionDataRequesterCollector) FetchRetried()
- func (ec *ExecutionDataRequesterCollector) NotificationSent(height uint64)
- type ExecutionDataRequesterV2Collector
- func (c *ExecutionDataRequesterV2Collector) FulfilledHeight(blockHeight uint64)
- func (c *ExecutionDataRequesterV2Collector) ReceiptSkipped()
- func (c *ExecutionDataRequesterV2Collector) RequestCanceled()
- func (c *ExecutionDataRequesterV2Collector) RequestFailed(duration time.Duration, retryable bool)
- func (c *ExecutionDataRequesterV2Collector) RequestSucceeded(blockHeight uint64, duration time.Duration, totalSize uint64, ...)
- func (c *ExecutionDataRequesterV2Collector) ResponseDropped()
- type ExecutionStateIndexerCollector
- type GossipSubRpcValidationInspectorMetrics
- func (c *GossipSubRpcValidationInspectorMetrics) AsyncProcessingFinished(duration time.Duration)
- func (c *GossipSubRpcValidationInspectorMetrics) AsyncProcessingStarted()
- func (c *GossipSubRpcValidationInspectorMetrics) OnActiveClusterIDsNotSetErr()
- func (c *GossipSubRpcValidationInspectorMetrics) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
- func (c *GossipSubRpcValidationInspectorMetrics) OnGraftDuplicateTopicIdsExceedThreshold()
- func (c *GossipSubRpcValidationInspectorMetrics) OnGraftMessageInspected(duplicateTopicIds int)
- func (c *GossipSubRpcValidationInspectorMetrics) OnIHaveControlMessageIdsTruncated(diff int)
- func (c *GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateMessageIdsExceedThreshold()
- func (c *GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateTopicIdsExceedThreshold()
- func (c *GossipSubRpcValidationInspectorMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
- func (c *GossipSubRpcValidationInspectorMetrics) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int)
- func (c *GossipSubRpcValidationInspectorMetrics) OnIWantCacheMissMessageIdsExceedThreshold()
- func (c *GossipSubRpcValidationInspectorMetrics) OnIWantControlMessageIdsTruncated(diff int)
- func (c *GossipSubRpcValidationInspectorMetrics) OnIWantDuplicateMessageIdsExceedThreshold()
- func (c *GossipSubRpcValidationInspectorMetrics) OnIWantMessageIDsReceived(msgIdCount int)
- func (c *GossipSubRpcValidationInspectorMetrics) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
- func (c *GossipSubRpcValidationInspectorMetrics) OnIncomingRpcReceived(iHaveCount, iWantCount, graftCount, pruneCount, msgCount int)
- func (c *GossipSubRpcValidationInspectorMetrics) OnInvalidControlMessageNotificationSent()
- func (c *GossipSubRpcValidationInspectorMetrics) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
- func (c *GossipSubRpcValidationInspectorMetrics) OnPruneDuplicateTopicIdsExceedThreshold()
- func (c *GossipSubRpcValidationInspectorMetrics) OnPruneMessageInspected(duplicateTopicIds int)
- func (c *GossipSubRpcValidationInspectorMetrics) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, ...)
- func (c *GossipSubRpcValidationInspectorMetrics) OnPublishMessagesInspectionErrorExceedsThreshold()
- func (c *GossipSubRpcValidationInspectorMetrics) OnUnstakedPeerInspectionFailed()
- type GossipSubScoreMetrics
- func (g *GossipSubScoreMetrics) OnAppSpecificScoreUpdated(score float64)
- func (g *GossipSubScoreMetrics) OnBehaviourPenaltyUpdated(penalty float64)
- func (g *GossipSubScoreMetrics) OnFirstMessageDeliveredUpdated(topic channels.Topic, f float64)
- func (g *GossipSubScoreMetrics) OnIPColocationFactorUpdated(factor float64)
- func (g *GossipSubScoreMetrics) OnInvalidMessageDeliveredUpdated(topic channels.Topic, f float64)
- func (g *GossipSubScoreMetrics) OnMeshMessageDeliveredUpdated(topic channels.Topic, f float64)
- func (g *GossipSubScoreMetrics) OnOverallPeerScoreUpdated(score float64)
- func (g *GossipSubScoreMetrics) OnTimeInMeshUpdated(topic channels.Topic, duration time.Duration)
- func (g *GossipSubScoreMetrics) SetWarningStateCount(u uint)
- type HeroCacheCollector
- func AccessNodeExecutionDataCacheMetrics(registrar prometheus.Registerer) *HeroCacheCollector
- func ChunkDataPackRequestQueueMetricsFactory(registrar prometheus.Registerer) *HeroCacheCollector
- func CollectionNodeTransactionsCacheMetrics(registrar prometheus.Registerer, epoch uint64) *HeroCacheCollector
- func CollectionRequestsQueueMetricFactory(registrar prometheus.Registerer) *HeroCacheCollector
- func DisallowListNotificationQueueMetricFactory(registrar prometheus.Registerer) *HeroCacheCollector
- func FollowerCacheMetrics(registrar prometheus.Registerer) *HeroCacheCollector
- func NetworkDnsIpCacheMetricsFactory(registrar prometheus.Registerer) *HeroCacheCollector
- func NetworkDnsTxtCacheMetricsFactory(registrar prometheus.Registerer) *HeroCacheCollector
- func NewHeroCacheCollector(nameSpace string, cacheName string, registrar prometheus.Registerer) *HeroCacheCollector
- func ReceiptRequestsQueueMetricFactory(registrar prometheus.Registerer) *HeroCacheCollector
- func (h *HeroCacheCollector) BucketAvailableSlots(availableSlots uint64, totalSlots uint64)
- func (h *HeroCacheCollector) OnEntityEjectionDueToEmergency()
- func (h *HeroCacheCollector) OnEntityEjectionDueToFullCapacity()
- func (h *HeroCacheCollector) OnKeyGetFailure()
- func (h *HeroCacheCollector) OnKeyGetSuccess()
- func (h *HeroCacheCollector) OnKeyPutAttempt(size uint32)
- func (h *HeroCacheCollector) OnKeyPutDeduplicated()
- func (h *HeroCacheCollector) OnKeyPutDrop()
- func (h *HeroCacheCollector) OnKeyPutSuccess(size uint32)
- func (h *HeroCacheCollector) OnKeyRemoved(size uint32)
- type HeroCacheMetricsFactory
- type HeroCacheMetricsRegistrationFunc
- type HotstuffCollector
- func (hc *HotstuffCollector) BlockProcessingDuration(duration time.Duration)
- func (hc *HotstuffCollector) CommitteeProcessingDuration(duration time.Duration)
- func (hc *HotstuffCollector) CountSkipped()
- func (hc *HotstuffCollector) CountTimeout()
- func (hc *HotstuffCollector) HotStuffBusyDuration(duration time.Duration, event string)
- func (hc *HotstuffCollector) HotStuffIdleDuration(duration time.Duration)
- func (hc *HotstuffCollector) HotStuffWaitDuration(duration time.Duration, event string)
- func (hc *HotstuffCollector) PayloadProductionDuration(duration time.Duration)
- func (hc *HotstuffCollector) SetCurView(view uint64)
- func (hc *HotstuffCollector) SetQCView(view uint64)
- func (hc *HotstuffCollector) SetTCView(view uint64)
- func (hc *HotstuffCollector) SetTimeout(duration time.Duration)
- func (hc *HotstuffCollector) SignerProcessingDuration(duration time.Duration)
- func (hc *HotstuffCollector) TimeoutCollectorsRange(lowestRetainedView uint64, newestViewCreatedCollector uint64, ...)
- func (hc *HotstuffCollector) TimeoutObjectProcessingDuration(duration time.Duration)
- func (hc *HotstuffCollector) ValidatorProcessingDuration(duration time.Duration)
- func (hc *HotstuffCollector) VoteProcessingDuration(duration time.Duration)
- type LibP2PResourceManagerMetrics
- func (l *LibP2PResourceManagerMetrics) AllowConn(dir network.Direction, usefd bool)
- func (l *LibP2PResourceManagerMetrics) AllowMemory(size int)
- func (l *LibP2PResourceManagerMetrics) AllowPeer(p peer.ID)
- func (l *LibP2PResourceManagerMetrics) AllowProtocol(proto protocol.ID)
- func (l *LibP2PResourceManagerMetrics) AllowService(svc string)
- func (l *LibP2PResourceManagerMetrics) AllowStream(p peer.ID, dir network.Direction)
- func (l *LibP2PResourceManagerMetrics) BlockConn(dir network.Direction, usefd bool)
- func (l *LibP2PResourceManagerMetrics) BlockMemory(size int)
- func (l *LibP2PResourceManagerMetrics) BlockPeer(p peer.ID)
- func (l *LibP2PResourceManagerMetrics) BlockProtocol(proto protocol.ID)
- func (l *LibP2PResourceManagerMetrics) BlockProtocolPeer(proto protocol.ID, p peer.ID)
- func (l *LibP2PResourceManagerMetrics) BlockService(svc string)
- func (l *LibP2PResourceManagerMetrics) BlockServicePeer(svc string, p peer.ID)
- func (l *LibP2PResourceManagerMetrics) BlockStream(p peer.ID, dir network.Direction)
- type LoaderCollector
- type LocalGossipSubRouterMetrics
- func (g *LocalGossipSubRouterMetrics) OnLocalMeshSizeUpdated(topic string, size int)
- func (g *LocalGossipSubRouterMetrics) OnLocalPeerJoinedTopic()
- func (g *LocalGossipSubRouterMetrics) OnLocalPeerLeftTopic()
- func (g *LocalGossipSubRouterMetrics) OnMessageDeliveredToAllSubscribers(size int)
- func (g *LocalGossipSubRouterMetrics) OnMessageDuplicate(size int)
- func (g *LocalGossipSubRouterMetrics) OnMessageEnteredValidation(int)
- func (g *LocalGossipSubRouterMetrics) OnMessageRejected(size int, reason string)
- func (g *LocalGossipSubRouterMetrics) OnOutboundRpcDropped()
- func (g *LocalGossipSubRouterMetrics) OnPeerAddedToProtocol(protocol string)
- func (g *LocalGossipSubRouterMetrics) OnPeerGraftTopic(topic string)
- func (g *LocalGossipSubRouterMetrics) OnPeerPruneTopic(topic string)
- func (g *LocalGossipSubRouterMetrics) OnPeerRemovedFromProtocol()
- func (g *LocalGossipSubRouterMetrics) OnPeerThrottled()
- func (g *LocalGossipSubRouterMetrics) OnRpcReceived(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (g *LocalGossipSubRouterMetrics) OnRpcSent(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (g *LocalGossipSubRouterMetrics) OnUndeliveredMessage()
- type MempoolCollector
- type NetworkCollector
- func (nc *NetworkCollector) DNSLookupDuration(duration time.Duration)
- func (nc *NetworkCollector) DuplicateInboundMessagesDropped(topic, protocol, messageType string)
- func (nc *NetworkCollector) InboundConnections(connectionCount uint)
- func (nc *NetworkCollector) InboundMessageReceived(sizeBytes int, topic, protocol, messageType string)
- func (nc *NetworkCollector) MessageAdded(priority int)
- func (nc *NetworkCollector) MessageProcessingFinished(topic string, duration time.Duration)
- func (nc *NetworkCollector) MessageProcessingStarted(topic string)
- func (nc *NetworkCollector) MessageRemoved(priority int)
- func (nc *NetworkCollector) OnDNSCacheHit()
- func (nc *NetworkCollector) OnDNSCacheInvalidated()
- func (nc *NetworkCollector) OnDNSCacheMiss()
- func (nc *NetworkCollector) OnDNSLookupRequestDropped()
- func (nc *NetworkCollector) OnRateLimitedPeer(peerID peer.ID, role, msgType, topic, reason string)
- func (nc *NetworkCollector) OnUnauthorizedMessage(role, msgType, topic, offense string)
- func (nc *NetworkCollector) OnViolationReportSkipped()
- func (nc *NetworkCollector) OutboundConnections(connectionCount uint)
- func (nc *NetworkCollector) OutboundMessageSent(sizeBytes int, topic, protocol, messageType string)
- func (nc *NetworkCollector) QueueDuration(duration time.Duration, priority int)
- func (nc *NetworkCollector) RoutingTablePeerAdded()
- func (nc *NetworkCollector) RoutingTablePeerRemoved()
- func (nc *NetworkCollector) UnicastMessageSendingCompleted(topic string)
- func (nc *NetworkCollector) UnicastMessageSendingStarted(topic string)
- type NetworkCollectorOpt
- type NodeInfoCollector
- type NoopCollector
- func (nc *NoopCollector) AddBlobsFailed()
- func (nc *NoopCollector) AddBlobsSucceeded(duration time.Duration, totalSize uint64)
- func (nc *NoopCollector) AddInflightRequests(context.Context, httpmetrics.HTTPProperties, int)
- func (nc *NoopCollector) AddTotalRequests(context.Context, string, string)
- func (nc *NoopCollector) AllowConn(network.Direction, bool)
- func (nc *NoopCollector) AllowMemory(int)
- func (nc *NoopCollector) AllowPeer(peer.ID)
- func (nc *NoopCollector) AllowProtocol(protocol.ID)
- func (nc *NoopCollector) AllowService(string)
- func (nc *NoopCollector) AllowStream(peer.ID, network.Direction)
- func (nc *NoopCollector) AsyncProcessingFinished(time.Duration)
- func (nc *NoopCollector) AsyncProcessingStarted()
- func (nc *NoopCollector) BadgerLSMSize(sizeBytes int64)
- func (nc *NoopCollector) BadgerNumBlockedPuts(n int64)
- func (nc *NoopCollector) BadgerNumBytesRead(n int64)
- func (nc *NoopCollector) BadgerNumBytesWritten(n int64)
- func (nc *NoopCollector) BadgerNumGets(n int64)
- func (nc *NoopCollector) BadgerNumMemtableGets(n int64)
- func (nc *NoopCollector) BadgerNumPuts(n int64)
- func (nc *NoopCollector) BadgerNumReads(n int64)
- func (nc *NoopCollector) BadgerNumWrites(n int64)
- func (nc *NoopCollector) BadgerVLogSize(sizeBytes int64)
- func (nc *NoopCollector) BatchRequested(batch chainsync.Batch)
- func (nc *NoopCollector) BlobsReceived(prefix string, n uint64)
- func (nc *NoopCollector) BlobsSent(prefix string, n uint64)
- func (nc *NoopCollector) BlockConn(network.Direction, bool)
- func (nc *NoopCollector) BlockFinalized(*flow.Block)
- func (nc *NoopCollector) BlockIndexed(uint64, time.Duration, int, int, int)
- func (nc *NoopCollector) BlockMemory(int)
- func (nc *NoopCollector) BlockPeer(peer.ID)
- func (nc *NoopCollector) BlockProcessingDuration(time.Duration)
- func (nc *NoopCollector) BlockProposalDuration(duration time.Duration)
- func (nc *NoopCollector) BlockProposed(*flow.Block)
- func (nc *NoopCollector) BlockProtocol(protocol.ID)
- func (nc *NoopCollector) BlockProtocolPeer(protocol.ID, peer.ID)
- func (nc *NoopCollector) BlockReindexed()
- func (nc *NoopCollector) BlockSealed(*flow.Block)
- func (nc *NoopCollector) BlockService(string)
- func (nc *NoopCollector) BlockServicePeer(string, peer.ID)
- func (nc *NoopCollector) BlockStream(peer.ID, network.Direction)
- func (nc *NoopCollector) BucketAvailableSlots(uint64, uint64)
- func (nc *NoopCollector) CacheEntries(resource string, entries uint)
- func (nc *NoopCollector) CacheHit(resource string)
- func (nc *NoopCollector) CacheMiss(resource string)
- func (nc *NoopCollector) CacheNotFound(resource string)
- func (nc *NoopCollector) CheckSealingDuration(duration time.Duration)
- func (nc *NoopCollector) ChunkDataPackRequestProcessed()
- func (nc *NoopCollector) ClusterBlockFinalized(*cluster.Block)
- func (nc *NoopCollector) ClusterBlockProposed(*cluster.Block)
- func (nc *NoopCollector) CollectionExecuted(light flow.LightCollection)
- func (nc *NoopCollector) CollectionFinalized(light flow.LightCollection)
- func (nc *NoopCollector) CommittedEpochFinalView(view uint64)
- func (nc *NoopCollector) CommitteeProcessingDuration(duration time.Duration)
- func (nc *NoopCollector) ConnectionAddedToPool()
- func (nc *NoopCollector) ConnectionFromPoolEvicted()
- func (nc *NoopCollector) ConnectionFromPoolInvalidated()
- func (nc *NoopCollector) ConnectionFromPoolReused()
- func (nc *NoopCollector) ConnectionFromPoolUpdated()
- func (nc *NoopCollector) CountSkipped()
- func (nc *NoopCollector) CountTimeout()
- func (nc *NoopCollector) CurrentDKGPhase1FinalView(view uint64)
- func (nc *NoopCollector) CurrentDKGPhase2FinalView(view uint64)
- func (nc *NoopCollector) CurrentDKGPhase3FinalView(view uint64)
- func (nc *NoopCollector) CurrentEpochCounter(counter uint64)
- func (nc *NoopCollector) CurrentEpochFinalView(view uint64)
- func (nc *NoopCollector) CurrentEpochPhase(phase flow.EpochPhase)
- func (nc *NoopCollector) DNSLookupDuration(duration time.Duration)
- func (nc *NoopCollector) DataReceived(prefix string, n uint64)
- func (nc *NoopCollector) DataSent(prefix string, n uint64)
- func (nc *NoopCollector) DirectMessageFinished(topic string)
- func (nc *NoopCollector) DirectMessageStarted(topic string)
- func (nc *NoopCollector) DupBlobsReceived(prefix string, n uint64)
- func (nc *NoopCollector) DupDataReceived(prefix string, n uint64)
- func (nc *NoopCollector) DuplicateInboundMessagesDropped(string, string, string)
- func (nc *NoopCollector) EmergencySeal()
- func (nc *NoopCollector) EpochEmergencyFallbackTriggered()
- func (nc *NoopCollector) EpochTransitionHeight(height uint64)
- func (nc *NoopCollector) ExecutionBlockCachedPrograms(programs int)
- func (nc *NoopCollector) ExecutionBlockDataUploadFinished(dur time.Duration)
- func (nc *NoopCollector) ExecutionBlockDataUploadStarted()
- func (nc *NoopCollector) ExecutionBlockExecuted(_ time.Duration, _ module.ExecutionResultStats)
- func (nc *NoopCollector) ExecutionBlockExecutionEffortVectorComponent(_ string, _ uint)
- func (nc *NoopCollector) ExecutionCheckpointSize(bytes uint64)
- func (nc *NoopCollector) ExecutionChunkDataPackGenerated(_, _ int)
- func (nc *NoopCollector) ExecutionCollectionExecuted(_ time.Duration, _ module.ExecutionResultStats)
- func (nc *NoopCollector) ExecutionCollectionRequestRetried()
- func (nc *NoopCollector) ExecutionCollectionRequestSent()
- func (nc *NoopCollector) ExecutionComputationResultUploadRetried()
- func (nc *NoopCollector) ExecutionComputationResultUploaded()
- func (nc *NoopCollector) ExecutionComputationUsedPerBlock(computation uint64)
- func (nc *NoopCollector) ExecutionDataFetchFinished(_ time.Duration, _ bool, _ uint64)
- func (nc *NoopCollector) ExecutionDataFetchStarted()
- func (nc *NoopCollector) ExecutionLastExecutedBlockHeight(height uint64)
- func (nc *NoopCollector) ExecutionLastFinalizedExecutedBlockHeight(height uint64)
- func (nc *NoopCollector) ExecutionReceiptReceived(r *flow.ExecutionReceipt)
- func (nc *NoopCollector) ExecutionScriptExecuted(dur time.Duration, compUsed, _, _ uint64)
- func (nc *NoopCollector) ExecutionStorageStateCommitment(bytes int64)
- func (nc *NoopCollector) ExecutionSync(syncing bool)
- func (nc *NoopCollector) ExecutionTransactionExecuted(_ time.Duration, _ int, _, _ uint64, _, _ int, _ bool)
- func (nc *NoopCollector) FetchRetried()
- func (nc *NoopCollector) FinalizedHeight(height uint64)
- func (nc *NoopCollector) FinishBlockReceivedToExecuted(blockID flow.Identifier)
- func (nc *NoopCollector) FinishBlockToSeal(blockID flow.Identifier)
- func (nc *NoopCollector) FinishCollectionToFinalized(collectionID flow.Identifier)
- func (nc *NoopCollector) ForestApproxMemorySize(bytes uint64)
- func (nc *NoopCollector) ForestNumberOfTrees(number uint64)
- func (nc *NoopCollector) FulfilledHeight(blockHeight uint64)
- func (nc *NoopCollector) HotStuffBusyDuration(duration time.Duration, event string)
- func (nc *NoopCollector) HotStuffIdleDuration(duration time.Duration)
- func (nc *NoopCollector) HotStuffWaitDuration(duration time.Duration, event string)
- func (nc *NoopCollector) InboundConnections(_ uint)
- func (nc *NoopCollector) InboundMessageDropped(engine string, message string)
- func (nc *NoopCollector) InboundMessageReceived(int, string, string, string)
- func (nc *NoopCollector) InitializeLatestHeight(height uint64)
- func (nc *NoopCollector) LatestTrieMaxDepthTouched(maxDepth uint16)
- func (nc *NoopCollector) LatestTrieRegCount(number uint64)
- func (nc *NoopCollector) LatestTrieRegCountDiff(number int64)
- func (nc *NoopCollector) LatestTrieRegSize(size uint64)
- func (nc *NoopCollector) LatestTrieRegSizeDiff(size int64)
- func (nc *NoopCollector) MempoolEntries(resource string, entries uint)
- func (nc *NoopCollector) MessageAdded(priority int)
- func (nc *NoopCollector) MessageHandled(engine string, message string)
- func (nc *NoopCollector) MessageProcessingFinished(topic string, duration time.Duration)
- func (nc *NoopCollector) MessageProcessingStarted(topic string)
- func (nc *NoopCollector) MessageReceived(engine string, message string)
- func (nc *NoopCollector) MessageRemoved(priority int)
- func (nc *NoopCollector) MessageSent(engine string, message string)
- func (nc *NoopCollector) MessagesReceived(prefix string, n uint64)
- func (nc *NoopCollector) NetworkDuplicateMessagesDropped(topic string, messageType string)
- func (nc *NoopCollector) NetworkMessageReceived(sizeBytes int, topic string, messageType string)
- func (nc *NoopCollector) NetworkMessageSent(sizeBytes int, topic string, messageType string)
- func (nc *NoopCollector) NewConnectionEstablished()
- func (nc *NoopCollector) NotificationSent(height uint64)
- func (nc *NoopCollector) ObserveHTTPRequestDuration(context.Context, httpmetrics.HTTPReqProperties, time.Duration)
- func (nc *NoopCollector) ObserveHTTPResponseSize(context.Context, httpmetrics.HTTPReqProperties, int64)
- func (nc *NoopCollector) OnActiveClusterIDsNotSetErr()
- func (nc *NoopCollector) OnAppSpecificScoreUpdated(f float64)
- func (nc *NoopCollector) OnApprovalProcessingDuration(duration time.Duration)
- func (nc *NoopCollector) OnAssignedChunkProcessedAtAssigner()
- func (nc *NoopCollector) OnAssignedChunkReceivedAtFetcher()
- func (nc *NoopCollector) OnBehaviourPenaltyUpdated(f float64)
- func (nc *NoopCollector) OnBlockConsumerJobDone(uint64)
- func (nc *NoopCollector) OnChunkConsumerJobDone(uint64)
- func (nc *NoopCollector) OnChunkDataPackArrivedAtFetcher()
- func (nc *NoopCollector) OnChunkDataPackRequestDispatchedInNetworkByRequester()
- func (nc *NoopCollector) OnChunkDataPackRequestReceivedByRequester()
- func (nc *NoopCollector) OnChunkDataPackRequestSentByFetcher()
- func (nc *NoopCollector) OnChunkDataPackResponseReceivedFromNetworkByRequester()
- func (nc *NoopCollector) OnChunkDataPackSentToFetcher()
- func (nc *NoopCollector) OnChunksAssignmentDoneAtAssigner(chunks int)
- func (nc *NoopCollector) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
- func (nc *NoopCollector) OnDNSCacheHit()
- func (nc *NoopCollector) OnDNSCacheInvalidated()
- func (nc *NoopCollector) OnDNSCacheMiss()
- func (nc *NoopCollector) OnDNSLookupRequestDropped()
- func (nc *NoopCollector) OnDialRetryBudgetResetToDefault()
- func (nc *NoopCollector) OnDialRetryBudgetUpdated(budget uint64)
- func (nc *NoopCollector) OnEntityEjectionDueToEmergency()
- func (nc *NoopCollector) OnEntityEjectionDueToFullCapacity()
- func (nc *NoopCollector) OnEstablishStreamFailure(duration time.Duration, attempts int)
- func (nc *NoopCollector) OnExecutionResultReceivedAtAssignerEngine()
- func (nc *NoopCollector) OnFinalizedBlockArrivedAtAssigner(height uint64)
- func (nc *NoopCollector) OnFirstMessageDeliveredUpdated(topic channels.Topic, f float64)
- func (nc *NoopCollector) OnGraftDuplicateTopicIdsExceedThreshold()
- func (nc *NoopCollector) OnGraftMessageInspected(duplicateTopicIds int)
- func (nc *NoopCollector) OnIHaveControlMessageIdsTruncated(diff int)
- func (nc *NoopCollector) OnIHaveDuplicateMessageIdsExceedThreshold()
- func (nc *NoopCollector) OnIHaveDuplicateTopicIdsExceedThreshold()
- func (nc *NoopCollector) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
- func (nc *NoopCollector) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int)
- func (nc *NoopCollector) OnIPColocationFactorUpdated(f float64)
- func (nc *NoopCollector) OnIWantCacheMissMessageIdsExceedThreshold()
- func (nc *NoopCollector) OnIWantControlMessageIdsTruncated(diff int)
- func (nc *NoopCollector) OnIWantDuplicateMessageIdsExceedThreshold()
- func (nc *NoopCollector) OnIWantMessageIDsReceived(msgIdCount int)
- func (nc *NoopCollector) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
- func (nc *NoopCollector) OnIncomingRpcReceived(iHaveCount, iWantCount, graftCount, pruneCount, msgCount int)
- func (nc *NoopCollector) OnInvalidControlMessageNotificationSent()
- func (nc *NoopCollector) OnInvalidMessageDeliveredUpdated(topic channels.Topic, f float64)
- func (nc *NoopCollector) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
- func (nc *NoopCollector) OnKeyGetFailure()
- func (nc *NoopCollector) OnKeyGetSuccess()
- func (nc *NoopCollector) OnKeyPutAttempt(uint32)
- func (nc *NoopCollector) OnKeyPutDeduplicated()
- func (nc *NoopCollector) OnKeyPutDrop()
- func (nc *NoopCollector) OnKeyPutSuccess(uint32)
- func (nc *NoopCollector) OnKeyRemoved(uint32)
- func (nc *NoopCollector) OnLocalMeshSizeUpdated(string, int)
- func (nc *NoopCollector) OnLocalPeerJoinedTopic()
- func (nc *NoopCollector) OnLocalPeerLeftTopic()
- func (nc *NoopCollector) OnMeshMessageDeliveredUpdated(topic channels.Topic, f float64)
- func (nc *NoopCollector) OnMessageDeliveredToAllSubscribers(size int)
- func (nc *NoopCollector) OnMessageDuplicate(size int)
- func (nc *NoopCollector) OnMessageEnteredValidation(size int)
- func (nc *NoopCollector) OnMessageRejected(size int, reason string)
- func (nc *NoopCollector) OnMisbehaviorReported(string, string)
- func (nc *NoopCollector) OnOutboundRpcDropped()
- func (nc *NoopCollector) OnOverallPeerScoreUpdated(f float64)
- func (nc *NoopCollector) OnPeerAddedToProtocol(protocol string)
- func (nc *NoopCollector) OnPeerDialFailure(duration time.Duration, attempts int)
- func (nc *NoopCollector) OnPeerDialed(duration time.Duration, attempts int)
- func (nc *NoopCollector) OnPeerGraftTopic(topic string)
- func (nc *NoopCollector) OnPeerPruneTopic(topic string)
- func (nc *NoopCollector) OnPeerRemovedFromProtocol()
- func (nc *NoopCollector) OnPeerThrottled()
- func (nc *NoopCollector) OnPruneDuplicateTopicIdsExceedThreshold()
- func (nc *NoopCollector) OnPruneMessageInspected(duplicateTopicIds int)
- func (nc *NoopCollector) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, ...)
- func (nc *NoopCollector) OnPublishMessagesInspectionErrorExceedsThreshold()
- func (nc *NoopCollector) OnRateLimitedPeer(pid peer.ID, role, msgType, topic, reason string)
- func (nc *NoopCollector) OnReceiptProcessingDuration(duration time.Duration)
- func (nc *NoopCollector) OnResultApprovalDispatchedInNetworkByVerifier()
- func (nc *NoopCollector) OnRpcReceived(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (nc *NoopCollector) OnRpcSent(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (nc *NoopCollector) OnStreamCreated(duration time.Duration, attempts int)
- func (nc *NoopCollector) OnStreamCreationFailure(duration time.Duration, attempts int)
- func (nc *NoopCollector) OnStreamCreationRetryBudgetResetToDefault()
- func (nc *NoopCollector) OnStreamCreationRetryBudgetUpdated(budget uint64)
- func (nc *NoopCollector) OnStreamEstablished(duration time.Duration, attempts int)
- func (nc *NoopCollector) OnTimeInMeshUpdated(topic channels.Topic, duration time.Duration)
- func (nc *NoopCollector) OnUnauthorizedMessage(role, msgType, topic, offense string)
- func (nc *NoopCollector) OnUndeliveredMessage()
- func (nc *NoopCollector) OnUnstakedPeerInspectionFailed()
- func (nc *NoopCollector) OnVerifiableChunkReceivedAtVerifierEngine()
- func (nc *NoopCollector) OnVerifiableChunkSentToVerifier()
- func (nc *NoopCollector) OnViolationReportSkipped()
- func (nc *NoopCollector) OutboundConnections(_ uint)
- func (nc *NoopCollector) OutboundMessageDropped(engine string, messages string)
- func (nc *NoopCollector) OutboundMessageSent(int, string, string, string)
- func (nc *NoopCollector) PayloadProductionDuration(duration time.Duration)
- func (nc *NoopCollector) Peers(prefix string, n int)
- func (nc *NoopCollector) ProofSize(bytes uint32)
- func (nc *NoopCollector) Pruned(height uint64, duration time.Duration)
- func (nc *NoopCollector) PrunedBlockByHeight(status *chainsync.Status)
- func (nc *NoopCollector) PrunedBlockById(status *chainsync.Status)
- func (nc *NoopCollector) PrunedBlocks(totalByHeight, totalById, storedByHeight, storedById int)
- func (nc *NoopCollector) QueueDuration(duration time.Duration, priority int)
- func (nc *NoopCollector) RanGC(duration time.Duration)
- func (nc *NoopCollector) RangeRequested(ran chainsync.Range)
- func (nc *NoopCollector) ReadDuration(duration time.Duration)
- func (nc *NoopCollector) ReadDurationPerItem(duration time.Duration)
- func (nc *NoopCollector) ReadValuesNumber(number uint64)
- func (nc *NoopCollector) ReadValuesSize(byte uint64)
- func (nc *NoopCollector) ReceiptSkipped()
- func (nc *NoopCollector) RecordRPC(handler, rpc string, code codes.Code)
- func (nc *NoopCollector) Register(resource string, entriesFunc module.EntriesFunc) error
- func (nc *NoopCollector) RequestCanceled()
- func (nc *NoopCollector) RequestFailed(duration time.Duration, retryable bool)
- func (nc *NoopCollector) RequestSucceeded(uint64, time.Duration, uint64, int)
- func (nc *NoopCollector) ResponseDropped()
- func (nc *NoopCollector) RootIDComputed(duration time.Duration, numberOfChunks int)
- func (nc *NoopCollector) RoutingTablePeerAdded()
- func (nc *NoopCollector) RoutingTablePeerRemoved()
- func (nc *NoopCollector) RuntimeSetNumberOfAccounts(count uint64)
- func (nc *NoopCollector) RuntimeTransactionChecked(dur time.Duration)
- func (nc *NoopCollector) RuntimeTransactionInterpreted(dur time.Duration)
- func (nc *NoopCollector) RuntimeTransactionParsed(dur time.Duration)
- func (nc *NoopCollector) RuntimeTransactionProgramsCacheHit()
- func (nc *NoopCollector) RuntimeTransactionProgramsCacheMiss()
- func (nc *NoopCollector) ScriptExecuted(dur time.Duration, size int)
- func (nc *NoopCollector) ScriptExecutionErrorLocal()
- func (nc *NoopCollector) ScriptExecutionErrorMatch()
- func (nc *NoopCollector) ScriptExecutionErrorMismatch()
- func (nc *NoopCollector) ScriptExecutionErrorOnExecutionNode()
- func (nc *NoopCollector) ScriptExecutionNotIndexed()
- func (nc *NoopCollector) ScriptExecutionResultMatch()
- func (nc *NoopCollector) ScriptExecutionResultMismatch()
- func (nc *NoopCollector) SealedHeight(height uint64)
- func (nc *NoopCollector) SetCurView(view uint64)
- func (nc *NoopCollector) SetMaxChunkDataPackAttemptsForNextUnsealedHeightAtRequester(attempts uint64)
- func (nc *NoopCollector) SetQCView(view uint64)
- func (nc *NoopCollector) SetTCView(uint64)
- func (nc *NoopCollector) SetTimeout(duration time.Duration)
- func (nc *NoopCollector) SetWarningStateCount(u uint)
- func (nc *NoopCollector) SignerProcessingDuration(duration time.Duration)
- func (nc *NoopCollector) StartBlockReceivedToExecuted(blockID flow.Identifier)
- func (nc *NoopCollector) StartBlockToSeal(blockID flow.Identifier)
- func (nc *NoopCollector) StartCollectionToFinalized(collectionID flow.Identifier)
- func (nc *NoopCollector) TimeoutCollectorsRange(uint64, uint64, int)
- func (nc *NoopCollector) TimeoutObjectProcessingDuration(time.Duration)
- func (nc *NoopCollector) TotalConnectionsInPool(connectionCount uint, connectionPoolSize uint)
- func (nc *NoopCollector) TransactionExecuted(txID flow.Identifier, when time.Time)
- func (nc *NoopCollector) TransactionExpired(txID flow.Identifier)
- func (nc *NoopCollector) TransactionFinalized(txID flow.Identifier, when time.Time)
- func (nc *NoopCollector) TransactionIngested(txID flow.Identifier)
- func (nc *NoopCollector) TransactionReceived(txID flow.Identifier, when time.Time)
- func (nc *NoopCollector) TransactionResultFetched(dur time.Duration, size int)
- func (nc *NoopCollector) TransactionSubmissionFailed()
- func (nc *NoopCollector) UnicastMessageSendingCompleted(topic string)
- func (nc *NoopCollector) UnicastMessageSendingStarted(topic string)
- func (nc *NoopCollector) UnstakedInboundConnections(_ uint)
- func (nc *NoopCollector) UnstakedOutboundConnections(_ uint)
- func (nc *NoopCollector) UpdateCollectionMaxHeight(height uint64)
- func (nc *NoopCollector) UpdateCount()
- func (nc *NoopCollector) UpdateDuration(duration time.Duration)
- func (nc *NoopCollector) UpdateDurationPerItem(duration time.Duration)
- func (nc *NoopCollector) UpdateExecutionReceiptMaxHeight(height uint64)
- func (nc *NoopCollector) UpdateLastFullBlockHeight(height uint64)
- func (nc *NoopCollector) UpdateValuesNumber(number uint64)
- func (nc *NoopCollector) UpdateValuesSize(byte uint64)
- func (nc *NoopCollector) ValidatorProcessingDuration(duration time.Duration)
- func (nc *NoopCollector) VoteProcessingDuration(time.Duration)
- func (nc *NoopCollector) Wantlist(prefix string, n int)
- type ObserverCollector
- type ObserverMetrics
- type PingCollector
- type RateLimitedBlockstoreCollector
- type RestCollector
- func (r *RestCollector) AddInflightRequests(_ context.Context, p httpmetrics.HTTPProperties, quantity int)
- func (r *RestCollector) AddTotalRequests(_ context.Context, method, path string)
- func (r *RestCollector) ObserveHTTPRequestDuration(_ context.Context, p httpmetrics.HTTPReqProperties, duration time.Duration)
- func (r *RestCollector) ObserveHTTPResponseSize(_ context.Context, p httpmetrics.HTTPReqProperties, sizeBytes int64)
- type Server
- type StorageCollector
- type TransactionCollector
- func (tc *TransactionCollector) ScriptExecuted(dur time.Duration, size int)
- func (tc *TransactionCollector) ScriptExecutionErrorLocal()
- func (tc *TransactionCollector) ScriptExecutionErrorMatch()
- func (tc *TransactionCollector) ScriptExecutionErrorMismatch()
- func (tc *TransactionCollector) ScriptExecutionErrorOnExecutionNode()
- func (tc *TransactionCollector) ScriptExecutionNotIndexed()
- func (tc *TransactionCollector) ScriptExecutionResultMatch()
- func (tc *TransactionCollector) ScriptExecutionResultMismatch()
- func (tc *TransactionCollector) TransactionExecuted(txID flow.Identifier, when time.Time)
- func (tc *TransactionCollector) TransactionExpired(txID flow.Identifier)
- func (tc *TransactionCollector) TransactionFinalized(txID flow.Identifier, when time.Time)
- func (tc *TransactionCollector) TransactionReceived(txID flow.Identifier, when time.Time)
- func (tc *TransactionCollector) TransactionResultFetched(dur time.Duration, size int)
- func (tc *TransactionCollector) TransactionSubmissionFailed()
- type UnicastManagerMetrics
- func (u *UnicastManagerMetrics) OnDialRetryBudgetResetToDefault()
- func (u *UnicastManagerMetrics) OnDialRetryBudgetUpdated(budget uint64)
- func (u *UnicastManagerMetrics) OnEstablishStreamFailure(duration time.Duration, attempts int)
- func (u *UnicastManagerMetrics) OnPeerDialFailure(duration time.Duration, attempts int)
- func (u *UnicastManagerMetrics) OnPeerDialed(duration time.Duration, attempts int)
- func (u *UnicastManagerMetrics) OnStreamCreated(duration time.Duration, attempts int)
- func (u *UnicastManagerMetrics) OnStreamCreationFailure(duration time.Duration, attempts int)
- func (u *UnicastManagerMetrics) OnStreamCreationRetryBudgetResetToDefault()
- func (u *UnicastManagerMetrics) OnStreamCreationRetryBudgetUpdated(budget uint64)
- func (u *UnicastManagerMetrics) OnStreamEstablished(duration time.Duration, attempts int)
- type VerificationCollector
- func (vc *VerificationCollector) OnAssignedChunkProcessedAtAssigner()
- func (vc *VerificationCollector) OnAssignedChunkReceivedAtFetcher()
- func (vc *VerificationCollector) OnBlockConsumerJobDone(processedIndex uint64)
- func (vc *VerificationCollector) OnChunkConsumerJobDone(processedIndex uint64)
- func (vc *VerificationCollector) OnChunkDataPackArrivedAtFetcher()
- func (vc *VerificationCollector) OnChunkDataPackRequestDispatchedInNetworkByRequester()
- func (vc *VerificationCollector) OnChunkDataPackRequestReceivedByRequester()
- func (vc *VerificationCollector) OnChunkDataPackRequestSentByFetcher()
- func (vc *VerificationCollector) OnChunkDataPackResponseReceivedFromNetworkByRequester()
- func (vc *VerificationCollector) OnChunkDataPackSentToFetcher()
- func (vc *VerificationCollector) OnChunksAssignmentDoneAtAssigner(chunks int)
- func (vc *VerificationCollector) OnExecutionResultReceivedAtAssignerEngine()
- func (vc *VerificationCollector) OnFinalizedBlockArrivedAtAssigner(height uint64)
- func (vc *VerificationCollector) OnResultApprovalDispatchedInNetworkByVerifier()
- func (vc *VerificationCollector) OnVerifiableChunkReceivedAtVerifierEngine()
- func (vc *VerificationCollector) OnVerifiableChunkSentToVerifier()
- func (vc *VerificationCollector) SetMaxChunkDataPackAttemptsForNextUnsealedHeightAtRequester(attempts uint64)
Constants ¶
const ( HotstuffEventTypeLocalTimeout = "localtimeout" HotstuffEventTypeOnProposal = "onproposal" HotstuffEventTypeOnQC = "onqc" HotstuffEventTypeOnTC = "ontc" HotstuffEventTypeOnPartialTc = "onpartialtc" )
HotStuff Metrics
const ( LabelChannel = "topic" LabelChain = "chain" LabelProposer = "proposer" EngineLabel = "engine" LabelResource = "resource" LabelProtocol = "protocol" LabelMessage = "message" LabelNodeID = "nodeid" LabelNodeAddress = "nodeaddress" LabelNodeRole = "noderole" LabelNodeInfo = "nodeinfo" LabelNodeVersion = "nodeversion" LabelPriority = "priority" LabelComputationKind = "computationKind" LabelConnectionDirection = "direction" LabelConnectionUseFD = "usefd" // whether the connection is using a file descriptor LabelSuccess = "success" LabelMisbehavior = "misbehavior" LabelHandler = "handler" LabelStatusCode = "code" LabelMethod = "method" LabelService = "service" LabelRejectionReason = "rejection_reason" )
const ( // collection EngineClusterCompliance = "collection_compliance" EngineCollectionMessageHub = "collection_message_hub" EngineCollectionIngest = "collection_ingest" EngineCollectionProvider = "collection_provider" EngineClusterSynchronization = "cluster-sync" // consensus EnginePropagation = "propagation" EngineCompliance = "compliance" EngineConsensusMessageHub = "consensus_message_hub" EngineConsensusIngestion = "consensus_ingestion" EngineSealing = "sealing" EngineSynchronization = "sync" // common EngineFollower = "follower" EngineVoteAggregator = "vote_aggregator" EngineTimeoutAggregator = "timeout_aggregator" )
const ( ResourceUndefined = "undefined" ResourceProposal = "proposal" ResourceHeader = "header" ResourceFinalizedHeight = "finalized_height" ResourceIndex = "index" ResourceIdentity = "identity" ResourceGuarantee = "guarantee" ResourceResult = "result" ResourceResultApprovals = "result_approvals" ResourceReceipt = "receipt" ResourceQC = "qc" ResourceMyReceipt = "my_receipt" ResourceCollection = "collection" ResourceApproval = "approval" ResourceSeal = "seal" ResourcePendingIncorporatedSeal = "pending_incorporated_seal" ResourceCommit = "commit" ResourceTransaction = "transaction" ResourceClusterPayload = "cluster_payload" ResourceClusterProposal = "cluster_proposal" ResourceProcessedResultID = "processed_result_id" // verification node, finder engine // TODO: remove finder engine labels ResourceDiscardedResultID = "discarded_result_id" // verification node, finder engine ResourcePendingReceipt = "pending_receipt" // verification node, finder engine ResourceReceiptIDsByResult = "receipt_ids_by_result" // verification node, finder engine ResourcePendingReceiptIDsByBlock = "pending_receipt_ids_by_block" // verification node, finder engine ResourcePendingResult = "pending_result" // verification node, match engine ResourceChunkIDsByResult = "chunk_ids_by_result" // verification node, match engine ResourcePendingChunk = "pending_chunk" // verification node, match engine ResourcePendingBlock = "pending_block" // verification node, match engine ResourceCachedReceipt = "cached_receipt" // verification node, finder engine ResourceCachedBlockID = "cached_block_id" // verification node, finder engine ResourceChunkStatus = "chunk_status" // verification node, fetcher engine ResourceChunkRequest = "chunk_request" // verification node, requester engine ResourceChunkConsumer = "chunk_consumer_jobs" // verification node ResourceBlockConsumer = "block_consumer_jobs" // verification node ResourceEpochSetup = "epoch_setup" ResourceEpochCommit = "epoch_commit" ResourceEpochStatus = "epoch_status" ResourceNetworkingReceiveCache = "networking_received_message" // networking layer ResourceNetworkingSubscriptionRecordsCache = "subscription_records_cache" // networking layer ResourceNetworkingDnsIpCache = "networking_dns_ip_cache" // networking layer ResourceNetworkingDnsTxtCache = "networking_dns_txt_cache" // networking layer ResourceNetworkingDisallowListNotificationQueue = "networking_disallow_list_notification_queue" ResourceNetworkingRpcInspectorNotificationQueue = "networking_rpc_inspector_notification_queue" ResourceNetworkingRpcValidationInspectorQueue = "networking_rpc_validation_inspector_queue" ResourceNetworkingApplicationLayerSpamRecordCache = "application_layer_spam_record_cache" ResourceNetworkingApplicationLayerSpamReportQueue = "application_layer_spam_report_queue" ResourceNetworkingRpcClusterPrefixReceivedCache = "rpc_cluster_prefixed_received_cache" ResourceNetworkingAppSpecificScoreUpdateQueue = "gossipsub_app_specific_score_update_queue" ResourceNetworkingGossipSubApplicationSpecificScoreCache = "gossipsub_application_specific_score_cache" ResourceNetworkingGossipSubSpamRecordCache = "gossipsub_spam_record_cache" ResourceNetworkingDisallowListCache = "disallow_list_cache" ResourceNetworkingRPCSentTrackerCache = "gossipsub_rpc_sent_tracker_cache" ResourceNetworkingRPCSentTrackerQueue = "gossipsub_rpc_sent_tracker_queue" ResourceNetworkingUnicastDialConfigCache = "unicast_dial_config_cache" ResourceFollowerPendingBlocksCache = "follower_pending_block_cache" // follower engine ResourceFollowerLoopCertifiedBlocksChannel = "follower_loop_certified_blocks_channel" // follower loop, certified blocks buffered channel ResourceClusterBlockProposalQueue = "cluster_compliance_proposal_queue" // collection node, compliance engine ResourceTransactionIngestQueue = "ingest_transaction_queue" // collection node, ingest engine ResourceBeaconKey = "beacon-key" // consensus node, DKG engine ResourceDKGMessage = "dkg_private_message" // consensus, DKG messaging engine ResourceApprovalQueue = "sealing_approval_queue" // consensus node, sealing engine ResourceReceiptQueue = "sealing_receipt_queue" // consensus node, sealing engine ResourceApprovalResponseQueue = "sealing_approval_response_queue" // consensus node, sealing engine ResourceBlockResponseQueue = "compliance_block_response_queue" // consensus node, compliance engine ResourceBlockProposalQueue = "compliance_proposal_queue" // consensus node, compliance engine ResourceBlockVoteQueue = "vote_aggregator_queue" // consensus/collection node, vote aggregator ResourceTimeoutObjectQueue = "timeout_aggregator_queue" // consensus/collection node, timeout aggregator ResourceCollectionGuaranteesQueue = "ingestion_col_guarantee_queue" // consensus node, ingestion engine ResourceChunkDataPack = "chunk_data_pack" // execution node ResourceChunkDataPackRequests = "chunk_data_pack_request" // execution node ResourceEvents = "events" // execution node ResourceServiceEvents = "service_events" // execution node ResourceTransactionResults = "transaction_results" // execution node ResourceTransactionResultIndices = "transaction_result_indices" // execution node ResourceTransactionResultByBlock = "transaction_result_by_block" // execution node ResourceExecutionDataCache = "execution_data_cache" // access node )
const ( MessageCollectionGuarantee = "guarantee" MessageBlockProposal = "proposal" MessageBlockVote = "vote" MessageTimeoutObject = "timeout_object" MessageExecutionReceipt = "receipt" MessageResultApproval = "approval" MessageSyncRequest = "ping" MessageSyncResponse = "pong" MessageRangeRequest = "range" MessageBatchRequest = "batch" MessageBlockResponse = "block" MessageSyncedBlocks = "synced_blocks" MessageSyncedClusterBlock = "synced_cluster_block" MessageTransaction = "transaction" MessageSubmitGuarantee = "submit_guarantee" MessageCollectionRequest = "collection_request" MessageCollectionResponse = "collection_response" MessageEntityRequest = "entity_request" MessageEntityResponse = "entity_response" )
const ( KiB = 1 << (10 * iota) MiB GiB )
const ExecutionDataRequestRetryable = "retryable"
const LabelRateLimitReason = "reason"
const LabelViolationReason = "reason"
Variables ¶
This section is empty.
Functions ¶
func ApplicationLayerSpamRecordCacheMetricFactory ¶ added in v0.31.0
func ApplicationLayerSpamRecordCacheMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
func ApplicationLayerSpamRecordQueueMetricsFactory ¶ added in v0.31.0
func ApplicationLayerSpamRecordQueueMetricsFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
func DialConfigCacheMetricFactory ¶ added in v0.32.2
func DialConfigCacheMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
func DisallowListCacheMetricsFactory ¶ added in v0.32.0
func DisallowListCacheMetricsFactory(f HeroCacheMetricsFactory, networkingType network.NetworkingType) module.HeroCacheMetrics
DisallowListCacheMetricsFactory is the factory method for creating a new HeroCacheCollector for the disallow list cache. The disallow-list cache is used to keep track of peers that are disallow-listed and the reasons for it. Args: - f: the HeroCacheMetricsFactory to create the collector - networkingType: the networking type of the cache, i.e., whether it is used for the public or the private network Returns: - a HeroCacheMetrics for the disallow list cache
func GossipSubAppSpecificScoreUpdateQueueMetricFactory ¶ added in v0.33.1
func GossipSubAppSpecificScoreUpdateQueueMetricFactory(f HeroCacheMetricsFactory, networkingType network.NetworkingType) module.HeroCacheMetrics
GossipSubAppSpecificScoreUpdateQueueMetricFactory is the factory method for creating a new HeroCacheCollector for the app-specific score update queue of the GossipSub peer scoring module. The app-specific score update queue is used to queue the update requests for the app-specific score of peers. The update requests are queued in a worker pool and processed asynchronously. Args: - f: the HeroCacheMetricsFactory to create the collector Returns: - a HeroCacheMetrics for the app-specific score update queue.
func GossipSubRPCInspectorClusterPrefixedCacheMetricFactory ¶ added in v0.31.0
func GossipSubRPCInspectorClusterPrefixedCacheMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
func GossipSubRPCInspectorQueueMetricFactory ¶ added in v0.31.0
func GossipSubRPCInspectorQueueMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
func GossipSubRPCSentTrackerMetricFactory ¶ added in v0.32.0
func GossipSubRPCSentTrackerMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
func GossipSubRPCSentTrackerQueueMetricFactory ¶ added in v0.32.0
func GossipSubRPCSentTrackerQueueMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
func GossipSubSpamRecordCacheMetricsFactory ¶ added in v0.33.1
func GossipSubSpamRecordCacheMetricsFactory(f HeroCacheMetricsFactory, networkingType network.NetworkingType) module.HeroCacheMetrics
GossipSubSpamRecordCacheMetricsFactory is the factory method for creating a new HeroCacheCollector for the spam record cache. The spam record cache is used to keep track of peers that are spamming the network and the reasons for it.
func NetworkReceiveCacheMetricsFactory ¶ added in v0.25.2
func NetworkReceiveCacheMetricsFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
func NewExecutionDataRequesterCollector ¶ added in v0.26.2
func NewExecutionDataRequesterCollector() module.ExecutionDataRequesterMetrics
func NewExecutionStateIndexerCollector ¶ added in v0.32.1
func NewExecutionStateIndexerCollector() module.ExecutionStateIndexerMetrics
func NewGossipSubApplicationSpecificScoreCacheMetrics ¶ added in v0.33.1
func NewGossipSubApplicationSpecificScoreCacheMetrics(f HeroCacheMetricsFactory, networkingType network.NetworkingType) module.HeroCacheMetrics
NewGossipSubApplicationSpecificScoreCacheMetrics is the factory method for creating a new HeroCacheCollector for the application specific score cache of the GossipSub peer scoring module. The application specific score cache is used to keep track of the application specific score of peers in GossipSub. Args: - f: the HeroCacheMetricsFactory to create the collector Returns: - a HeroCacheMetrics for the application specific score cache
func NewRateLimitedBlockstoreCollector ¶ added in v0.28.0
func NewRateLimitedBlockstoreCollector(prefix string) module.RateLimitedBlockstoreMetrics
func NewSubscriptionRecordCacheMetricsFactory ¶ added in v0.33.1
func NewSubscriptionRecordCacheMetricsFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
func PrependPublicPrefix ¶ added in v0.31.0
PrependPublicPrefix prepends the string "public" to the given string. This is used to distinguish between public and private metrics. Args: - str: the string to prepend, example: "my_metric" Returns: - the prepended string, example: "public_my_metric"
func RegisterBadgerMetrics ¶
func RegisterBadgerMetrics() error
func RpcInspectorNotificationQueueMetricFactory ¶ added in v0.30.0
func RpcInspectorNotificationQueueMetricFactory(f HeroCacheMetricsFactory, networkType network.NetworkingType) module.HeroCacheMetrics
Types ¶
type AccessCollector ¶ added in v0.26.16
type AccessCollector struct { module.RestMetrics module.TransactionMetrics module.BackendScriptsMetrics // contains filtered or unexported fields }
func NewAccessCollector ¶ added in v0.26.16
func NewAccessCollector(opts ...AccessCollectorOpts) *AccessCollector
func (*AccessCollector) ConnectionAddedToPool ¶ added in v0.26.17
func (ac *AccessCollector) ConnectionAddedToPool()
func (*AccessCollector) ConnectionFromPoolEvicted ¶ added in v0.26.17
func (ac *AccessCollector) ConnectionFromPoolEvicted()
func (*AccessCollector) ConnectionFromPoolInvalidated ¶ added in v0.26.17
func (ac *AccessCollector) ConnectionFromPoolInvalidated()
func (*AccessCollector) ConnectionFromPoolReused ¶ added in v0.26.17
func (ac *AccessCollector) ConnectionFromPoolReused()
func (*AccessCollector) ConnectionFromPoolUpdated ¶ added in v0.26.17
func (ac *AccessCollector) ConnectionFromPoolUpdated()
func (*AccessCollector) NewConnectionEstablished ¶ added in v0.26.17
func (ac *AccessCollector) NewConnectionEstablished()
func (*AccessCollector) TotalConnectionsInPool ¶ added in v0.26.16
func (ac *AccessCollector) TotalConnectionsInPool(connectionCount uint, connectionPoolSize uint)
func (*AccessCollector) UpdateExecutionReceiptMaxHeight ¶ added in v0.31.0
func (ac *AccessCollector) UpdateExecutionReceiptMaxHeight(height uint64)
func (*AccessCollector) UpdateLastFullBlockHeight ¶ added in v0.31.0
func (ac *AccessCollector) UpdateLastFullBlockHeight(height uint64)
type AccessCollectorOpts ¶ added in v0.31.0
type AccessCollectorOpts func(*AccessCollector)
func WithBackendScriptsMetrics ¶ added in v0.31.0
func WithBackendScriptsMetrics(m module.BackendScriptsMetrics) AccessCollectorOpts
func WithRestMetrics ¶ added in v0.31.14
func WithRestMetrics(m module.RestMetrics) AccessCollectorOpts
func WithTransactionMetrics ¶ added in v0.31.0
func WithTransactionMetrics(m module.TransactionMetrics) AccessCollectorOpts
type AlspMetrics ¶ added in v0.31.0
type AlspMetrics struct {
// contains filtered or unexported fields
}
AlspMetrics is a struct that contains all the metrics related to the ALSP module. It implements the AlspMetrics interface. AlspMetrics encapsulates the metrics collectors for the Application Layer Spam Prevention (ALSP) module, which is part of the networking layer. ALSP is responsible to prevent spam attacks on the application layer messages that appear to be valid for the networking layer but carry on a malicious intent on the application layer (i.e., Flow protocols).
func NewAlspMetrics ¶ added in v0.31.0
func NewAlspMetrics() *AlspMetrics
NewAlspMetrics creates a new AlspMetrics struct. It initializes the metrics collectors for the ALSP module. Returns: - a pointer to the AlspMetrics struct.
func (*AlspMetrics) OnMisbehaviorReported ¶ added in v0.31.0
func (a *AlspMetrics) OnMisbehaviorReported(channel string, misbehaviorType string)
OnMisbehaviorReported is called when a misbehavior is reported by the application layer to ALSP. An engine detecting a spamming-related misbehavior reports it to the ALSP module. It increases the counter vector of reported misbehavior. Args: - channel: the channel on which the misbehavior was reported - misbehaviorType: the type of misbehavior reported
type BitswapCollector ¶ added in v0.27.3
type BitswapCollector struct {
// contains filtered or unexported fields
}
func NewBitswapCollector ¶ added in v0.27.3
func NewBitswapCollector() *BitswapCollector
func (*BitswapCollector) BlobsReceived ¶ added in v0.27.3
func (bc *BitswapCollector) BlobsReceived(prefix string, n uint64)
func (*BitswapCollector) BlobsSent ¶ added in v0.27.3
func (bc *BitswapCollector) BlobsSent(prefix string, n uint64)
func (*BitswapCollector) DataReceived ¶ added in v0.27.3
func (bc *BitswapCollector) DataReceived(prefix string, n uint64)
func (*BitswapCollector) DataSent ¶ added in v0.27.3
func (bc *BitswapCollector) DataSent(prefix string, n uint64)
func (*BitswapCollector) DupBlobsReceived ¶ added in v0.27.3
func (bc *BitswapCollector) DupBlobsReceived(prefix string, n uint64)
func (*BitswapCollector) DupDataReceived ¶ added in v0.27.3
func (bc *BitswapCollector) DupDataReceived(prefix string, n uint64)
func (*BitswapCollector) MessagesReceived ¶ added in v0.27.3
func (bc *BitswapCollector) MessagesReceived(prefix string, n uint64)
func (*BitswapCollector) Peers ¶ added in v0.27.3
func (bc *BitswapCollector) Peers(prefix string, n int)
func (*BitswapCollector) Wantlist ¶ added in v0.27.3
func (bc *BitswapCollector) Wantlist(prefix string, n int)
type CacheCollector ¶
type CacheCollector struct {
// contains filtered or unexported fields
}
func NewCacheCollector ¶
func NewCacheCollector(chain flow.ChainID) *CacheCollector
func (*CacheCollector) CacheEntries ¶
func (cc *CacheCollector) CacheEntries(resource string, entries uint)
CacheEntries records the size of the node identities cache.
func (*CacheCollector) CacheHit ¶
func (cc *CacheCollector) CacheHit(resource string)
CacheHit records the number of hits in the node identities cache.
func (*CacheCollector) CacheMiss ¶
func (cc *CacheCollector) CacheMiss(resource string)
CacheMiss report the number of times the queried item is not found in the cache, but found in the database.
func (*CacheCollector) CacheNotFound ¶ added in v0.16.0
func (cc *CacheCollector) CacheNotFound(resource string)
CacheNotFound records the number of times the queried item was not found in either cache or database.
type ChainSyncCollector ¶ added in v0.27.0
type ChainSyncCollector struct {
// contains filtered or unexported fields
}
func NewChainSyncCollector ¶ added in v0.27.0
func NewChainSyncCollector(chainID flow.ChainID) *ChainSyncCollector
func (*ChainSyncCollector) BatchRequested ¶ added in v0.27.0
func (c *ChainSyncCollector) BatchRequested(batch chainsync.Batch)
func (*ChainSyncCollector) PrunedBlockByHeight ¶ added in v0.27.0
func (c *ChainSyncCollector) PrunedBlockByHeight(status *chainsync.Status)
func (*ChainSyncCollector) PrunedBlockById ¶ added in v0.27.0
func (c *ChainSyncCollector) PrunedBlockById(status *chainsync.Status)
func (*ChainSyncCollector) PrunedBlocks ¶ added in v0.27.0
func (c *ChainSyncCollector) PrunedBlocks(totalByHeight, totalById, storedByHeight, storedById int)
func (*ChainSyncCollector) RangeRequested ¶ added in v0.27.0
func (c *ChainSyncCollector) RangeRequested(ran chainsync.Range)
type CleanerCollector ¶
type CleanerCollector struct {
// contains filtered or unexported fields
}
func NewCleanerCollector ¶
func NewCleanerCollector() *CleanerCollector
func (*CleanerCollector) RanGC ¶
func (cc *CleanerCollector) RanGC(duration time.Duration)
RanGC records a successful run of the Badger garbage collector.
type CollectionCollector ¶
type CollectionCollector struct {
// contains filtered or unexported fields
}
func NewCollectionCollector ¶
func NewCollectionCollector(tracer module.Tracer) *CollectionCollector
func (*CollectionCollector) ClusterBlockFinalized ¶
func (cc *CollectionCollector) ClusterBlockFinalized(block *cluster.Block)
ClusterBlockFinalized updates the guaranteed collection size gauge and finishes the tx->collection span for each constituent transaction.
func (*CollectionCollector) ClusterBlockProposed ¶
func (cc *CollectionCollector) ClusterBlockProposed(block *cluster.Block)
ClusterBlockProposed tracks the size and number of proposals, as well as starting the collection->guarantee span.
func (*CollectionCollector) TransactionIngested ¶
func (cc *CollectionCollector) TransactionIngested(txID flow.Identifier)
TransactionIngested starts a span to trace the duration of a transaction from being created to being included as part of a collection.
type ComplianceCollector ¶
type ComplianceCollector struct {
// contains filtered or unexported fields
}
func NewComplianceCollector ¶
func NewComplianceCollector() *ComplianceCollector
func (*ComplianceCollector) BlockFinalized ¶
func (cc *ComplianceCollector) BlockFinalized(block *flow.Block)
BlockFinalized reports metrics about finalized blocks.
func (*ComplianceCollector) BlockSealed ¶
func (cc *ComplianceCollector) BlockSealed(block *flow.Block)
BlockSealed reports metrics about sealed blocks.
func (*ComplianceCollector) CommittedEpochFinalView ¶ added in v0.18.3
func (cc *ComplianceCollector) CommittedEpochFinalView(view uint64)
func (*ComplianceCollector) CurrentDKGPhase1FinalView ¶ added in v0.21.0
func (cc *ComplianceCollector) CurrentDKGPhase1FinalView(view uint64)
func (*ComplianceCollector) CurrentDKGPhase2FinalView ¶ added in v0.21.0
func (cc *ComplianceCollector) CurrentDKGPhase2FinalView(view uint64)
func (*ComplianceCollector) CurrentDKGPhase3FinalView ¶ added in v0.21.0
func (cc *ComplianceCollector) CurrentDKGPhase3FinalView(view uint64)
func (*ComplianceCollector) CurrentEpochCounter ¶ added in v0.20.0
func (cc *ComplianceCollector) CurrentEpochCounter(counter uint64)
func (*ComplianceCollector) CurrentEpochFinalView ¶ added in v0.21.0
func (cc *ComplianceCollector) CurrentEpochFinalView(view uint64)
func (*ComplianceCollector) CurrentEpochPhase ¶ added in v0.20.0
func (cc *ComplianceCollector) CurrentEpochPhase(phase flow.EpochPhase)
func (*ComplianceCollector) EpochEmergencyFallbackTriggered ¶ added in v0.23.2
func (cc *ComplianceCollector) EpochEmergencyFallbackTriggered()
func (*ComplianceCollector) EpochTransitionHeight ¶ added in v0.30.0
func (cc *ComplianceCollector) EpochTransitionHeight(height uint64)
func (*ComplianceCollector) FinalizedHeight ¶
func (cc *ComplianceCollector) FinalizedHeight(height uint64)
FinalizedHeight sets the finalized height.
func (*ComplianceCollector) SealedHeight ¶
func (cc *ComplianceCollector) SealedHeight(height uint64)
SealedHeight sets the finalized height.
type ConsensusCollector ¶
type ConsensusCollector struct {
// contains filtered or unexported fields
}
ConsensusCollector ...
func NewConsensusCollector ¶
func NewConsensusCollector(tracer module.Tracer, registerer prometheus.Registerer) *ConsensusCollector
NewConsensusCollector created a new consensus collector
func (*ConsensusCollector) CheckSealingDuration ¶ added in v0.11.0
func (cc *ConsensusCollector) CheckSealingDuration(duration time.Duration)
CheckSealingDuration increases the number of seconds spent in checkSealing
func (*ConsensusCollector) EmergencySeal ¶ added in v0.14.0
func (cc *ConsensusCollector) EmergencySeal()
EmergencySeal increments the counter of emergency seals.
func (*ConsensusCollector) FinishBlockToSeal ¶
func (cc *ConsensusCollector) FinishBlockToSeal(blockID flow.Identifier)
FinishBlockToSeal reports Metrics C4: Block Received by CCL → Block Seal in finalized block
func (*ConsensusCollector) FinishCollectionToFinalized ¶
func (cc *ConsensusCollector) FinishCollectionToFinalized(collectionID flow.Identifier)
FinishCollectionToFinalized reports Metrics C1: Collection Received by CCL→ Collection Included in Finalized Block
func (*ConsensusCollector) OnApprovalProcessingDuration ¶ added in v0.14.1
func (cc *ConsensusCollector) OnApprovalProcessingDuration(duration time.Duration)
OnApprovalProcessingDuration increases the number of seconds spent processing approvals
func (*ConsensusCollector) OnReceiptProcessingDuration ¶ added in v0.14.1
func (cc *ConsensusCollector) OnReceiptProcessingDuration(duration time.Duration)
OnReceiptProcessingDuration increases the number of seconds spent processing receipts
func (*ConsensusCollector) StartBlockToSeal ¶
func (cc *ConsensusCollector) StartBlockToSeal(blockID flow.Identifier)
StartBlockToSeal reports Metrics C4: Block Received by CCL → Block Seal in finalized block
func (*ConsensusCollector) StartCollectionToFinalized ¶
func (cc *ConsensusCollector) StartCollectionToFinalized(collectionID flow.Identifier)
StartCollectionToFinalized reports Metrics C1: Collection Received by CCL→ Collection Included in Finalized Block
type CruiseCtlMetrics ¶ added in v0.31.0
type CruiseCtlMetrics struct {
// contains filtered or unexported fields
}
CruiseCtlMetrics captures metrics about the Block Rate Controller, which adjusts the proposal duration to attain a target epoch switchover time.
func NewCruiseCtlMetrics ¶ added in v0.31.0
func NewCruiseCtlMetrics() *CruiseCtlMetrics
func (*CruiseCtlMetrics) ControllerOutput ¶ added in v0.31.0
func (c *CruiseCtlMetrics) ControllerOutput(duration time.Duration)
func (*CruiseCtlMetrics) PIDError ¶ added in v0.31.0
func (c *CruiseCtlMetrics) PIDError(p, i, d float64)
func (*CruiseCtlMetrics) TargetProposalDuration ¶ added in v0.31.0
func (c *CruiseCtlMetrics) TargetProposalDuration(duration time.Duration)
type EngineCollector ¶
type EngineCollector struct {
// contains filtered or unexported fields
}
func NewEngineCollector ¶
func NewEngineCollector() *EngineCollector
func (*EngineCollector) InboundMessageDropped ¶ added in v0.29.0
func (ec *EngineCollector) InboundMessageDropped(engine string, message string)
func (*EngineCollector) MessageHandled ¶
func (ec *EngineCollector) MessageHandled(engine string, message string)
func (*EngineCollector) MessageReceived ¶
func (ec *EngineCollector) MessageReceived(engine string, message string)
func (*EngineCollector) MessageSent ¶
func (ec *EngineCollector) MessageSent(engine string, message string)
func (*EngineCollector) OutboundMessageDropped ¶ added in v0.29.0
func (ec *EngineCollector) OutboundMessageDropped(engine string, message string)
type ExecutionCollector ¶
type ExecutionCollector struct {
// contains filtered or unexported fields
}
func NewExecutionCollector ¶
func NewExecutionCollector(tracer module.Tracer) *ExecutionCollector
func (*ExecutionCollector) ChunkDataPackRequestProcessed ¶ added in v0.28.0
func (ec *ExecutionCollector) ChunkDataPackRequestProcessed()
ChunkDataPackRequestProcessed is executed every time a chunk data pack request is picked up for processing at execution node. It increases the request processed counter by one.
func (*ExecutionCollector) ExecutionBlockCachedPrograms ¶ added in v0.29.17
func (ec *ExecutionCollector) ExecutionBlockCachedPrograms(programs int)
func (*ExecutionCollector) ExecutionBlockDataUploadFinished ¶ added in v0.20.6
func (ec *ExecutionCollector) ExecutionBlockDataUploadFinished(dur time.Duration)
func (*ExecutionCollector) ExecutionBlockDataUploadStarted ¶ added in v0.20.6
func (ec *ExecutionCollector) ExecutionBlockDataUploadStarted()
func (*ExecutionCollector) ExecutionBlockExecuted ¶ added in v0.18.3
func (ec *ExecutionCollector) ExecutionBlockExecuted( dur time.Duration, stats module.ExecutionResultStats, )
ExecutionBlockExecuted reports execution meta data after executing a block
func (*ExecutionCollector) ExecutionBlockExecutionEffortVectorComponent ¶ added in v0.28.2
func (ec *ExecutionCollector) ExecutionBlockExecutionEffortVectorComponent(compKind string, value uint)
func (*ExecutionCollector) ExecutionCheckpointSize ¶ added in v0.33.10
func (ec *ExecutionCollector) ExecutionCheckpointSize(bytes uint64)
ExecutionCheckpointSize reports the size of a checkpoint in bytes
func (*ExecutionCollector) ExecutionChunkDataPackGenerated ¶ added in v0.28.7
func (ec *ExecutionCollector) ExecutionChunkDataPackGenerated(proofSize, numberOfTransactions int)
ExecutionChunkDataPackGenerated reports stats on chunk data pack generation
func (*ExecutionCollector) ExecutionCollectionExecuted ¶ added in v0.18.3
func (ec *ExecutionCollector) ExecutionCollectionExecuted( dur time.Duration, stats module.ExecutionResultStats, )
ExecutionCollectionExecuted reports stats for executing a collection
func (*ExecutionCollector) ExecutionCollectionRequestRetried ¶
func (ec *ExecutionCollector) ExecutionCollectionRequestRetried()
func (*ExecutionCollector) ExecutionCollectionRequestSent ¶
func (ec *ExecutionCollector) ExecutionCollectionRequestSent()
func (*ExecutionCollector) ExecutionComputationResultUploadRetried ¶ added in v0.28.0
func (ec *ExecutionCollector) ExecutionComputationResultUploadRetried()
func (*ExecutionCollector) ExecutionComputationResultUploaded ¶ added in v0.28.0
func (ec *ExecutionCollector) ExecutionComputationResultUploaded()
func (*ExecutionCollector) ExecutionLastExecutedBlockHeight ¶
func (ec *ExecutionCollector) ExecutionLastExecutedBlockHeight(height uint64)
ExecutionLastExecutedBlockHeight reports last executed block height
func (*ExecutionCollector) ExecutionLastFinalizedExecutedBlockHeight ¶ added in v0.33.1
func (ec *ExecutionCollector) ExecutionLastFinalizedExecutedBlockHeight(height uint64)
ExecutionLastFinalizedExecutedBlockHeight reports last finalized executed block height
func (*ExecutionCollector) ExecutionScriptExecuted ¶ added in v0.18.3
func (ec *ExecutionCollector) ExecutionScriptExecuted(dur time.Duration, compUsed, memoryUsed, memoryEstimated uint64)
ScriptExecuted reports the time spent executing a single script
func (*ExecutionCollector) ExecutionStateStorageDiskTotal ¶
func (ec *ExecutionCollector) ExecutionStateStorageDiskTotal(bytes int64)
ExecutionStateStorageDiskTotal reports the total storage size of the execution state on disk in bytes
func (*ExecutionCollector) ExecutionStorageStateCommitment ¶
func (ec *ExecutionCollector) ExecutionStorageStateCommitment(bytes int64)
ExecutionStorageStateCommitment reports the storage size of a state commitment
func (*ExecutionCollector) ExecutionSync ¶
func (ec *ExecutionCollector) ExecutionSync(syncing bool)
func (*ExecutionCollector) ExecutionTransactionExecuted ¶ added in v0.18.3
func (ec *ExecutionCollector) ExecutionTransactionExecuted( dur time.Duration, numConflictRetries int, compUsed uint64, memoryUsed uint64, eventCounts int, eventSize int, failed bool, )
TransactionExecuted reports stats for executing a transaction
func (*ExecutionCollector) FinishBlockReceivedToExecuted ¶
func (ec *ExecutionCollector) FinishBlockReceivedToExecuted(blockID flow.Identifier)
FinishBlockReceivedToExecuted finishes a span to trace the duration of a block from being received for execution to execution being finished
func (*ExecutionCollector) ForestApproxMemorySize ¶
func (ec *ExecutionCollector) ForestApproxMemorySize(bytes uint64)
ForestApproxMemorySize records approximate memory usage of forest (all in-memory trees)
func (*ExecutionCollector) ForestNumberOfTrees ¶
func (ec *ExecutionCollector) ForestNumberOfTrees(number uint64)
ForestNumberOfTrees current number of trees in a forest (in memory)
func (*ExecutionCollector) LatestTrieMaxDepthTouched ¶ added in v0.25.2
func (ec *ExecutionCollector) LatestTrieMaxDepthTouched(maxDepth uint16)
LatestTrieMaxDepthTouched records the maximum depth touched of the last created trie
func (*ExecutionCollector) LatestTrieRegCount ¶
func (ec *ExecutionCollector) LatestTrieRegCount(number uint64)
LatestTrieRegCount records the number of unique register allocated (the lastest created trie)
func (*ExecutionCollector) LatestTrieRegCountDiff ¶
func (ec *ExecutionCollector) LatestTrieRegCountDiff(number int64)
LatestTrieRegCountDiff records the difference between the number of unique register allocated of the latest created trie and parent trie
func (*ExecutionCollector) LatestTrieRegSize ¶ added in v0.25.2
func (ec *ExecutionCollector) LatestTrieRegSize(size uint64)
LatestTrieRegSize records the size of unique register allocated (the lastest created trie)
func (*ExecutionCollector) LatestTrieRegSizeDiff ¶ added in v0.25.2
func (ec *ExecutionCollector) LatestTrieRegSizeDiff(size int64)
LatestTrieRegSizeDiff records the difference between the size of unique register allocated of the latest created trie and parent trie
func (*ExecutionCollector) ProofSize ¶
func (ec *ExecutionCollector) ProofSize(bytes uint32)
ProofSize records a proof size
func (*ExecutionCollector) ReadDuration ¶
func (ec *ExecutionCollector) ReadDuration(duration time.Duration)
ReadDuration records absolute time for the read from a trie
func (*ExecutionCollector) ReadDurationPerItem ¶
func (ec *ExecutionCollector) ReadDurationPerItem(duration time.Duration)
ReadDurationPerItem records read time for single value (total duration / number of read values)
func (*ExecutionCollector) ReadValuesNumber ¶
func (ec *ExecutionCollector) ReadValuesNumber(number uint64)
ReadValuesNumber accumulates number of read values
func (*ExecutionCollector) ReadValuesSize ¶
func (ec *ExecutionCollector) ReadValuesSize(bytes uint64)
ReadValuesSize total size (in bytes) of read values
func (*ExecutionCollector) RuntimeSetNumberOfAccounts ¶ added in v0.18.3
func (ec *ExecutionCollector) RuntimeSetNumberOfAccounts(count uint64)
func (*ExecutionCollector) RuntimeTransactionChecked ¶ added in v0.18.3
func (ec *ExecutionCollector) RuntimeTransactionChecked(dur time.Duration)
TransactionChecked reports the time spent checking a single transaction
func (*ExecutionCollector) RuntimeTransactionInterpreted ¶ added in v0.18.3
func (ec *ExecutionCollector) RuntimeTransactionInterpreted(dur time.Duration)
TransactionInterpreted reports the time spent interpreting a single transaction
func (*ExecutionCollector) RuntimeTransactionParsed ¶ added in v0.18.3
func (ec *ExecutionCollector) RuntimeTransactionParsed(dur time.Duration)
TransactionParsed reports the time spent parsing a single transaction
func (*ExecutionCollector) RuntimeTransactionProgramsCacheHit ¶ added in v0.29.17
func (ec *ExecutionCollector) RuntimeTransactionProgramsCacheHit()
func (*ExecutionCollector) RuntimeTransactionProgramsCacheMiss ¶ added in v0.29.17
func (ec *ExecutionCollector) RuntimeTransactionProgramsCacheMiss()
func (*ExecutionCollector) StartBlockReceivedToExecuted ¶
func (ec *ExecutionCollector) StartBlockReceivedToExecuted(blockID flow.Identifier)
StartBlockReceivedToExecuted starts a span to trace the duration of a block from being received for execution to execution being finished
func (*ExecutionCollector) UpdateCollectionMaxHeight ¶ added in v0.27.0
func (ec *ExecutionCollector) UpdateCollectionMaxHeight(height uint64)
func (*ExecutionCollector) UpdateCount ¶
func (ec *ExecutionCollector) UpdateCount()
UpdateCount increase a counter of performed updates
func (*ExecutionCollector) UpdateDuration ¶
func (ec *ExecutionCollector) UpdateDuration(duration time.Duration)
UpdateDuration records absolute time for the update of a trie
func (*ExecutionCollector) UpdateDurationPerItem ¶
func (ec *ExecutionCollector) UpdateDurationPerItem(duration time.Duration)
UpdateDurationPerItem records update time for single value (total duration / number of updated values)
func (*ExecutionCollector) UpdateValuesNumber ¶
func (ec *ExecutionCollector) UpdateValuesNumber(number uint64)
UpdateValuesNumber accumulates number of updated values
func (*ExecutionCollector) UpdateValuesSize ¶
func (ec *ExecutionCollector) UpdateValuesSize(bytes uint64)
UpdateValuesSize total size (in bytes) of updates values
type ExecutionDataProviderCollector ¶ added in v0.27.2
type ExecutionDataProviderCollector struct {
// contains filtered or unexported fields
}
func NewExecutionDataProviderCollector ¶ added in v0.27.2
func NewExecutionDataProviderCollector() *ExecutionDataProviderCollector
func (*ExecutionDataProviderCollector) AddBlobsFailed ¶ added in v0.27.2
func (c *ExecutionDataProviderCollector) AddBlobsFailed()
func (*ExecutionDataProviderCollector) AddBlobsSucceeded ¶ added in v0.27.2
func (c *ExecutionDataProviderCollector) AddBlobsSucceeded(duration time.Duration, totalSize uint64)
func (*ExecutionDataProviderCollector) RootIDComputed ¶ added in v0.27.2
func (c *ExecutionDataProviderCollector) RootIDComputed(duration time.Duration, numberOfChunks int)
type ExecutionDataPrunerCollector ¶ added in v0.27.2
type ExecutionDataPrunerCollector struct {
// contains filtered or unexported fields
}
func NewExecutionDataPrunerCollector ¶ added in v0.27.2
func NewExecutionDataPrunerCollector() *ExecutionDataPrunerCollector
type ExecutionDataRequesterCollector ¶ added in v0.26.2
type ExecutionDataRequesterCollector struct {
// contains filtered or unexported fields
}
func (*ExecutionDataRequesterCollector) ExecutionDataFetchFinished ¶ added in v0.26.2
func (ec *ExecutionDataRequesterCollector) ExecutionDataFetchFinished(duration time.Duration, success bool, height uint64)
func (*ExecutionDataRequesterCollector) ExecutionDataFetchStarted ¶ added in v0.26.2
func (ec *ExecutionDataRequesterCollector) ExecutionDataFetchStarted()
func (*ExecutionDataRequesterCollector) FetchRetried ¶ added in v0.26.2
func (ec *ExecutionDataRequesterCollector) FetchRetried()
func (*ExecutionDataRequesterCollector) NotificationSent ¶ added in v0.26.2
func (ec *ExecutionDataRequesterCollector) NotificationSent(height uint64)
type ExecutionDataRequesterV2Collector ¶ added in v0.27.2
type ExecutionDataRequesterV2Collector struct {
// contains filtered or unexported fields
}
func NewExecutionDataRequesterV2Collector ¶ added in v0.27.2
func NewExecutionDataRequesterV2Collector() *ExecutionDataRequesterV2Collector
func (*ExecutionDataRequesterV2Collector) FulfilledHeight ¶ added in v0.27.2
func (c *ExecutionDataRequesterV2Collector) FulfilledHeight(blockHeight uint64)
func (*ExecutionDataRequesterV2Collector) ReceiptSkipped ¶ added in v0.27.2
func (c *ExecutionDataRequesterV2Collector) ReceiptSkipped()
func (*ExecutionDataRequesterV2Collector) RequestCanceled ¶ added in v0.27.2
func (c *ExecutionDataRequesterV2Collector) RequestCanceled()
func (*ExecutionDataRequesterV2Collector) RequestFailed ¶ added in v0.27.2
func (c *ExecutionDataRequesterV2Collector) RequestFailed(duration time.Duration, retryable bool)
func (*ExecutionDataRequesterV2Collector) RequestSucceeded ¶ added in v0.27.2
func (*ExecutionDataRequesterV2Collector) ResponseDropped ¶ added in v0.27.2
func (c *ExecutionDataRequesterV2Collector) ResponseDropped()
type ExecutionStateIndexerCollector ¶ added in v0.32.1
type ExecutionStateIndexerCollector struct {
// contains filtered or unexported fields
}
func (*ExecutionStateIndexerCollector) BlockIndexed ¶ added in v0.32.1
func (c *ExecutionStateIndexerCollector) BlockIndexed(height uint64, duration time.Duration, events, registers, transactionResults int)
BlockIndexed records metrics from indexing execution data from a single block.
func (*ExecutionStateIndexerCollector) BlockReindexed ¶ added in v0.32.1
func (c *ExecutionStateIndexerCollector) BlockReindexed()
BlockReindexed records that a previously indexed block was indexed again.
func (*ExecutionStateIndexerCollector) InitializeLatestHeight ¶ added in v0.32.2
func (c *ExecutionStateIndexerCollector) InitializeLatestHeight(height uint64)
InitializeLatestHeight records the latest height that has been indexed. This should only be used during startup. After startup, use BlockIndexed to record newly indexed heights.
type GossipSubRpcValidationInspectorMetrics ¶ added in v0.31.0
type GossipSubRpcValidationInspectorMetrics struct {
// contains filtered or unexported fields
}
GossipSubRpcValidationInspectorMetrics metrics collector for the gossipsub RPC validation inspector.
func NewGossipSubRPCValidationInspectorMetrics ¶ added in v0.31.0
func NewGossipSubRPCValidationInspectorMetrics(prefix string) *GossipSubRpcValidationInspectorMetrics
NewGossipSubRPCValidationInspectorMetrics returns a new *GossipSubRpcValidationInspectorMetrics.
func (*GossipSubRpcValidationInspectorMetrics) AsyncProcessingFinished ¶ added in v0.31.0
func (c *GossipSubRpcValidationInspectorMetrics) AsyncProcessingFinished(duration time.Duration)
AsyncProcessingFinished tracks the time spent by the rpc validation inspector to process an RPC asynchronously and decrements the metric tracking the number of RPC's being processed asynchronously by the rpc validation inspector.
func (*GossipSubRpcValidationInspectorMetrics) AsyncProcessingStarted ¶ added in v0.31.0
func (c *GossipSubRpcValidationInspectorMetrics) AsyncProcessingStarted()
AsyncProcessingStarted increments the metric tracking the number of RPC's being processed asynchronously by the rpc validation inspector.
func (*GossipSubRpcValidationInspectorMetrics) OnActiveClusterIDsNotSetErr ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnActiveClusterIDsNotSetErr()
OnActiveClusterIDsNotSetErr tracks the number of times that the async inspection of a control message type on a single RPC failed due to active cluster ids not set inspection failure. This is not causing a misbehaviour report.
func (*GossipSubRpcValidationInspectorMetrics) OnControlMessagesTruncated ¶ added in v0.33.1
func (c *GossipSubRpcValidationInspectorMetrics) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
OnControlMessageIDsTruncated tracks the number of times a control message was truncated. Args:
messageType: the type of the control message that was truncated diff: the number of message ids truncated.
func (*GossipSubRpcValidationInspectorMetrics) OnGraftDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnGraftDuplicateTopicIdsExceedThreshold()
OnGraftDuplicateTopicIdsExceedThreshold tracks the number of times that the async inspection of a graft message failed due to the number of duplicate topic ids. received by the node on graft messages of the same rpc excesses threshold, which results in a misbehaviour report.
func (*GossipSubRpcValidationInspectorMetrics) OnGraftMessageInspected ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnGraftMessageInspected(duplicateTopicIds int)
OnGraftMessageInspected is called at the end of the async inspection of graft messages of a single RPC, regardless of the result of the inspection. Args:
duplicateTopicIds: the number of duplicate topic ids received by the node on the graft messages at the end of the async inspection of a single RPC.
func (*GossipSubRpcValidationInspectorMetrics) OnIHaveControlMessageIdsTruncated ¶ added in v0.33.1
func (c *GossipSubRpcValidationInspectorMetrics) OnIHaveControlMessageIdsTruncated(diff int)
OnIHaveControlMessageIdsTruncated tracks the number of times message ids on an iHave message were truncated. Note that this function is called only when the message ids are truncated from an iHave message, not when the iHave message itself is truncated. This is different from the OnControlMessagesTruncated function which is called when a slice of control messages truncated from an RPC with all their message ids. Args:
diff: the number of actual messages truncated.
func (*GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateMessageIdsExceedThreshold()
OnIHaveDuplicateMessageIdsExceedThreshold tracks the number of times that the async inspection of iHave messages of a single RPC failed due to the total number of duplicate message ids received by the node on an iHave message exceeding the threshold, which results in a misbehaviour report.
func (*GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateTopicIdsExceedThreshold()
OnIHaveDuplicateTopicIdsExceedThreshold tracks the number of times that the async inspection of iHave messages of a single RPC failed due to the total number of duplicate topic ids received by the node on the iHave messages of that RPC exceeding the threshold, which results in a misbehaviour report.
func (*GossipSubRpcValidationInspectorMetrics) OnIHaveMessageIDsReceived ¶ added in v0.33.1
func (c *GossipSubRpcValidationInspectorMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
OnIHaveMessageIDsReceived tracks the number of message ids received by the node from other nodes on an iHave message. This function is called on each iHave message received by the node. Args: - channel: the channel on which the iHave message was received. - msgIdCount: the number of message ids received on the iHave message.
func (*GossipSubRpcValidationInspectorMetrics) OnIHaveMessagesInspected ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int)
OnIHaveMessagesInspected is called at the end of the async inspection of iHave messages of a single RPC, regardless of the result of the inspection. It tracks the number of duplicate topic ids and duplicate message ids received by the node on the iHave messages of that single RPC at the end of the async inspection iHaves. Args:
duplicateTopicIds: the total number of duplicate topic ids received by the node on the iHave messages at the end of the async inspection of the RPC. duplicateMessageIds: the number of duplicate message ids received by the node on the iHave messages at the end of the async inspection of the RPC.
func (*GossipSubRpcValidationInspectorMetrics) OnIWantCacheMissMessageIdsExceedThreshold ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnIWantCacheMissMessageIdsExceedThreshold()
OnIWantCacheMissMessageIdsExceedThreshold tracks the number of times that async inspection of iWant messages failed due to the total number of cache miss message ids received by the node on the iWant messages of a single RPC exceeding the threshold, which results in a misbehaviour report.
func (*GossipSubRpcValidationInspectorMetrics) OnIWantControlMessageIdsTruncated ¶ added in v0.33.1
func (c *GossipSubRpcValidationInspectorMetrics) OnIWantControlMessageIdsTruncated(diff int)
OnIWantControlMessageIdsTruncated tracks the number of times message ids on an iWant message were truncated. Note that this function is called only when the message ids are truncated from an iWant message, not when the iWant message itself is truncated. This is different from the OnControlMessagesTruncated function which is called when a slice of control messages truncated from an RPC with all their message ids. Args:
diff: the number of actual messages truncated.
func (*GossipSubRpcValidationInspectorMetrics) OnIWantDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnIWantDuplicateMessageIdsExceedThreshold()
OnIWantDuplicateMessageIdsExceedThreshold tracks the number of times that async inspection of iWant messages failed due to the total number of duplicate message ids received by the node on the iWant messages of a single RPC exceeding the threshold, which results in a misbehaviour report.
func (*GossipSubRpcValidationInspectorMetrics) OnIWantMessageIDsReceived ¶ added in v0.33.1
func (c *GossipSubRpcValidationInspectorMetrics) OnIWantMessageIDsReceived(msgIdCount int)
OnIWantMessageIDsReceived tracks the number of message ids received by the node from other nodes on an RPC. Note: this function is called on each IWANT message received by the node. Args: - msgIdCount: the number of message ids received on the IWANT message.
func (*GossipSubRpcValidationInspectorMetrics) OnIWantMessagesInspected ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
OnIWantMessagesInspected tracks the number of duplicate and cache miss message ids received by the node on iWant messages at the end of the async inspection iWants across one RPC, regardless of the result of the inspection.
duplicateCount: the total number of duplicate message ids received by the node on the iWant messages at the end of the async inspection of the RPC. cacheMissCount: the total number of cache miss message ids received by the node on the iWant message at the end of the async inspection of the RPC.
func (*GossipSubRpcValidationInspectorMetrics) OnIncomingRpcReceived ¶ added in v0.33.1
func (c *GossipSubRpcValidationInspectorMetrics) OnIncomingRpcReceived(iHaveCount, iWantCount, graftCount, pruneCount, msgCount int)
OnIncomingRpcReceived tracks the number of incoming RPC messages received by the node.
func (*GossipSubRpcValidationInspectorMetrics) OnInvalidControlMessageNotificationSent ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnInvalidControlMessageNotificationSent()
OnInvalidControlMessageNotificationSent tracks the number of times that the async inspection of a control message failed and resulted in dissemination of an invalid control message was sent (i.e., a misbehavior report).
func (*GossipSubRpcValidationInspectorMetrics) OnInvalidTopicIdDetectedForControlMessage ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
OnInvalidTopicIdDetectedForControlMessage tracks the number of times that the async inspection of a control message type on a single RPC failed due to an invalid topic id. Args: - messageType: the type of the control message that was truncated.
func (*GossipSubRpcValidationInspectorMetrics) OnPruneDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnPruneDuplicateTopicIdsExceedThreshold()
OnPruneDuplicateTopicIdsExceedThreshold tracks the number of times that the async inspection of prune messages for an RPC failed due to the number of duplicate topic ids received by the node on prune messages of the same RPC excesses threshold, which results in a misbehaviour report.
func (*GossipSubRpcValidationInspectorMetrics) OnPruneMessageInspected ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnPruneMessageInspected(duplicateTopicIds int)
OnPruneMessageInspected is called at the end of the async inspection of prune messages of the RPC, regardless of the result of the inspection. Args:
duplicateTopicIds: the number of duplicate topic ids received by the node on the prune messages of the RPC at the end of the async inspection prunes.
func (*GossipSubRpcValidationInspectorMetrics) OnPublishMessageInspected ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, invalidSendersCount int)
OnPublishMessageInspected is called at the end of the async inspection of publish messages of a single RPC, regardless of the result of the inspection. It tracks the total number of errors detected during the async inspection of the rpc together with their individual breakdown. Args: - errCount: the number of errors that occurred during the async inspection of publish messages. - invalidTopicIdsCount: the number of times that an invalid topic id was detected during the async inspection of publish messages. - invalidSubscriptionsCount: the number of times that an invalid subscription was detected during the async inspection of publish messages. - invalidSendersCount: the number of times that an invalid sender was detected during the async inspection of publish messages.
func (*GossipSubRpcValidationInspectorMetrics) OnPublishMessagesInspectionErrorExceedsThreshold ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnPublishMessagesInspectionErrorExceedsThreshold()
OnPublishMessagesInspectionErrorExceedsThreshold tracks the number of times that async inspection of publish messages failed due to the number of errors exceeding the threshold. Note that it causes a misbehaviour report.
func (*GossipSubRpcValidationInspectorMetrics) OnUnstakedPeerInspectionFailed ¶ added in v0.33.7
func (c *GossipSubRpcValidationInspectorMetrics) OnUnstakedPeerInspectionFailed()
OnUnstakedPeerInspectionFailed tracks the number of times that the async inspection of a control message type on a single RPC failed due to unstaked peer inspection failure. This is not causing a misbehaviour report.
type GossipSubScoreMetrics ¶ added in v0.30.0
type GossipSubScoreMetrics struct {
// contains filtered or unexported fields
}
func NewGossipSubScoreMetrics ¶ added in v0.30.0
func NewGossipSubScoreMetrics(prefix string) *GossipSubScoreMetrics
func (*GossipSubScoreMetrics) OnAppSpecificScoreUpdated ¶ added in v0.30.0
func (g *GossipSubScoreMetrics) OnAppSpecificScoreUpdated(score float64)
func (*GossipSubScoreMetrics) OnBehaviourPenaltyUpdated ¶ added in v0.30.0
func (g *GossipSubScoreMetrics) OnBehaviourPenaltyUpdated(penalty float64)
func (*GossipSubScoreMetrics) OnFirstMessageDeliveredUpdated ¶ added in v0.30.0
func (g *GossipSubScoreMetrics) OnFirstMessageDeliveredUpdated(topic channels.Topic, f float64)
func (*GossipSubScoreMetrics) OnIPColocationFactorUpdated ¶ added in v0.30.0
func (g *GossipSubScoreMetrics) OnIPColocationFactorUpdated(factor float64)
func (*GossipSubScoreMetrics) OnInvalidMessageDeliveredUpdated ¶ added in v0.30.0
func (g *GossipSubScoreMetrics) OnInvalidMessageDeliveredUpdated(topic channels.Topic, f float64)
func (*GossipSubScoreMetrics) OnMeshMessageDeliveredUpdated ¶ added in v0.30.0
func (g *GossipSubScoreMetrics) OnMeshMessageDeliveredUpdated(topic channels.Topic, f float64)
func (*GossipSubScoreMetrics) OnOverallPeerScoreUpdated ¶ added in v0.30.0
func (g *GossipSubScoreMetrics) OnOverallPeerScoreUpdated(score float64)
func (*GossipSubScoreMetrics) OnTimeInMeshUpdated ¶ added in v0.30.0
func (g *GossipSubScoreMetrics) OnTimeInMeshUpdated(topic channels.Topic, duration time.Duration)
func (*GossipSubScoreMetrics) SetWarningStateCount ¶ added in v0.30.0
func (g *GossipSubScoreMetrics) SetWarningStateCount(u uint)
type HeroCacheCollector ¶ added in v0.25.2
type HeroCacheCollector struct {
// contains filtered or unexported fields
}
func AccessNodeExecutionDataCacheMetrics ¶ added in v0.30.2
func AccessNodeExecutionDataCacheMetrics(registrar prometheus.Registerer) *HeroCacheCollector
func ChunkDataPackRequestQueueMetricsFactory ¶ added in v0.28.0
func ChunkDataPackRequestQueueMetricsFactory(registrar prometheus.Registerer) *HeroCacheCollector
func CollectionNodeTransactionsCacheMetrics ¶ added in v0.25.2
func CollectionNodeTransactionsCacheMetrics(registrar prometheus.Registerer, epoch uint64) *HeroCacheCollector
func CollectionRequestsQueueMetricFactory ¶ added in v0.29.0
func CollectionRequestsQueueMetricFactory(registrar prometheus.Registerer) *HeroCacheCollector
func DisallowListNotificationQueueMetricFactory ¶ added in v0.30.0
func DisallowListNotificationQueueMetricFactory(registrar prometheus.Registerer) *HeroCacheCollector
func FollowerCacheMetrics ¶ added in v0.30.0
func FollowerCacheMetrics(registrar prometheus.Registerer) *HeroCacheCollector
func NetworkDnsIpCacheMetricsFactory ¶ added in v0.25.2
func NetworkDnsIpCacheMetricsFactory(registrar prometheus.Registerer) *HeroCacheCollector
func NetworkDnsTxtCacheMetricsFactory ¶ added in v0.25.2
func NetworkDnsTxtCacheMetricsFactory(registrar prometheus.Registerer) *HeroCacheCollector
func NewHeroCacheCollector ¶ added in v0.25.2
func NewHeroCacheCollector(nameSpace string, cacheName string, registrar prometheus.Registerer) *HeroCacheCollector
func ReceiptRequestsQueueMetricFactory ¶ added in v0.29.0
func ReceiptRequestsQueueMetricFactory(registrar prometheus.Registerer) *HeroCacheCollector
func (*HeroCacheCollector) BucketAvailableSlots ¶ added in v0.25.2
func (h *HeroCacheCollector) BucketAvailableSlots(availableSlots uint64, totalSlots uint64)
BucketAvailableSlots keeps track of number of available slots in buckets of cache.
func (*HeroCacheCollector) OnEntityEjectionDueToEmergency ¶ added in v0.25.2
func (h *HeroCacheCollector) OnEntityEjectionDueToEmergency()
OnEntityEjectionDueToEmergency is called whenever a bucket is found full and all of its keys are valid, i.e., each key belongs to an existing (key, entity) pair. Hence, adding a new key to that bucket will replace the oldest valid key inside that bucket. Note: in context of HeroCache, the key corresponds to the identifier of its entity.
func (*HeroCacheCollector) OnEntityEjectionDueToFullCapacity ¶ added in v0.25.2
func (h *HeroCacheCollector) OnEntityEjectionDueToFullCapacity()
OnEntityEjectionDueToFullCapacity is called whenever adding a new (key, entity) to the cache results in ejection of another (key', entity') pair. This normally happens -- and is expected -- when the cache is full. Note: in context of HeroCache, the key corresponds to the identifier of its entity.
func (*HeroCacheCollector) OnKeyGetFailure ¶ added in v0.25.2
func (h *HeroCacheCollector) OnKeyGetFailure()
OnKeyGetFailure tracks total number of unsuccessful read queries. A read query is unsuccessful if the entity corresponding to its key is not available in the cache. Note: in context of HeroCache, the key corresponds to the identifier of its entity.
func (*HeroCacheCollector) OnKeyGetSuccess ¶ added in v0.25.2
func (h *HeroCacheCollector) OnKeyGetSuccess()
OnKeyGetSuccess tracks total number of successful read queries. A read query is successful if the entity corresponding to its key is available in the cache. Note: in context of HeroCache, the key corresponds to the identifier of its entity.
func (*HeroCacheCollector) OnKeyPutAttempt ¶ added in v0.29.0
func (h *HeroCacheCollector) OnKeyPutAttempt(size uint32)
OnKeyPutAttempt is called whenever a new (key, value) pair is attempted to be put in cache. It does not reflect whether the put was successful or not. A (key, value) pair put attempt may fail if the cache is full, or the key already exists. size parameter is the current size of the cache prior to the put attempt.
func (*HeroCacheCollector) OnKeyPutDeduplicated ¶ added in v0.29.0
func (h *HeroCacheCollector) OnKeyPutDeduplicated()
OnKeyPutDeduplicated is tracking the total number of unsuccessful writes caused by adding a duplicate key to the cache. A duplicate key is dropped by the cache when it is written to the cache. Note: in context of HeroCache, the key corresponds to the identifier of its entity. Hence, a duplicate key corresponds to a duplicate entity.
func (*HeroCacheCollector) OnKeyPutDrop ¶ added in v0.29.0
func (h *HeroCacheCollector) OnKeyPutDrop()
OnKeyPutDrop is called whenever a new (key, entity) pair is dropped from the cache due to full cache.
func (*HeroCacheCollector) OnKeyPutSuccess ¶ added in v0.25.2
func (h *HeroCacheCollector) OnKeyPutSuccess(size uint32)
OnKeyPutSuccess is called whenever a new (key, entity) pair is successfully added to the cache. size parameter is the current size of the cache post insertion.
func (*HeroCacheCollector) OnKeyRemoved ¶ added in v0.29.0
func (h *HeroCacheCollector) OnKeyRemoved(size uint32)
OnKeyRemoved is called whenever a (key, entity) pair is removed from the cache. size parameter is the current size of the cache.
type HeroCacheMetricsFactory ¶ added in v0.31.0
type HeroCacheMetricsFactory func(namespace string, cacheName string) module.HeroCacheMetrics
HeroCacheMetricsFactory is a factory method to create a new HeroCacheCollector for a specific cache with a specific namespace and a specific name. Args: - namespace: the namespace of the cache - cacheName: the name of the cache
func NewHeroCacheMetricsFactory ¶ added in v0.31.0
func NewHeroCacheMetricsFactory(registrar prometheus.Registerer) HeroCacheMetricsFactory
NewHeroCacheMetricsFactory creates a new HeroCacheMetricsFactory for the given registrar. It allows to defer the registration of the metrics to the point where the cache is created without exposing the registrar to the cache. Args: - registrar: the prometheus registrar to register the metrics with Returns: - a HeroCacheMetricsFactory that can be used to create a new HeroCacheCollector for a specific cache
func NewNoopHeroCacheMetricsFactory ¶ added in v0.31.0
func NewNoopHeroCacheMetricsFactory() HeroCacheMetricsFactory
NewNoopHeroCacheMetricsFactory creates a new HeroCacheMetricsFactory that returns a noop collector. This is useful for tests that don't want to register metrics. Args: - none Returns: - a HeroCacheMetricsFactory that returns a noop collector
type HeroCacheMetricsRegistrationFunc ¶ added in v0.25.2
type HeroCacheMetricsRegistrationFunc func(uint64) module.HeroCacheMetrics
type HotstuffCollector ¶
type HotstuffCollector struct {
// contains filtered or unexported fields
}
HotstuffCollector implements only the metrics emitted by the HotStuff core logic. We have multiple instances of HotStuff running within Flow: Consensus Nodes form the main consensus committee. In addition each Collector node cluster runs their own HotStuff instance. Depending on the node role, the name space is different. Furthermore, even within the `collection` name space, we need to separate metrics between the different clusters. We do this by adding the label `committeeID` to the HotStuff metrics and allowing for configurable name space.
func NewHotstuffCollector ¶
func NewHotstuffCollector(chain flow.ChainID) *HotstuffCollector
func (*HotstuffCollector) BlockProcessingDuration ¶ added in v0.29.0
func (hc *HotstuffCollector) BlockProcessingDuration(duration time.Duration)
BlockProcessingDuration measures the time which the compliance engine spends to process one block proposal.
func (*HotstuffCollector) CommitteeProcessingDuration ¶
func (hc *HotstuffCollector) CommitteeProcessingDuration(duration time.Duration)
CommitteeProcessingDuration measures the time which the HotStuff's core logic spends in the hotstuff.Committee component, i.e. the time determining consensus committee relations.
func (*HotstuffCollector) CountSkipped ¶
func (hc *HotstuffCollector) CountSkipped()
CountSkipped counts the number of skips we did.
func (*HotstuffCollector) CountTimeout ¶
func (hc *HotstuffCollector) CountTimeout()
CountTimeout tracks the number of views that this replica left due to observing a TC.
func (*HotstuffCollector) HotStuffBusyDuration ¶
func (hc *HotstuffCollector) HotStuffBusyDuration(duration time.Duration, event string)
HotStuffBusyDuration reports Metrics C6 HotStuff Busy Duration
func (*HotstuffCollector) HotStuffIdleDuration ¶
func (hc *HotstuffCollector) HotStuffIdleDuration(duration time.Duration)
HotStuffIdleDuration reports Metrics C6 HotStuff Idle Duration
func (*HotstuffCollector) HotStuffWaitDuration ¶
func (hc *HotstuffCollector) HotStuffWaitDuration(duration time.Duration, event string)
HotStuffWaitDuration reports Metrics C6 HotStuff Idle Duration - the time between receiving and enqueueing a message to beginning to process that message.
func (*HotstuffCollector) PayloadProductionDuration ¶
func (hc *HotstuffCollector) PayloadProductionDuration(duration time.Duration)
PayloadProductionDuration reports the time which the HotStuff's core logic spends in the module.Builder component, i.e. the with generating block payloads
func (*HotstuffCollector) SetCurView ¶
func (hc *HotstuffCollector) SetCurView(view uint64)
SetCurView reports Metrics C8: Current View
func (*HotstuffCollector) SetQCView ¶
func (hc *HotstuffCollector) SetQCView(view uint64)
SetQCView reports Metrics C9: View of Newest Known QC
func (*HotstuffCollector) SetTCView ¶ added in v0.29.0
func (hc *HotstuffCollector) SetTCView(view uint64)
SetTCView reports the view of the newest known TC
func (*HotstuffCollector) SetTimeout ¶
func (hc *HotstuffCollector) SetTimeout(duration time.Duration)
SetTimeout sets the current timeout duration.
func (*HotstuffCollector) SignerProcessingDuration ¶
func (hc *HotstuffCollector) SignerProcessingDuration(duration time.Duration)
SignerProcessingDuration reports the time which the HotStuff's core logic spends in the hotstuff.Signer component, i.e. the with crypto-related operations.
func (*HotstuffCollector) TimeoutCollectorsRange ¶ added in v0.32.0
func (hc *HotstuffCollector) TimeoutCollectorsRange(lowestRetainedView uint64, newestViewCreatedCollector uint64, activeCollectors int)
TimeoutCollectorsRange collects information from the node's `TimeoutAggregator` component. Specifically, it measurers the number of views for which we are currently collecting timeouts (i.e. the number of `TimeoutCollector` instances we are maintaining) and their lowest/highest view.
func (*HotstuffCollector) TimeoutObjectProcessingDuration ¶ added in v0.29.0
func (hc *HotstuffCollector) TimeoutObjectProcessingDuration(duration time.Duration)
TimeoutObjectProcessingDuration reports the processing time for a TimeoutObject
func (*HotstuffCollector) ValidatorProcessingDuration ¶
func (hc *HotstuffCollector) ValidatorProcessingDuration(duration time.Duration)
ValidatorProcessingDuration reports the time which the HotStuff's core logic spends in the hotstuff.Validator component, i.e. the with verifying higher-level consensus messages.
func (*HotstuffCollector) VoteProcessingDuration ¶ added in v0.29.0
func (hc *HotstuffCollector) VoteProcessingDuration(duration time.Duration)
VoteProcessingDuration reports the processing time for a single vote
type LibP2PResourceManagerMetrics ¶ added in v0.29.0
type LibP2PResourceManagerMetrics struct {
// contains filtered or unexported fields
}
func NewLibP2PResourceManagerMetrics ¶ added in v0.29.0
func NewLibP2PResourceManagerMetrics(logger zerolog.Logger, prefix string) *LibP2PResourceManagerMetrics
func (*LibP2PResourceManagerMetrics) AllowConn ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) AllowConn(dir network.Direction, usefd bool)
func (*LibP2PResourceManagerMetrics) AllowMemory ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) AllowMemory(size int)
func (*LibP2PResourceManagerMetrics) AllowPeer ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) AllowPeer(p peer.ID)
func (*LibP2PResourceManagerMetrics) AllowProtocol ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) AllowProtocol(proto protocol.ID)
func (*LibP2PResourceManagerMetrics) AllowService ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) AllowService(svc string)
func (*LibP2PResourceManagerMetrics) AllowStream ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) AllowStream(p peer.ID, dir network.Direction)
func (*LibP2PResourceManagerMetrics) BlockConn ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) BlockConn(dir network.Direction, usefd bool)
func (*LibP2PResourceManagerMetrics) BlockMemory ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) BlockMemory(size int)
func (*LibP2PResourceManagerMetrics) BlockPeer ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) BlockPeer(p peer.ID)
func (*LibP2PResourceManagerMetrics) BlockProtocol ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) BlockProtocol(proto protocol.ID)
func (*LibP2PResourceManagerMetrics) BlockProtocolPeer ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) BlockProtocolPeer(proto protocol.ID, p peer.ID)
func (*LibP2PResourceManagerMetrics) BlockService ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) BlockService(svc string)
func (*LibP2PResourceManagerMetrics) BlockServicePeer ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) BlockServicePeer(svc string, p peer.ID)
func (*LibP2PResourceManagerMetrics) BlockStream ¶ added in v0.29.0
func (l *LibP2PResourceManagerMetrics) BlockStream(p peer.ID, dir network.Direction)
type LoaderCollector ¶
type LoaderCollector struct {
// contains filtered or unexported fields
}
func NewLoaderCollector ¶
func NewLoaderCollector() *LoaderCollector
func (*LoaderCollector) SetTPSConfigured ¶
func (cc *LoaderCollector) SetTPSConfigured(tps uint)
func (*LoaderCollector) TransactionExecuted ¶ added in v0.27.0
func (cc *LoaderCollector) TransactionExecuted(duration time.Duration)
func (*LoaderCollector) TransactionLost ¶ added in v0.29.0
func (cc *LoaderCollector) TransactionLost()
func (*LoaderCollector) TransactionSent ¶
func (cc *LoaderCollector) TransactionSent()
type LocalGossipSubRouterMetrics ¶ added in v0.33.1
type LocalGossipSubRouterMetrics struct {
// contains filtered or unexported fields
}
LocalGossipSubRouterMetrics encapsulates the metrics collectors for GossipSub router of the local node. It gives a lens into the local node's view of the GossipSub protocol.
func NewGossipSubLocalMeshMetrics ¶ added in v0.30.0
func NewGossipSubLocalMeshMetrics(prefix string) *LocalGossipSubRouterMetrics
func (*LocalGossipSubRouterMetrics) OnLocalMeshSizeUpdated ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnLocalMeshSizeUpdated(topic string, size int)
OnLocalMeshSizeUpdated updates the local mesh size metric.
func (*LocalGossipSubRouterMetrics) OnLocalPeerJoinedTopic ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnLocalPeerJoinedTopic()
OnLocalPeerJoinedTopic is called when the local node subscribes to a gossipsub topic. Args:
topic: the topic that the local peer subscribed to.
func (*LocalGossipSubRouterMetrics) OnLocalPeerLeftTopic ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnLocalPeerLeftTopic()
OnLocalPeerLeftTopic is called when the local node unsubscribes from a gossipsub topic. Args:
topic: the topic that the local peer has unsubscribed from.
func (*LocalGossipSubRouterMetrics) OnMessageDeliveredToAllSubscribers ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnMessageDeliveredToAllSubscribers(size int)
OnMessageDeliveredToAllSubscribers is called when a message is delivered to all subscribers of the topic. Args:
size: the size of the delivered message.
func (*LocalGossipSubRouterMetrics) OnMessageDuplicate ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnMessageDuplicate(size int)
OnMessageDuplicate is called when a received pubsub message is a duplicate of a previously received message, and is dropped. Args:
size: the size of the duplicate message.
func (*LocalGossipSubRouterMetrics) OnMessageEnteredValidation ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnMessageEnteredValidation(int)
OnMessageEnteredValidation is called when a received pubsub message enters the validation pipeline. It is the internal validation pipeline of GossipSub protocol. The message may be rejected or accepted by the validation pipeline.
func (*LocalGossipSubRouterMetrics) OnMessageRejected ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnMessageRejected(size int, reason string)
OnMessageRejected is called when a received pubsub message is rejected by the validation pipeline. Args:
reason: the reason for rejection. size: the size of the rejected message.
func (*LocalGossipSubRouterMetrics) OnOutboundRpcDropped ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnOutboundRpcDropped()
OnOutboundRpcDropped is called when an outbound RPC message is dropped by the local node, typically because the local node outbound message queue is full; or the RPC is big and the local node cannot fragment it.
func (*LocalGossipSubRouterMetrics) OnPeerAddedToProtocol ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnPeerAddedToProtocol(protocol string)
OnPeerAddedToProtocol is called when the local node receives a stream from a peer on a gossipsub-related protocol. Args:
protocol: the protocol name that the peer is connected to.
func (*LocalGossipSubRouterMetrics) OnPeerGraftTopic ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnPeerGraftTopic(topic string)
OnPeerGraftTopic is called when the local node receives a GRAFT message from a remote peer on a topic. Note: the received GRAFT at this point is considered passed the RPC inspection, and is accepted by the local node.
func (*LocalGossipSubRouterMetrics) OnPeerPruneTopic ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnPeerPruneTopic(topic string)
OnPeerPruneTopic is called when the local node receives a PRUNE message from a remote peer on a topic. Note: the received PRUNE at this point is considered passed the RPC inspection, and is accepted by the local node.
func (*LocalGossipSubRouterMetrics) OnPeerRemovedFromProtocol ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnPeerRemovedFromProtocol()
OnPeerRemovedFromProtocol is called when the local considers a remote peer blacklisted or unavailable.
func (*LocalGossipSubRouterMetrics) OnPeerThrottled ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnPeerThrottled()
OnPeerThrottled is called when a peer is throttled by the local node, i.e., the local node is not accepting any pubsub message from the peer but may still accept control messages.
func (*LocalGossipSubRouterMetrics) OnRpcReceived ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnRpcReceived(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
OnRpcReceived is called when an RPC message is received by the local node. The received RPC is considered passed the RPC inspection, and is accepted by the local node.
func (*LocalGossipSubRouterMetrics) OnRpcSent ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnRpcSent(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
OnRpcSent is called when an RPC message is sent by the local node. Note: the sent RPC is considered passed the RPC inspection, and is accepted by the local node.
func (*LocalGossipSubRouterMetrics) OnUndeliveredMessage ¶ added in v0.33.1
func (g *LocalGossipSubRouterMetrics) OnUndeliveredMessage()
OnUndeliveredMessage is called when a message is not delivered at least one subscriber of the topic, for example when the subscriber is too slow to process the message.
type MempoolCollector ¶
type MempoolCollector struct {
// contains filtered or unexported fields
}
func NewMempoolCollector ¶
func NewMempoolCollector(interval time.Duration) *MempoolCollector
func (*MempoolCollector) Done ¶
func (mc *MempoolCollector) Done() <-chan struct{}
func (*MempoolCollector) MempoolEntries ¶
func (mc *MempoolCollector) MempoolEntries(resource string, entries uint)
func (*MempoolCollector) Ready ¶
func (mc *MempoolCollector) Ready() <-chan struct{}
func (*MempoolCollector) Register ¶
func (mc *MempoolCollector) Register(resource string, entriesFunc module.EntriesFunc) error
Register registers entriesFunc for a resource
type NetworkCollector ¶
type NetworkCollector struct { *UnicastManagerMetrics *LibP2PResourceManagerMetrics *GossipSubScoreMetrics *LocalGossipSubRouterMetrics *GossipSubRpcValidationInspectorMetrics *AlspMetrics // contains filtered or unexported fields }
func NewNetworkCollector ¶
func NewNetworkCollector(logger zerolog.Logger, opts ...NetworkCollectorOpt) *NetworkCollector
func (*NetworkCollector) DNSLookupDuration ¶ added in v0.21.0
func (nc *NetworkCollector) DNSLookupDuration(duration time.Duration)
DNSLookupDuration tracks the time spent to resolve a DNS address.
func (*NetworkCollector) DuplicateInboundMessagesDropped ¶ added in v0.29.1
func (nc *NetworkCollector) DuplicateInboundMessagesDropped(topic, protocol, messageType string)
DuplicateInboundMessagesDropped increments the metric tracking the number of duplicate messages dropped by the node.
func (*NetworkCollector) InboundConnections ¶ added in v0.12.0
func (nc *NetworkCollector) InboundConnections(connectionCount uint)
InboundConnections updates the metric tracking the number of inbound connections of this node
func (*NetworkCollector) InboundMessageReceived ¶ added in v0.29.1
func (nc *NetworkCollector) InboundMessageReceived(sizeBytes int, topic, protocol, messageType string)
InboundMessageReceived collects metrics related to a message received by the node.
func (*NetworkCollector) MessageAdded ¶
func (nc *NetworkCollector) MessageAdded(priority int)
func (*NetworkCollector) MessageProcessingFinished ¶ added in v0.24.7
func (nc *NetworkCollector) MessageProcessingFinished(topic string, duration time.Duration)
MessageProcessingFinished tracks the time spent by the node to process a message and decrements the metric tracking the number of messages being processed by the node.
func (*NetworkCollector) MessageProcessingStarted ¶ added in v0.24.7
func (nc *NetworkCollector) MessageProcessingStarted(topic string)
MessageProcessingStarted increments the metric tracking the number of messages being processed by the node.
func (*NetworkCollector) MessageRemoved ¶
func (nc *NetworkCollector) MessageRemoved(priority int)
func (*NetworkCollector) OnDNSCacheHit ¶ added in v0.21.0
func (nc *NetworkCollector) OnDNSCacheHit()
OnDNSCacheHit tracks the total number of dns requests resolved through the cache without looking up the network.
func (*NetworkCollector) OnDNSCacheInvalidated ¶ added in v0.21.0
func (nc *NetworkCollector) OnDNSCacheInvalidated()
OnDNSCacheInvalidated is called whenever dns cache is invalidated for an entry
func (*NetworkCollector) OnDNSCacheMiss ¶ added in v0.21.0
func (nc *NetworkCollector) OnDNSCacheMiss()
OnDNSCacheMiss tracks the total number of dns requests resolved through looking up the network.
func (*NetworkCollector) OnDNSLookupRequestDropped ¶ added in v0.23.9
func (nc *NetworkCollector) OnDNSLookupRequestDropped()
OnDNSLookupRequestDropped tracks the number of dns lookup requests that are dropped due to a full queue
func (*NetworkCollector) OnRateLimitedPeer ¶ added in v0.30.0
func (nc *NetworkCollector) OnRateLimitedPeer(peerID peer.ID, role, msgType, topic, reason string)
OnRateLimitedPeer tracks the number of rate limited messages seen on the network.
func (*NetworkCollector) OnUnauthorizedMessage ¶ added in v0.28.0
func (nc *NetworkCollector) OnUnauthorizedMessage(role, msgType, topic, offense string)
OnUnauthorizedMessage tracks the number of unauthorized messages seen on the network.
func (*NetworkCollector) OnViolationReportSkipped ¶ added in v0.32.0
func (nc *NetworkCollector) OnViolationReportSkipped()
OnViolationReportSkipped tracks the number of slashing violations consumer violations that were not reported for misbehavior when the identity of the sender not known.
func (*NetworkCollector) OutboundConnections ¶ added in v0.12.0
func (nc *NetworkCollector) OutboundConnections(connectionCount uint)
OutboundConnections updates the metric tracking the number of outbound connections of this node
func (*NetworkCollector) OutboundMessageSent ¶ added in v0.29.1
func (nc *NetworkCollector) OutboundMessageSent(sizeBytes int, topic, protocol, messageType string)
OutboundMessageSent collects metrics related to a message sent by the node.
func (*NetworkCollector) QueueDuration ¶
func (nc *NetworkCollector) QueueDuration(duration time.Duration, priority int)
func (*NetworkCollector) RoutingTablePeerAdded ¶ added in v0.26.11
func (nc *NetworkCollector) RoutingTablePeerAdded()
func (*NetworkCollector) RoutingTablePeerRemoved ¶ added in v0.26.11
func (nc *NetworkCollector) RoutingTablePeerRemoved()
func (*NetworkCollector) UnicastMessageSendingCompleted ¶ added in v0.29.1
func (nc *NetworkCollector) UnicastMessageSendingCompleted(topic string)
UnicastMessageSendingCompleted decrements the metric tracking the number of unicast messages sent by the node.
func (*NetworkCollector) UnicastMessageSendingStarted ¶ added in v0.29.1
func (nc *NetworkCollector) UnicastMessageSendingStarted(topic string)
UnicastMessageSendingStarted increments the metric tracking the number of unicast messages sent by the node.
type NetworkCollectorOpt ¶ added in v0.23.9
type NetworkCollectorOpt func(*NetworkCollector)
func WithNetworkPrefix ¶ added in v0.23.9
func WithNetworkPrefix(prefix string) NetworkCollectorOpt
type NodeInfoCollector ¶ added in v0.29.6
type NodeInfoCollector struct {
// contains filtered or unexported fields
}
NodeInfoCollector implements metrics to report static information about node. Such information can include: version, commit, sporkID.
func NewNodeInfoCollector ¶ added in v0.29.6
func NewNodeInfoCollector() *NodeInfoCollector
func (*NodeInfoCollector) NodeInfo ¶ added in v0.29.6
func (sc *NodeInfoCollector) NodeInfo(version, commit, sporkID string, protocolVersion uint)
type NoopCollector ¶
type NoopCollector struct{}
func NewNoopCollector ¶
func NewNoopCollector() *NoopCollector
func (*NoopCollector) AddBlobsFailed ¶ added in v0.27.2
func (nc *NoopCollector) AddBlobsFailed()
func (*NoopCollector) AddBlobsSucceeded ¶ added in v0.27.2
func (nc *NoopCollector) AddBlobsSucceeded(duration time.Duration, totalSize uint64)
func (*NoopCollector) AddInflightRequests ¶ added in v0.29.12
func (nc *NoopCollector) AddInflightRequests(context.Context, httpmetrics.HTTPProperties, int)
func (*NoopCollector) AddTotalRequests ¶ added in v0.29.12
func (nc *NoopCollector) AddTotalRequests(context.Context, string, string)
func (*NoopCollector) AllowConn ¶ added in v0.29.0
func (nc *NoopCollector) AllowConn(network.Direction, bool)
func (*NoopCollector) AllowMemory ¶ added in v0.29.0
func (nc *NoopCollector) AllowMemory(int)
func (*NoopCollector) AllowPeer ¶ added in v0.29.0
func (nc *NoopCollector) AllowPeer(peer.ID)
func (*NoopCollector) AllowProtocol ¶ added in v0.29.0
func (nc *NoopCollector) AllowProtocol(protocol.ID)
func (*NoopCollector) AllowService ¶ added in v0.29.0
func (nc *NoopCollector) AllowService(string)
func (*NoopCollector) AllowStream ¶ added in v0.29.0
func (nc *NoopCollector) AllowStream(peer.ID, network.Direction)
func (*NoopCollector) AsyncProcessingFinished ¶ added in v0.31.0
func (nc *NoopCollector) AsyncProcessingFinished(time.Duration)
func (*NoopCollector) AsyncProcessingStarted ¶ added in v0.31.0
func (nc *NoopCollector) AsyncProcessingStarted()
func (*NoopCollector) BadgerLSMSize ¶
func (nc *NoopCollector) BadgerLSMSize(sizeBytes int64)
func (*NoopCollector) BadgerNumBlockedPuts ¶
func (nc *NoopCollector) BadgerNumBlockedPuts(n int64)
func (*NoopCollector) BadgerNumBytesRead ¶
func (nc *NoopCollector) BadgerNumBytesRead(n int64)
func (*NoopCollector) BadgerNumBytesWritten ¶
func (nc *NoopCollector) BadgerNumBytesWritten(n int64)
func (*NoopCollector) BadgerNumGets ¶
func (nc *NoopCollector) BadgerNumGets(n int64)
func (*NoopCollector) BadgerNumMemtableGets ¶
func (nc *NoopCollector) BadgerNumMemtableGets(n int64)
func (*NoopCollector) BadgerNumPuts ¶
func (nc *NoopCollector) BadgerNumPuts(n int64)
func (*NoopCollector) BadgerNumReads ¶
func (nc *NoopCollector) BadgerNumReads(n int64)
func (*NoopCollector) BadgerNumWrites ¶
func (nc *NoopCollector) BadgerNumWrites(n int64)
func (*NoopCollector) BadgerVLogSize ¶
func (nc *NoopCollector) BadgerVLogSize(sizeBytes int64)
func (*NoopCollector) BatchRequested ¶ added in v0.27.0
func (nc *NoopCollector) BatchRequested(batch chainsync.Batch)
func (*NoopCollector) BlobsReceived ¶ added in v0.27.3
func (nc *NoopCollector) BlobsReceived(prefix string, n uint64)
func (*NoopCollector) BlobsSent ¶ added in v0.27.3
func (nc *NoopCollector) BlobsSent(prefix string, n uint64)
func (*NoopCollector) BlockConn ¶ added in v0.29.0
func (nc *NoopCollector) BlockConn(network.Direction, bool)
func (*NoopCollector) BlockFinalized ¶
func (nc *NoopCollector) BlockFinalized(*flow.Block)
func (*NoopCollector) BlockIndexed ¶ added in v0.32.1
func (*NoopCollector) BlockMemory ¶ added in v0.29.0
func (nc *NoopCollector) BlockMemory(int)
func (*NoopCollector) BlockPeer ¶ added in v0.29.0
func (nc *NoopCollector) BlockPeer(peer.ID)
func (*NoopCollector) BlockProcessingDuration ¶ added in v0.29.0
func (nc *NoopCollector) BlockProcessingDuration(time.Duration)
func (*NoopCollector) BlockProposalDuration ¶ added in v0.15.0
func (nc *NoopCollector) BlockProposalDuration(duration time.Duration)
func (*NoopCollector) BlockProposed ¶
func (nc *NoopCollector) BlockProposed(*flow.Block)
func (*NoopCollector) BlockProtocol ¶ added in v0.29.0
func (nc *NoopCollector) BlockProtocol(protocol.ID)
func (*NoopCollector) BlockProtocolPeer ¶ added in v0.29.0
func (nc *NoopCollector) BlockProtocolPeer(protocol.ID, peer.ID)
func (*NoopCollector) BlockReindexed ¶ added in v0.32.1
func (nc *NoopCollector) BlockReindexed()
func (*NoopCollector) BlockSealed ¶
func (nc *NoopCollector) BlockSealed(*flow.Block)
func (*NoopCollector) BlockService ¶ added in v0.29.0
func (nc *NoopCollector) BlockService(string)
func (*NoopCollector) BlockServicePeer ¶ added in v0.29.0
func (nc *NoopCollector) BlockServicePeer(string, peer.ID)
func (*NoopCollector) BlockStream ¶ added in v0.29.0
func (nc *NoopCollector) BlockStream(peer.ID, network.Direction)
func (*NoopCollector) BucketAvailableSlots ¶ added in v0.25.2
func (nc *NoopCollector) BucketAvailableSlots(uint64, uint64)
func (*NoopCollector) CacheEntries ¶
func (nc *NoopCollector) CacheEntries(resource string, entries uint)
func (*NoopCollector) CacheHit ¶
func (nc *NoopCollector) CacheHit(resource string)
func (*NoopCollector) CacheMiss ¶
func (nc *NoopCollector) CacheMiss(resource string)
func (*NoopCollector) CacheNotFound ¶ added in v0.16.0
func (nc *NoopCollector) CacheNotFound(resource string)
func (*NoopCollector) CheckSealingDuration ¶ added in v0.11.0
func (nc *NoopCollector) CheckSealingDuration(duration time.Duration)
func (*NoopCollector) ChunkDataPackRequestProcessed ¶ added in v0.28.0
func (nc *NoopCollector) ChunkDataPackRequestProcessed()
func (*NoopCollector) ClusterBlockFinalized ¶
func (nc *NoopCollector) ClusterBlockFinalized(*cluster.Block)
func (*NoopCollector) ClusterBlockProposed ¶
func (nc *NoopCollector) ClusterBlockProposed(*cluster.Block)
func (*NoopCollector) CollectionExecuted ¶ added in v0.33.15
func (nc *NoopCollector) CollectionExecuted(light flow.LightCollection)
func (*NoopCollector) CollectionFinalized ¶ added in v0.33.15
func (nc *NoopCollector) CollectionFinalized(light flow.LightCollection)
func (*NoopCollector) CommittedEpochFinalView ¶ added in v0.18.3
func (nc *NoopCollector) CommittedEpochFinalView(view uint64)
func (*NoopCollector) CommitteeProcessingDuration ¶
func (nc *NoopCollector) CommitteeProcessingDuration(duration time.Duration)
func (*NoopCollector) ConnectionAddedToPool ¶ added in v0.26.17
func (nc *NoopCollector) ConnectionAddedToPool()
func (*NoopCollector) ConnectionFromPoolEvicted ¶ added in v0.26.17
func (nc *NoopCollector) ConnectionFromPoolEvicted()
func (*NoopCollector) ConnectionFromPoolInvalidated ¶ added in v0.26.17
func (nc *NoopCollector) ConnectionFromPoolInvalidated()
func (*NoopCollector) ConnectionFromPoolReused ¶ added in v0.26.17
func (nc *NoopCollector) ConnectionFromPoolReused()
func (*NoopCollector) ConnectionFromPoolUpdated ¶ added in v0.26.17
func (nc *NoopCollector) ConnectionFromPoolUpdated()
func (*NoopCollector) CountSkipped ¶
func (nc *NoopCollector) CountSkipped()
func (*NoopCollector) CountTimeout ¶
func (nc *NoopCollector) CountTimeout()
func (*NoopCollector) CurrentDKGPhase1FinalView ¶ added in v0.21.0
func (nc *NoopCollector) CurrentDKGPhase1FinalView(view uint64)
func (*NoopCollector) CurrentDKGPhase2FinalView ¶ added in v0.21.0
func (nc *NoopCollector) CurrentDKGPhase2FinalView(view uint64)
func (*NoopCollector) CurrentDKGPhase3FinalView ¶ added in v0.21.0
func (nc *NoopCollector) CurrentDKGPhase3FinalView(view uint64)
func (*NoopCollector) CurrentEpochCounter ¶ added in v0.20.0
func (nc *NoopCollector) CurrentEpochCounter(counter uint64)
func (*NoopCollector) CurrentEpochFinalView ¶ added in v0.21.0
func (nc *NoopCollector) CurrentEpochFinalView(view uint64)
func (*NoopCollector) CurrentEpochPhase ¶ added in v0.20.0
func (nc *NoopCollector) CurrentEpochPhase(phase flow.EpochPhase)
func (*NoopCollector) DNSLookupDuration ¶ added in v0.21.0
func (nc *NoopCollector) DNSLookupDuration(duration time.Duration)
func (*NoopCollector) DataReceived ¶ added in v0.27.3
func (nc *NoopCollector) DataReceived(prefix string, n uint64)
func (*NoopCollector) DataSent ¶ added in v0.27.3
func (nc *NoopCollector) DataSent(prefix string, n uint64)
func (*NoopCollector) DirectMessageFinished ¶ added in v0.24.7
func (nc *NoopCollector) DirectMessageFinished(topic string)
func (*NoopCollector) DirectMessageStarted ¶ added in v0.24.7
func (nc *NoopCollector) DirectMessageStarted(topic string)
func (*NoopCollector) DupBlobsReceived ¶ added in v0.27.3
func (nc *NoopCollector) DupBlobsReceived(prefix string, n uint64)
func (*NoopCollector) DupDataReceived ¶ added in v0.27.3
func (nc *NoopCollector) DupDataReceived(prefix string, n uint64)
func (*NoopCollector) DuplicateInboundMessagesDropped ¶ added in v0.29.1
func (nc *NoopCollector) DuplicateInboundMessagesDropped(string, string, string)
func (*NoopCollector) EmergencySeal ¶ added in v0.14.0
func (nc *NoopCollector) EmergencySeal()
func (*NoopCollector) EpochEmergencyFallbackTriggered ¶ added in v0.23.2
func (nc *NoopCollector) EpochEmergencyFallbackTriggered()
func (*NoopCollector) EpochTransitionHeight ¶ added in v0.30.0
func (nc *NoopCollector) EpochTransitionHeight(height uint64)
func (*NoopCollector) ExecutionBlockCachedPrograms ¶ added in v0.29.17
func (nc *NoopCollector) ExecutionBlockCachedPrograms(programs int)
func (*NoopCollector) ExecutionBlockDataUploadFinished ¶ added in v0.20.6
func (nc *NoopCollector) ExecutionBlockDataUploadFinished(dur time.Duration)
func (*NoopCollector) ExecutionBlockDataUploadStarted ¶ added in v0.20.6
func (nc *NoopCollector) ExecutionBlockDataUploadStarted()
func (*NoopCollector) ExecutionBlockExecuted ¶ added in v0.18.3
func (nc *NoopCollector) ExecutionBlockExecuted(_ time.Duration, _ module.ExecutionResultStats)
func (*NoopCollector) ExecutionBlockExecutionEffortVectorComponent ¶ added in v0.28.2
func (nc *NoopCollector) ExecutionBlockExecutionEffortVectorComponent(_ string, _ uint)
func (*NoopCollector) ExecutionCheckpointSize ¶ added in v0.33.10
func (nc *NoopCollector) ExecutionCheckpointSize(bytes uint64)
func (*NoopCollector) ExecutionChunkDataPackGenerated ¶ added in v0.28.7
func (nc *NoopCollector) ExecutionChunkDataPackGenerated(_, _ int)
func (*NoopCollector) ExecutionCollectionExecuted ¶ added in v0.18.3
func (nc *NoopCollector) ExecutionCollectionExecuted(_ time.Duration, _ module.ExecutionResultStats)
func (*NoopCollector) ExecutionCollectionRequestRetried ¶
func (nc *NoopCollector) ExecutionCollectionRequestRetried()
func (*NoopCollector) ExecutionCollectionRequestSent ¶
func (nc *NoopCollector) ExecutionCollectionRequestSent()
func (*NoopCollector) ExecutionComputationResultUploadRetried ¶ added in v0.28.0
func (nc *NoopCollector) ExecutionComputationResultUploadRetried()
func (*NoopCollector) ExecutionComputationResultUploaded ¶ added in v0.28.0
func (nc *NoopCollector) ExecutionComputationResultUploaded()
func (*NoopCollector) ExecutionComputationUsedPerBlock ¶ added in v0.18.3
func (nc *NoopCollector) ExecutionComputationUsedPerBlock(computation uint64)
func (*NoopCollector) ExecutionDataFetchFinished ¶ added in v0.26.2
func (nc *NoopCollector) ExecutionDataFetchFinished(_ time.Duration, _ bool, _ uint64)
func (*NoopCollector) ExecutionDataFetchStarted ¶ added in v0.26.2
func (nc *NoopCollector) ExecutionDataFetchStarted()
func (*NoopCollector) ExecutionLastExecutedBlockHeight ¶
func (nc *NoopCollector) ExecutionLastExecutedBlockHeight(height uint64)
func (*NoopCollector) ExecutionLastFinalizedExecutedBlockHeight ¶ added in v0.33.1
func (nc *NoopCollector) ExecutionLastFinalizedExecutedBlockHeight(height uint64)
func (*NoopCollector) ExecutionReceiptReceived ¶ added in v0.33.15
func (nc *NoopCollector) ExecutionReceiptReceived(r *flow.ExecutionReceipt)
func (*NoopCollector) ExecutionScriptExecuted ¶ added in v0.18.3
func (nc *NoopCollector) ExecutionScriptExecuted(dur time.Duration, compUsed, _, _ uint64)
func (*NoopCollector) ExecutionStorageStateCommitment ¶
func (nc *NoopCollector) ExecutionStorageStateCommitment(bytes int64)
func (*NoopCollector) ExecutionSync ¶
func (nc *NoopCollector) ExecutionSync(syncing bool)
func (*NoopCollector) ExecutionTransactionExecuted ¶ added in v0.18.3
func (*NoopCollector) FetchRetried ¶ added in v0.26.2
func (nc *NoopCollector) FetchRetried()
func (*NoopCollector) FinalizedHeight ¶
func (nc *NoopCollector) FinalizedHeight(height uint64)
func (*NoopCollector) FinishBlockReceivedToExecuted ¶
func (nc *NoopCollector) FinishBlockReceivedToExecuted(blockID flow.Identifier)
func (*NoopCollector) FinishBlockToSeal ¶
func (nc *NoopCollector) FinishBlockToSeal(blockID flow.Identifier)
func (*NoopCollector) FinishCollectionToFinalized ¶
func (nc *NoopCollector) FinishCollectionToFinalized(collectionID flow.Identifier)
func (*NoopCollector) ForestApproxMemorySize ¶
func (nc *NoopCollector) ForestApproxMemorySize(bytes uint64)
func (*NoopCollector) ForestNumberOfTrees ¶
func (nc *NoopCollector) ForestNumberOfTrees(number uint64)
func (*NoopCollector) FulfilledHeight ¶ added in v0.27.2
func (nc *NoopCollector) FulfilledHeight(blockHeight uint64)
func (*NoopCollector) HotStuffBusyDuration ¶
func (nc *NoopCollector) HotStuffBusyDuration(duration time.Duration, event string)
func (*NoopCollector) HotStuffIdleDuration ¶
func (nc *NoopCollector) HotStuffIdleDuration(duration time.Duration)
func (*NoopCollector) HotStuffWaitDuration ¶
func (nc *NoopCollector) HotStuffWaitDuration(duration time.Duration, event string)
func (*NoopCollector) InboundConnections ¶ added in v0.12.0
func (nc *NoopCollector) InboundConnections(_ uint)
func (*NoopCollector) InboundMessageDropped ¶ added in v0.29.0
func (nc *NoopCollector) InboundMessageDropped(engine string, message string)
func (*NoopCollector) InboundMessageReceived ¶ added in v0.29.1
func (nc *NoopCollector) InboundMessageReceived(int, string, string, string)
func (*NoopCollector) InitializeLatestHeight ¶ added in v0.32.2
func (nc *NoopCollector) InitializeLatestHeight(height uint64)
func (*NoopCollector) LatestTrieMaxDepthTouched ¶ added in v0.25.2
func (nc *NoopCollector) LatestTrieMaxDepthTouched(maxDepth uint16)
func (*NoopCollector) LatestTrieRegCount ¶
func (nc *NoopCollector) LatestTrieRegCount(number uint64)
func (*NoopCollector) LatestTrieRegCountDiff ¶
func (nc *NoopCollector) LatestTrieRegCountDiff(number int64)
func (*NoopCollector) LatestTrieRegSize ¶ added in v0.25.2
func (nc *NoopCollector) LatestTrieRegSize(size uint64)
func (*NoopCollector) LatestTrieRegSizeDiff ¶ added in v0.25.2
func (nc *NoopCollector) LatestTrieRegSizeDiff(size int64)
func (*NoopCollector) MempoolEntries ¶
func (nc *NoopCollector) MempoolEntries(resource string, entries uint)
func (*NoopCollector) MessageAdded ¶
func (nc *NoopCollector) MessageAdded(priority int)
func (*NoopCollector) MessageHandled ¶
func (nc *NoopCollector) MessageHandled(engine string, message string)
func (*NoopCollector) MessageProcessingFinished ¶ added in v0.24.7
func (nc *NoopCollector) MessageProcessingFinished(topic string, duration time.Duration)
func (*NoopCollector) MessageProcessingStarted ¶ added in v0.24.7
func (nc *NoopCollector) MessageProcessingStarted(topic string)
func (*NoopCollector) MessageReceived ¶
func (nc *NoopCollector) MessageReceived(engine string, message string)
func (*NoopCollector) MessageRemoved ¶
func (nc *NoopCollector) MessageRemoved(priority int)
func (*NoopCollector) MessageSent ¶
func (nc *NoopCollector) MessageSent(engine string, message string)
func (*NoopCollector) MessagesReceived ¶ added in v0.27.3
func (nc *NoopCollector) MessagesReceived(prefix string, n uint64)
func (*NoopCollector) NetworkDuplicateMessagesDropped ¶
func (nc *NoopCollector) NetworkDuplicateMessagesDropped(topic string, messageType string)
func (*NoopCollector) NetworkMessageReceived ¶
func (nc *NoopCollector) NetworkMessageReceived(sizeBytes int, topic string, messageType string)
func (*NoopCollector) NetworkMessageSent ¶
func (nc *NoopCollector) NetworkMessageSent(sizeBytes int, topic string, messageType string)
func (*NoopCollector) NewConnectionEstablished ¶ added in v0.26.17
func (nc *NoopCollector) NewConnectionEstablished()
func (*NoopCollector) NotificationSent ¶ added in v0.26.2
func (nc *NoopCollector) NotificationSent(height uint64)
func (*NoopCollector) ObserveHTTPRequestDuration ¶ added in v0.29.12
func (nc *NoopCollector) ObserveHTTPRequestDuration(context.Context, httpmetrics.HTTPReqProperties, time.Duration)
func (*NoopCollector) ObserveHTTPResponseSize ¶ added in v0.29.12
func (nc *NoopCollector) ObserveHTTPResponseSize(context.Context, httpmetrics.HTTPReqProperties, int64)
func (*NoopCollector) OnActiveClusterIDsNotSetErr ¶ added in v0.33.7
func (nc *NoopCollector) OnActiveClusterIDsNotSetErr()
func (*NoopCollector) OnAppSpecificScoreUpdated ¶ added in v0.30.0
func (nc *NoopCollector) OnAppSpecificScoreUpdated(f float64)
func (*NoopCollector) OnApprovalProcessingDuration ¶ added in v0.14.1
func (nc *NoopCollector) OnApprovalProcessingDuration(duration time.Duration)
func (*NoopCollector) OnAssignedChunkProcessedAtAssigner ¶ added in v0.17.1
func (nc *NoopCollector) OnAssignedChunkProcessedAtAssigner()
func (*NoopCollector) OnAssignedChunkReceivedAtFetcher ¶ added in v0.17.1
func (nc *NoopCollector) OnAssignedChunkReceivedAtFetcher()
func (*NoopCollector) OnBehaviourPenaltyUpdated ¶ added in v0.30.0
func (nc *NoopCollector) OnBehaviourPenaltyUpdated(f float64)
func (*NoopCollector) OnBlockConsumerJobDone ¶ added in v0.19.0
func (nc *NoopCollector) OnBlockConsumerJobDone(uint64)
func (*NoopCollector) OnChunkConsumerJobDone ¶ added in v0.19.0
func (nc *NoopCollector) OnChunkConsumerJobDone(uint64)
func (*NoopCollector) OnChunkDataPackArrivedAtFetcher ¶ added in v0.17.1
func (nc *NoopCollector) OnChunkDataPackArrivedAtFetcher()
func (*NoopCollector) OnChunkDataPackRequestDispatchedInNetworkByRequester ¶ added in v0.19.0
func (nc *NoopCollector) OnChunkDataPackRequestDispatchedInNetworkByRequester()
func (*NoopCollector) OnChunkDataPackRequestReceivedByRequester ¶ added in v0.17.1
func (nc *NoopCollector) OnChunkDataPackRequestReceivedByRequester()
func (*NoopCollector) OnChunkDataPackRequestSentByFetcher ¶ added in v0.17.1
func (nc *NoopCollector) OnChunkDataPackRequestSentByFetcher()
func (*NoopCollector) OnChunkDataPackResponseReceivedFromNetworkByRequester ¶ added in v0.19.0
func (nc *NoopCollector) OnChunkDataPackResponseReceivedFromNetworkByRequester()
func (*NoopCollector) OnChunkDataPackSentToFetcher ¶ added in v0.17.1
func (nc *NoopCollector) OnChunkDataPackSentToFetcher()
func (*NoopCollector) OnChunksAssignmentDoneAtAssigner ¶ added in v0.17.1
func (nc *NoopCollector) OnChunksAssignmentDoneAtAssigner(chunks int)
func (*NoopCollector) OnControlMessagesTruncated ¶ added in v0.33.1
func (nc *NoopCollector) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
func (*NoopCollector) OnDNSCacheHit ¶ added in v0.21.0
func (nc *NoopCollector) OnDNSCacheHit()
func (*NoopCollector) OnDNSCacheInvalidated ¶ added in v0.21.0
func (nc *NoopCollector) OnDNSCacheInvalidated()
func (*NoopCollector) OnDNSCacheMiss ¶ added in v0.21.0
func (nc *NoopCollector) OnDNSCacheMiss()
func (*NoopCollector) OnDNSLookupRequestDropped ¶ added in v0.23.9
func (nc *NoopCollector) OnDNSLookupRequestDropped()
func (*NoopCollector) OnDialRetryBudgetResetToDefault ¶ added in v0.32.2
func (nc *NoopCollector) OnDialRetryBudgetResetToDefault()
func (*NoopCollector) OnDialRetryBudgetUpdated ¶ added in v0.32.2
func (nc *NoopCollector) OnDialRetryBudgetUpdated(budget uint64)
func (*NoopCollector) OnEntityEjectionDueToEmergency ¶ added in v0.25.2
func (nc *NoopCollector) OnEntityEjectionDueToEmergency()
func (*NoopCollector) OnEntityEjectionDueToFullCapacity ¶ added in v0.25.2
func (nc *NoopCollector) OnEntityEjectionDueToFullCapacity()
func (*NoopCollector) OnEstablishStreamFailure ¶ added in v0.30.0
func (nc *NoopCollector) OnEstablishStreamFailure(duration time.Duration, attempts int)
func (*NoopCollector) OnExecutionResultReceivedAtAssignerEngine ¶ added in v0.19.0
func (nc *NoopCollector) OnExecutionResultReceivedAtAssignerEngine()
func (*NoopCollector) OnFinalizedBlockArrivedAtAssigner ¶ added in v0.17.1
func (nc *NoopCollector) OnFinalizedBlockArrivedAtAssigner(height uint64)
func (*NoopCollector) OnFirstMessageDeliveredUpdated ¶ added in v0.30.0
func (nc *NoopCollector) OnFirstMessageDeliveredUpdated(topic channels.Topic, f float64)
func (*NoopCollector) OnGraftDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (nc *NoopCollector) OnGraftDuplicateTopicIdsExceedThreshold()
func (*NoopCollector) OnGraftMessageInspected ¶ added in v0.33.7
func (nc *NoopCollector) OnGraftMessageInspected(duplicateTopicIds int)
func (*NoopCollector) OnIHaveControlMessageIdsTruncated ¶ added in v0.33.1
func (nc *NoopCollector) OnIHaveControlMessageIdsTruncated(diff int)
func (*NoopCollector) OnIHaveDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (nc *NoopCollector) OnIHaveDuplicateMessageIdsExceedThreshold()
func (*NoopCollector) OnIHaveDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (nc *NoopCollector) OnIHaveDuplicateTopicIdsExceedThreshold()
func (*NoopCollector) OnIHaveMessageIDsReceived ¶ added in v0.33.1
func (nc *NoopCollector) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
func (*NoopCollector) OnIHaveMessagesInspected ¶ added in v0.33.7
func (nc *NoopCollector) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int)
func (*NoopCollector) OnIPColocationFactorUpdated ¶ added in v0.30.0
func (nc *NoopCollector) OnIPColocationFactorUpdated(f float64)
func (*NoopCollector) OnIWantCacheMissMessageIdsExceedThreshold ¶ added in v0.33.7
func (nc *NoopCollector) OnIWantCacheMissMessageIdsExceedThreshold()
func (*NoopCollector) OnIWantControlMessageIdsTruncated ¶ added in v0.33.1
func (nc *NoopCollector) OnIWantControlMessageIdsTruncated(diff int)
func (*NoopCollector) OnIWantDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (nc *NoopCollector) OnIWantDuplicateMessageIdsExceedThreshold()
func (*NoopCollector) OnIWantMessageIDsReceived ¶ added in v0.33.1
func (nc *NoopCollector) OnIWantMessageIDsReceived(msgIdCount int)
func (*NoopCollector) OnIWantMessagesInspected ¶ added in v0.33.7
func (nc *NoopCollector) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
func (*NoopCollector) OnIncomingRpcReceived ¶ added in v0.33.1
func (nc *NoopCollector) OnIncomingRpcReceived(iHaveCount, iWantCount, graftCount, pruneCount, msgCount int)
func (*NoopCollector) OnInvalidControlMessageNotificationSent ¶ added in v0.33.7
func (nc *NoopCollector) OnInvalidControlMessageNotificationSent()
func (*NoopCollector) OnInvalidMessageDeliveredUpdated ¶ added in v0.30.0
func (nc *NoopCollector) OnInvalidMessageDeliveredUpdated(topic channels.Topic, f float64)
func (*NoopCollector) OnInvalidTopicIdDetectedForControlMessage ¶ added in v0.33.7
func (nc *NoopCollector) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
func (*NoopCollector) OnKeyGetFailure ¶ added in v0.25.2
func (nc *NoopCollector) OnKeyGetFailure()
func (*NoopCollector) OnKeyGetSuccess ¶ added in v0.25.2
func (nc *NoopCollector) OnKeyGetSuccess()
func (*NoopCollector) OnKeyPutAttempt ¶ added in v0.29.0
func (nc *NoopCollector) OnKeyPutAttempt(uint32)
func (*NoopCollector) OnKeyPutDeduplicated ¶ added in v0.29.0
func (nc *NoopCollector) OnKeyPutDeduplicated()
func (*NoopCollector) OnKeyPutDrop ¶ added in v0.29.0
func (nc *NoopCollector) OnKeyPutDrop()
func (*NoopCollector) OnKeyPutSuccess ¶ added in v0.25.2
func (nc *NoopCollector) OnKeyPutSuccess(uint32)
func (*NoopCollector) OnKeyRemoved ¶ added in v0.29.0
func (nc *NoopCollector) OnKeyRemoved(uint32)
func (*NoopCollector) OnLocalMeshSizeUpdated ¶ added in v0.30.0
func (nc *NoopCollector) OnLocalMeshSizeUpdated(string, int)
func (*NoopCollector) OnLocalPeerJoinedTopic ¶ added in v0.33.1
func (nc *NoopCollector) OnLocalPeerJoinedTopic()
func (*NoopCollector) OnLocalPeerLeftTopic ¶ added in v0.33.1
func (nc *NoopCollector) OnLocalPeerLeftTopic()
func (*NoopCollector) OnMeshMessageDeliveredUpdated ¶ added in v0.30.0
func (nc *NoopCollector) OnMeshMessageDeliveredUpdated(topic channels.Topic, f float64)
func (*NoopCollector) OnMessageDeliveredToAllSubscribers ¶ added in v0.33.1
func (nc *NoopCollector) OnMessageDeliveredToAllSubscribers(size int)
func (*NoopCollector) OnMessageDuplicate ¶ added in v0.33.1
func (nc *NoopCollector) OnMessageDuplicate(size int)
func (*NoopCollector) OnMessageEnteredValidation ¶ added in v0.33.1
func (nc *NoopCollector) OnMessageEnteredValidation(size int)
func (*NoopCollector) OnMessageRejected ¶ added in v0.33.1
func (nc *NoopCollector) OnMessageRejected(size int, reason string)
func (*NoopCollector) OnMisbehaviorReported ¶ added in v0.31.0
func (nc *NoopCollector) OnMisbehaviorReported(string, string)
func (*NoopCollector) OnOutboundRpcDropped ¶ added in v0.33.1
func (nc *NoopCollector) OnOutboundRpcDropped()
func (*NoopCollector) OnOverallPeerScoreUpdated ¶ added in v0.30.0
func (nc *NoopCollector) OnOverallPeerScoreUpdated(f float64)
func (*NoopCollector) OnPeerAddedToProtocol ¶ added in v0.33.1
func (nc *NoopCollector) OnPeerAddedToProtocol(protocol string)
func (*NoopCollector) OnPeerDialFailure ¶ added in v0.30.0
func (nc *NoopCollector) OnPeerDialFailure(duration time.Duration, attempts int)
func (*NoopCollector) OnPeerDialed ¶ added in v0.30.0
func (nc *NoopCollector) OnPeerDialed(duration time.Duration, attempts int)
func (*NoopCollector) OnPeerGraftTopic ¶ added in v0.33.1
func (nc *NoopCollector) OnPeerGraftTopic(topic string)
func (*NoopCollector) OnPeerPruneTopic ¶ added in v0.33.1
func (nc *NoopCollector) OnPeerPruneTopic(topic string)
func (*NoopCollector) OnPeerRemovedFromProtocol ¶ added in v0.33.1
func (nc *NoopCollector) OnPeerRemovedFromProtocol()
func (*NoopCollector) OnPeerThrottled ¶ added in v0.33.1
func (nc *NoopCollector) OnPeerThrottled()
func (*NoopCollector) OnPruneDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (nc *NoopCollector) OnPruneDuplicateTopicIdsExceedThreshold()
func (*NoopCollector) OnPruneMessageInspected ¶ added in v0.33.7
func (nc *NoopCollector) OnPruneMessageInspected(duplicateTopicIds int)
func (*NoopCollector) OnPublishMessageInspected ¶ added in v0.33.7
func (nc *NoopCollector) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, invalidSendersCount int)
func (*NoopCollector) OnPublishMessagesInspectionErrorExceedsThreshold ¶ added in v0.33.7
func (nc *NoopCollector) OnPublishMessagesInspectionErrorExceedsThreshold()
func (*NoopCollector) OnRateLimitedPeer ¶ added in v0.30.0
func (nc *NoopCollector) OnRateLimitedPeer(pid peer.ID, role, msgType, topic, reason string)
func (*NoopCollector) OnReceiptProcessingDuration ¶ added in v0.14.1
func (nc *NoopCollector) OnReceiptProcessingDuration(duration time.Duration)
func (*NoopCollector) OnResultApprovalDispatchedInNetworkByVerifier ¶ added in v0.19.0
func (nc *NoopCollector) OnResultApprovalDispatchedInNetworkByVerifier()
func (*NoopCollector) OnRpcReceived ¶ added in v0.33.1
func (*NoopCollector) OnStreamCreated ¶ added in v0.30.0
func (nc *NoopCollector) OnStreamCreated(duration time.Duration, attempts int)
func (*NoopCollector) OnStreamCreationFailure ¶ added in v0.30.0
func (nc *NoopCollector) OnStreamCreationFailure(duration time.Duration, attempts int)
func (*NoopCollector) OnStreamCreationRetryBudgetResetToDefault ¶ added in v0.32.2
func (nc *NoopCollector) OnStreamCreationRetryBudgetResetToDefault()
func (*NoopCollector) OnStreamCreationRetryBudgetUpdated ¶ added in v0.32.2
func (nc *NoopCollector) OnStreamCreationRetryBudgetUpdated(budget uint64)
func (*NoopCollector) OnStreamEstablished ¶ added in v0.30.0
func (nc *NoopCollector) OnStreamEstablished(duration time.Duration, attempts int)
func (*NoopCollector) OnTimeInMeshUpdated ¶ added in v0.30.0
func (nc *NoopCollector) OnTimeInMeshUpdated(topic channels.Topic, duration time.Duration)
func (*NoopCollector) OnUnauthorizedMessage ¶ added in v0.28.0
func (nc *NoopCollector) OnUnauthorizedMessage(role, msgType, topic, offense string)
func (*NoopCollector) OnUndeliveredMessage ¶ added in v0.33.1
func (nc *NoopCollector) OnUndeliveredMessage()
func (*NoopCollector) OnUnstakedPeerInspectionFailed ¶ added in v0.33.7
func (nc *NoopCollector) OnUnstakedPeerInspectionFailed()
func (*NoopCollector) OnVerifiableChunkReceivedAtVerifierEngine ¶ added in v0.17.1
func (nc *NoopCollector) OnVerifiableChunkReceivedAtVerifierEngine()
func (*NoopCollector) OnVerifiableChunkSentToVerifier ¶ added in v0.17.1
func (nc *NoopCollector) OnVerifiableChunkSentToVerifier()
func (*NoopCollector) OnViolationReportSkipped ¶ added in v0.32.0
func (nc *NoopCollector) OnViolationReportSkipped()
func (*NoopCollector) OutboundConnections ¶ added in v0.12.0
func (nc *NoopCollector) OutboundConnections(_ uint)
func (*NoopCollector) OutboundMessageDropped ¶ added in v0.29.0
func (nc *NoopCollector) OutboundMessageDropped(engine string, messages string)
func (*NoopCollector) OutboundMessageSent ¶ added in v0.29.1
func (nc *NoopCollector) OutboundMessageSent(int, string, string, string)
func (*NoopCollector) PayloadProductionDuration ¶
func (nc *NoopCollector) PayloadProductionDuration(duration time.Duration)
func (*NoopCollector) Peers ¶ added in v0.27.3
func (nc *NoopCollector) Peers(prefix string, n int)
func (*NoopCollector) ProofSize ¶
func (nc *NoopCollector) ProofSize(bytes uint32)
func (*NoopCollector) Pruned ¶ added in v0.27.2
func (nc *NoopCollector) Pruned(height uint64, duration time.Duration)
func (*NoopCollector) PrunedBlockByHeight ¶ added in v0.27.0
func (nc *NoopCollector) PrunedBlockByHeight(status *chainsync.Status)
func (*NoopCollector) PrunedBlockById ¶ added in v0.27.0
func (nc *NoopCollector) PrunedBlockById(status *chainsync.Status)
func (*NoopCollector) PrunedBlocks ¶ added in v0.27.0
func (nc *NoopCollector) PrunedBlocks(totalByHeight, totalById, storedByHeight, storedById int)
func (*NoopCollector) QueueDuration ¶
func (nc *NoopCollector) QueueDuration(duration time.Duration, priority int)
func (*NoopCollector) RanGC ¶
func (nc *NoopCollector) RanGC(duration time.Duration)
func (*NoopCollector) RangeRequested ¶ added in v0.27.0
func (nc *NoopCollector) RangeRequested(ran chainsync.Range)
func (*NoopCollector) ReadDuration ¶
func (nc *NoopCollector) ReadDuration(duration time.Duration)
func (*NoopCollector) ReadDurationPerItem ¶
func (nc *NoopCollector) ReadDurationPerItem(duration time.Duration)
func (*NoopCollector) ReadValuesNumber ¶
func (nc *NoopCollector) ReadValuesNumber(number uint64)
func (*NoopCollector) ReadValuesSize ¶
func (nc *NoopCollector) ReadValuesSize(byte uint64)
func (*NoopCollector) ReceiptSkipped ¶ added in v0.27.2
func (nc *NoopCollector) ReceiptSkipped()
func (*NoopCollector) RecordRPC ¶ added in v0.32.0
func (nc *NoopCollector) RecordRPC(handler, rpc string, code codes.Code)
func (*NoopCollector) Register ¶
func (nc *NoopCollector) Register(resource string, entriesFunc module.EntriesFunc) error
func (*NoopCollector) RequestCanceled ¶ added in v0.27.2
func (nc *NoopCollector) RequestCanceled()
func (*NoopCollector) RequestFailed ¶ added in v0.27.2
func (nc *NoopCollector) RequestFailed(duration time.Duration, retryable bool)
func (*NoopCollector) RequestSucceeded ¶ added in v0.27.2
func (*NoopCollector) ResponseDropped ¶ added in v0.27.2
func (nc *NoopCollector) ResponseDropped()
func (*NoopCollector) RootIDComputed ¶ added in v0.27.2
func (nc *NoopCollector) RootIDComputed(duration time.Duration, numberOfChunks int)
func (*NoopCollector) RoutingTablePeerAdded ¶ added in v0.26.11
func (nc *NoopCollector) RoutingTablePeerAdded()
func (*NoopCollector) RoutingTablePeerRemoved ¶ added in v0.26.11
func (nc *NoopCollector) RoutingTablePeerRemoved()
func (*NoopCollector) RuntimeSetNumberOfAccounts ¶ added in v0.18.3
func (nc *NoopCollector) RuntimeSetNumberOfAccounts(count uint64)
func (*NoopCollector) RuntimeTransactionChecked ¶ added in v0.18.3
func (nc *NoopCollector) RuntimeTransactionChecked(dur time.Duration)
func (*NoopCollector) RuntimeTransactionInterpreted ¶ added in v0.18.3
func (nc *NoopCollector) RuntimeTransactionInterpreted(dur time.Duration)
func (*NoopCollector) RuntimeTransactionParsed ¶ added in v0.18.3
func (nc *NoopCollector) RuntimeTransactionParsed(dur time.Duration)
func (*NoopCollector) RuntimeTransactionProgramsCacheHit ¶ added in v0.29.17
func (nc *NoopCollector) RuntimeTransactionProgramsCacheHit()
func (*NoopCollector) RuntimeTransactionProgramsCacheMiss ¶ added in v0.29.17
func (nc *NoopCollector) RuntimeTransactionProgramsCacheMiss()
func (*NoopCollector) ScriptExecuted ¶ added in v0.26.1
func (nc *NoopCollector) ScriptExecuted(dur time.Duration, size int)
func (*NoopCollector) ScriptExecutionErrorLocal ¶ added in v0.32.2
func (nc *NoopCollector) ScriptExecutionErrorLocal()
func (*NoopCollector) ScriptExecutionErrorMatch ¶ added in v0.32.0
func (nc *NoopCollector) ScriptExecutionErrorMatch()
func (*NoopCollector) ScriptExecutionErrorMismatch ¶ added in v0.32.0
func (nc *NoopCollector) ScriptExecutionErrorMismatch()
func (*NoopCollector) ScriptExecutionErrorOnExecutionNode ¶ added in v0.31.11
func (nc *NoopCollector) ScriptExecutionErrorOnExecutionNode()
func (*NoopCollector) ScriptExecutionNotIndexed ¶ added in v0.32.7
func (nc *NoopCollector) ScriptExecutionNotIndexed()
func (*NoopCollector) ScriptExecutionResultMatch ¶ added in v0.32.0
func (nc *NoopCollector) ScriptExecutionResultMatch()
func (*NoopCollector) ScriptExecutionResultMismatch ¶ added in v0.32.0
func (nc *NoopCollector) ScriptExecutionResultMismatch()
func (*NoopCollector) SealedHeight ¶
func (nc *NoopCollector) SealedHeight(height uint64)
func (*NoopCollector) SetCurView ¶
func (nc *NoopCollector) SetCurView(view uint64)
func (*NoopCollector) SetMaxChunkDataPackAttemptsForNextUnsealedHeightAtRequester ¶ added in v0.22.0
func (nc *NoopCollector) SetMaxChunkDataPackAttemptsForNextUnsealedHeightAtRequester(attempts uint64)
func (*NoopCollector) SetQCView ¶
func (nc *NoopCollector) SetQCView(view uint64)
func (*NoopCollector) SetTCView ¶ added in v0.29.0
func (nc *NoopCollector) SetTCView(uint64)
func (*NoopCollector) SetTimeout ¶
func (nc *NoopCollector) SetTimeout(duration time.Duration)
func (*NoopCollector) SetWarningStateCount ¶ added in v0.30.0
func (nc *NoopCollector) SetWarningStateCount(u uint)
func (*NoopCollector) SignerProcessingDuration ¶
func (nc *NoopCollector) SignerProcessingDuration(duration time.Duration)
func (*NoopCollector) StartBlockReceivedToExecuted ¶
func (nc *NoopCollector) StartBlockReceivedToExecuted(blockID flow.Identifier)
func (*NoopCollector) StartBlockToSeal ¶
func (nc *NoopCollector) StartBlockToSeal(blockID flow.Identifier)
func (*NoopCollector) StartCollectionToFinalized ¶
func (nc *NoopCollector) StartCollectionToFinalized(collectionID flow.Identifier)
func (*NoopCollector) TimeoutCollectorsRange ¶ added in v0.32.0
func (nc *NoopCollector) TimeoutCollectorsRange(uint64, uint64, int)
func (*NoopCollector) TimeoutObjectProcessingDuration ¶ added in v0.29.0
func (nc *NoopCollector) TimeoutObjectProcessingDuration(time.Duration)
func (*NoopCollector) TotalConnectionsInPool ¶ added in v0.26.16
func (nc *NoopCollector) TotalConnectionsInPool(connectionCount uint, connectionPoolSize uint)
func (*NoopCollector) TransactionExecuted ¶
func (nc *NoopCollector) TransactionExecuted(txID flow.Identifier, when time.Time)
func (*NoopCollector) TransactionExpired ¶
func (nc *NoopCollector) TransactionExpired(txID flow.Identifier)
func (*NoopCollector) TransactionFinalized ¶
func (nc *NoopCollector) TransactionFinalized(txID flow.Identifier, when time.Time)
func (*NoopCollector) TransactionIngested ¶
func (nc *NoopCollector) TransactionIngested(txID flow.Identifier)
func (*NoopCollector) TransactionReceived ¶
func (nc *NoopCollector) TransactionReceived(txID flow.Identifier, when time.Time)
func (*NoopCollector) TransactionResultFetched ¶ added in v0.26.1
func (nc *NoopCollector) TransactionResultFetched(dur time.Duration, size int)
func (*NoopCollector) TransactionSubmissionFailed ¶
func (nc *NoopCollector) TransactionSubmissionFailed()
func (*NoopCollector) UnicastMessageSendingCompleted ¶ added in v0.29.1
func (nc *NoopCollector) UnicastMessageSendingCompleted(topic string)
func (*NoopCollector) UnicastMessageSendingStarted ¶ added in v0.29.1
func (nc *NoopCollector) UnicastMessageSendingStarted(topic string)
func (*NoopCollector) UnstakedInboundConnections ¶ added in v0.21.1
func (nc *NoopCollector) UnstakedInboundConnections(_ uint)
func (*NoopCollector) UnstakedOutboundConnections ¶ added in v0.21.1
func (nc *NoopCollector) UnstakedOutboundConnections(_ uint)
func (*NoopCollector) UpdateCollectionMaxHeight ¶ added in v0.27.0
func (nc *NoopCollector) UpdateCollectionMaxHeight(height uint64)
func (*NoopCollector) UpdateCount ¶
func (nc *NoopCollector) UpdateCount()
func (*NoopCollector) UpdateDuration ¶
func (nc *NoopCollector) UpdateDuration(duration time.Duration)
func (*NoopCollector) UpdateDurationPerItem ¶
func (nc *NoopCollector) UpdateDurationPerItem(duration time.Duration)
func (*NoopCollector) UpdateExecutionReceiptMaxHeight ¶ added in v0.27.0
func (nc *NoopCollector) UpdateExecutionReceiptMaxHeight(height uint64)
func (*NoopCollector) UpdateLastFullBlockHeight ¶ added in v0.31.0
func (nc *NoopCollector) UpdateLastFullBlockHeight(height uint64)
func (*NoopCollector) UpdateValuesNumber ¶
func (nc *NoopCollector) UpdateValuesNumber(number uint64)
func (*NoopCollector) UpdateValuesSize ¶
func (nc *NoopCollector) UpdateValuesSize(byte uint64)
func (*NoopCollector) ValidatorProcessingDuration ¶
func (nc *NoopCollector) ValidatorProcessingDuration(duration time.Duration)
func (*NoopCollector) VoteProcessingDuration ¶ added in v0.29.0
func (nc *NoopCollector) VoteProcessingDuration(time.Duration)
func (*NoopCollector) Wantlist ¶ added in v0.27.3
func (nc *NoopCollector) Wantlist(prefix string, n int)
type ObserverCollector ¶ added in v0.28.0
type ObserverCollector struct {
// contains filtered or unexported fields
}
func NewObserverCollector ¶ added in v0.28.0
func NewObserverCollector() *ObserverCollector
type ObserverMetrics ¶ added in v0.32.0
type PingCollector ¶
type PingCollector struct {
// contains filtered or unexported fields
}
func NewPingCollector ¶
func NewPingCollector() *PingCollector
func (*PingCollector) NodeReachable ¶
type RateLimitedBlockstoreCollector ¶ added in v0.28.0
type RateLimitedBlockstoreCollector struct {
// contains filtered or unexported fields
}
func (*RateLimitedBlockstoreCollector) BytesRead ¶ added in v0.28.0
func (r *RateLimitedBlockstoreCollector) BytesRead(n int)
type RestCollector ¶ added in v0.29.12
type RestCollector struct {
// contains filtered or unexported fields
}
func NewRestCollector ¶ added in v0.29.12
func NewRestCollector(urlToRouteMapper func(string) (string, error), registerer prometheus.Registerer) (*RestCollector, error)
NewRestCollector returns a new metrics RestCollector that implements the RestCollector using Prometheus as the backend.
func (*RestCollector) AddInflightRequests ¶ added in v0.31.0
func (r *RestCollector) AddInflightRequests(_ context.Context, p httpmetrics.HTTPProperties, quantity int)
AddInflightRequests increments and decrements the number of inflight request being processed. This method is called automatically by go-http-metrics/middleware
func (*RestCollector) AddTotalRequests ¶ added in v0.29.12
func (r *RestCollector) AddTotalRequests(_ context.Context, method, path string)
AddTotalRequests records all REST requests This is a custom method called by the REST handler
func (*RestCollector) ObserveHTTPRequestDuration ¶ added in v0.31.0
func (r *RestCollector) ObserveHTTPRequestDuration(_ context.Context, p httpmetrics.HTTPReqProperties, duration time.Duration)
ObserveHTTPRequestDuration records the duration of the REST request. This method is called automatically by go-http-metrics/middleware
func (*RestCollector) ObserveHTTPResponseSize ¶ added in v0.31.0
func (r *RestCollector) ObserveHTTPResponseSize(_ context.Context, p httpmetrics.HTTPReqProperties, sizeBytes int64)
ObserveHTTPResponseSize records the response size of the REST request. This method is called automatically by go-http-metrics/middleware
type Server ¶
type Server struct {
// contains filtered or unexported fields
}
Server is the http server that will be serving the /metrics request for prometheus
func NewServer ¶
NewServer creates a new server that will start on the specified port, and responds to only the `/metrics` endpoint
type StorageCollector ¶
type StorageCollector struct {
// contains filtered or unexported fields
}
func GetStorageCollector ¶
func GetStorageCollector() *StorageCollector
func (*StorageCollector) RetryOnConflict ¶
func (sc *StorageCollector) RetryOnConflict()
func (*StorageCollector) SkipDuplicate ¶
func (sc *StorageCollector) SkipDuplicate()
type TransactionCollector ¶
type TransactionCollector struct {
// contains filtered or unexported fields
}
func NewTransactionCollector ¶
func NewTransactionCollector( log zerolog.Logger, transactionTimings mempool.TransactionTimings, logTimeToFinalized bool, logTimeToExecuted bool, logTimeToFinalizedExecuted bool, ) *TransactionCollector
func (*TransactionCollector) ScriptExecuted ¶ added in v0.26.1
func (tc *TransactionCollector) ScriptExecuted(dur time.Duration, size int)
func (*TransactionCollector) ScriptExecutionErrorLocal ¶ added in v0.32.2
func (tc *TransactionCollector) ScriptExecutionErrorLocal()
func (*TransactionCollector) ScriptExecutionErrorMatch ¶ added in v0.32.0
func (tc *TransactionCollector) ScriptExecutionErrorMatch()
func (*TransactionCollector) ScriptExecutionErrorMismatch ¶ added in v0.32.0
func (tc *TransactionCollector) ScriptExecutionErrorMismatch()
func (*TransactionCollector) ScriptExecutionErrorOnExecutionNode ¶ added in v0.31.11
func (tc *TransactionCollector) ScriptExecutionErrorOnExecutionNode()
func (*TransactionCollector) ScriptExecutionNotIndexed ¶ added in v0.32.7
func (tc *TransactionCollector) ScriptExecutionNotIndexed()
ScriptExecutionNotIndexed records script execution matches where data for the block is not indexed locally yet
func (*TransactionCollector) ScriptExecutionResultMatch ¶ added in v0.32.0
func (tc *TransactionCollector) ScriptExecutionResultMatch()
func (*TransactionCollector) ScriptExecutionResultMismatch ¶ added in v0.32.0
func (tc *TransactionCollector) ScriptExecutionResultMismatch()
func (*TransactionCollector) TransactionExecuted ¶
func (tc *TransactionCollector) TransactionExecuted(txID flow.Identifier, when time.Time)
func (*TransactionCollector) TransactionExpired ¶
func (tc *TransactionCollector) TransactionExpired(txID flow.Identifier)
func (*TransactionCollector) TransactionFinalized ¶
func (tc *TransactionCollector) TransactionFinalized(txID flow.Identifier, when time.Time)
func (*TransactionCollector) TransactionReceived ¶
func (tc *TransactionCollector) TransactionReceived(txID flow.Identifier, when time.Time)
func (*TransactionCollector) TransactionResultFetched ¶ added in v0.26.1
func (tc *TransactionCollector) TransactionResultFetched(dur time.Duration, size int)
func (*TransactionCollector) TransactionSubmissionFailed ¶
func (tc *TransactionCollector) TransactionSubmissionFailed()
type UnicastManagerMetrics ¶ added in v0.30.0
type UnicastManagerMetrics struct {
// contains filtered or unexported fields
}
UnicastManagerMetrics metrics collector for the unicast manager.
func NewUnicastManagerMetrics ¶ added in v0.30.0
func NewUnicastManagerMetrics(prefix string) *UnicastManagerMetrics
func (*UnicastManagerMetrics) OnDialRetryBudgetResetToDefault ¶ added in v0.32.2
func (u *UnicastManagerMetrics) OnDialRetryBudgetResetToDefault()
OnDialRetryBudgetResetToDefault tracks the number of times the dial retry budget is reset to default.
func (*UnicastManagerMetrics) OnDialRetryBudgetUpdated ¶ added in v0.32.2
func (u *UnicastManagerMetrics) OnDialRetryBudgetUpdated(budget uint64)
OnDialRetryBudgetUpdated tracks the history of the dial retry budget updates.
func (*UnicastManagerMetrics) OnEstablishStreamFailure ¶ added in v0.30.0
func (u *UnicastManagerMetrics) OnEstablishStreamFailure(duration time.Duration, attempts int)
OnEstablishStreamFailure tracks the amount of time taken and number of retry attempts used when the unicast manager cannot establish a stream on the open connection between two peers.
func (*UnicastManagerMetrics) OnPeerDialFailure ¶ added in v0.30.0
func (u *UnicastManagerMetrics) OnPeerDialFailure(duration time.Duration, attempts int)
OnPeerDialFailure tracks the amount of time taken and number of retry attempts used when the unicast manager cannot dial a peer to establish the initial connection between the two.
func (*UnicastManagerMetrics) OnPeerDialed ¶ added in v0.30.0
func (u *UnicastManagerMetrics) OnPeerDialed(duration time.Duration, attempts int)
OnPeerDialed tracks the time it takes to dial a peer during stream creation and the number of retry attempts before a peer is dialed successfully.
func (*UnicastManagerMetrics) OnStreamCreated ¶ added in v0.30.0
func (u *UnicastManagerMetrics) OnStreamCreated(duration time.Duration, attempts int)
OnStreamCreated tracks the overall time taken to create a stream successfully and the number of retry attempts.
func (*UnicastManagerMetrics) OnStreamCreationFailure ¶ added in v0.30.0
func (u *UnicastManagerMetrics) OnStreamCreationFailure(duration time.Duration, attempts int)
OnStreamCreationFailure tracks the overall time taken and number of retry attempts used when the unicast manager fails to create a stream.
func (*UnicastManagerMetrics) OnStreamCreationRetryBudgetResetToDefault ¶ added in v0.32.2
func (u *UnicastManagerMetrics) OnStreamCreationRetryBudgetResetToDefault()
OnStreamCreationRetryBudgetResetToDefault tracks the number of times the stream creation retry budget is reset to default.
func (*UnicastManagerMetrics) OnStreamCreationRetryBudgetUpdated ¶ added in v0.32.2
func (u *UnicastManagerMetrics) OnStreamCreationRetryBudgetUpdated(budget uint64)
OnStreamCreationRetryBudgetUpdated tracks the history of the stream creation retry budget updates.
func (*UnicastManagerMetrics) OnStreamEstablished ¶ added in v0.30.0
func (u *UnicastManagerMetrics) OnStreamEstablished(duration time.Duration, attempts int)
OnStreamEstablished tracks the time it takes to create a stream successfully on the available open connection during stream creation and the number of retry attempts.
type VerificationCollector ¶
type VerificationCollector struct {
// contains filtered or unexported fields
}
func NewVerificationCollector ¶
func NewVerificationCollector(tracer module.Tracer, registerer prometheus.Registerer) *VerificationCollector
func (*VerificationCollector) OnAssignedChunkProcessedAtAssigner ¶ added in v0.17.1
func (vc *VerificationCollector) OnAssignedChunkProcessedAtAssigner()
OnAssignedChunkProcessedAtAssigner increments a counter that keeps track of the total number of assigned chunks pushed by assigner engine to the fetcher engine.
func (*VerificationCollector) OnAssignedChunkReceivedAtFetcher ¶ added in v0.17.1
func (vc *VerificationCollector) OnAssignedChunkReceivedAtFetcher()
OnAssignedChunkReceivedAtFetcher increments a counter that keeps track of number of assigned chunks arrive at fetcher engine.
func (*VerificationCollector) OnBlockConsumerJobDone ¶ added in v0.19.0
func (vc *VerificationCollector) OnBlockConsumerJobDone(processedIndex uint64)
OnBlockConsumerJobDone is invoked by block consumer whenever it is notified a job is done by a worker. It sets the last processed block job index.
func (*VerificationCollector) OnChunkConsumerJobDone ¶ added in v0.19.0
func (vc *VerificationCollector) OnChunkConsumerJobDone(processedIndex uint64)
OnChunkConsumerJobDone is invoked by chunk consumer whenever it is notified a job is done by a worker. It sets the last processed chunk job index.
func (*VerificationCollector) OnChunkDataPackArrivedAtFetcher ¶ added in v0.17.1
func (vc *VerificationCollector) OnChunkDataPackArrivedAtFetcher()
OnChunkDataPackArrivedAtFetcher increments a counter that keeps track of number of chunk data packs arrived at fetcher engine from requester engine.
func (*VerificationCollector) OnChunkDataPackRequestDispatchedInNetworkByRequester ¶ added in v0.19.0
func (vc *VerificationCollector) OnChunkDataPackRequestDispatchedInNetworkByRequester()
OnChunkDataPackRequestDispatchedInNetworkByRequester increments a counter that keeps track of number of chunk data pack requests that the requester engine dispatches in the network (to the execution nodes).
func (*VerificationCollector) OnChunkDataPackRequestReceivedByRequester ¶ added in v0.17.1
func (vc *VerificationCollector) OnChunkDataPackRequestReceivedByRequester()
OnChunkDataPackRequestReceivedByRequester increments a counter that keeps track of number of chunk data pack requests arrive at the requester engine from the fetcher engine.
func (*VerificationCollector) OnChunkDataPackRequestSentByFetcher ¶ added in v0.17.1
func (vc *VerificationCollector) OnChunkDataPackRequestSentByFetcher()
OnChunkDataPackRequestSentByFetcher increments a counter that keeps track of number of chunk data pack requests that fetcher engine sends to requester engine.
func (*VerificationCollector) OnChunkDataPackResponseReceivedFromNetworkByRequester ¶ added in v0.19.0
func (vc *VerificationCollector) OnChunkDataPackResponseReceivedFromNetworkByRequester()
OnChunkDataPackResponseReceivedFromNetworkByRequester increments a counter that keeps track of number of chunk data pack responses that the requester engine receives from execution nodes (through network).
func (*VerificationCollector) OnChunkDataPackSentToFetcher ¶ added in v0.17.1
func (vc *VerificationCollector) OnChunkDataPackSentToFetcher()
OnChunkDataPackSentToFetcher increases a counter that keeps track of number of chunk data packs sent to the fetcher engine from requester engine.
func (*VerificationCollector) OnChunksAssignmentDoneAtAssigner ¶ added in v0.17.1
func (vc *VerificationCollector) OnChunksAssignmentDoneAtAssigner(chunks int)
OnChunksAssignmentDoneAtAssigner increments a counter that keeps track of the total number of assigned chunks to the verification node.
func (*VerificationCollector) OnExecutionResultReceivedAtAssignerEngine ¶ added in v0.19.0
func (vc *VerificationCollector) OnExecutionResultReceivedAtAssignerEngine()
OnExecutionResultReceivedAtAssignerEngine is called whenever a new execution result arrives at Assigner engine. It increments total number of received results.
func (*VerificationCollector) OnFinalizedBlockArrivedAtAssigner ¶ added in v0.17.1
func (vc *VerificationCollector) OnFinalizedBlockArrivedAtAssigner(height uint64)
OnFinalizedBlockArrivedAtAssigner sets a gauge that keeps track of number of the latest block height arrives at assigner engine. Note that it assumes blocks are coming to assigner engine in strictly increasing order of their height.
func (*VerificationCollector) OnResultApprovalDispatchedInNetworkByVerifier ¶ added in v0.19.0
func (vc *VerificationCollector) OnResultApprovalDispatchedInNetworkByVerifier()
OnResultApprovalDispatchedInNetwork is called whenever a result approval for is emitted to consensus nodes. It increases the total number of result approvals.
func (*VerificationCollector) OnVerifiableChunkReceivedAtVerifierEngine ¶ added in v0.17.1
func (vc *VerificationCollector) OnVerifiableChunkReceivedAtVerifierEngine()
OnVerifiableChunkReceivedAtVerifierEngine is called whenever a verifiable chunk is received by Verifier engine from Assigner engine.It increments the total number of sent verifiable chunks.
func (*VerificationCollector) OnVerifiableChunkSentToVerifier ¶ added in v0.17.1
func (vc *VerificationCollector) OnVerifiableChunkSentToVerifier()
OnVerifiableChunkSentToVerifier increments a counter that keeps track of number of verifiable chunks fetcher engine sent to verifier engine.
func (*VerificationCollector) SetMaxChunkDataPackAttemptsForNextUnsealedHeightAtRequester ¶ added in v0.22.0
func (vc *VerificationCollector) SetMaxChunkDataPackAttemptsForNextUnsealedHeightAtRequester(attempts uint64)
SetMaxChunkDataPackAttemptsForNextUnsealedHeightAtRequester is invoked when a cycle of requesting chunk data packs is done by requester engine. It updates the maximum number of attempts made by requester engine for requesting the chunk data packs of the next unsealed height. The maximum is taken over the history of all chunk data packs requested during that cycle that belong to the next unsealed height.
Source Files ¶
- access.go
- alsp.go
- badger.go
- bitswap.go
- cache.go
- chainsync.go
- cleaner.go
- collection.go
- compliance.go
- consensus.go
- cruisectl.go
- engine.go
- execution.go
- execution_data_requester.go
- execution_data_sync.go
- execution_state_indexer.go
- gossipsub.go
- gossipsub_rpc_validation_inspector.go
- gossipsub_score.go
- herocache.go
- hotstuff.go
- labels.go
- libp2p_resource_manager.go
- loader.go
- mempool.go
- namespaces.go
- network.go
- node_info.go
- noop.go
- observer.go
- ping.go
- rate_limited_blockstore.go
- rest_api.go
- server.go
- storage.go
- transaction.go
- unicast_manager.go
- verification.go