Documentation ¶
Index ¶
- type AccessMetrics
- func (_m *AccessMetrics) AddInflightRequests(ctx context.Context, props metrics.HTTPProperties, quantity int)
- func (_m *AccessMetrics) AddTotalRequests(ctx context.Context, method string, routeName string)
- func (_m *AccessMetrics) ConnectionAddedToPool()
- func (_m *AccessMetrics) ConnectionFromPoolEvicted()
- func (_m *AccessMetrics) ConnectionFromPoolInvalidated()
- func (_m *AccessMetrics) ConnectionFromPoolReused()
- func (_m *AccessMetrics) ConnectionFromPoolUpdated()
- func (_m *AccessMetrics) NewConnectionEstablished()
- func (_m *AccessMetrics) ObserveHTTPRequestDuration(ctx context.Context, props metrics.HTTPReqProperties, duration time.Duration)
- func (_m *AccessMetrics) ObserveHTTPResponseSize(ctx context.Context, props metrics.HTTPReqProperties, sizeBytes int64)
- func (_m *AccessMetrics) ScriptExecuted(dur time.Duration, size int)
- func (_m *AccessMetrics) ScriptExecutionErrorLocal()
- func (_m *AccessMetrics) ScriptExecutionErrorMatch()
- func (_m *AccessMetrics) ScriptExecutionErrorMismatch()
- func (_m *AccessMetrics) ScriptExecutionErrorOnExecutionNode()
- func (_m *AccessMetrics) ScriptExecutionNotIndexed()
- func (_m *AccessMetrics) ScriptExecutionResultMatch()
- func (_m *AccessMetrics) ScriptExecutionResultMismatch()
- func (_m *AccessMetrics) TotalConnectionsInPool(connectionCount uint, connectionPoolSize uint)
- func (_m *AccessMetrics) TransactionExecuted(txID flow.Identifier, when time.Time)
- func (_m *AccessMetrics) TransactionExpired(txID flow.Identifier)
- func (_m *AccessMetrics) TransactionFinalized(txID flow.Identifier, when time.Time)
- func (_m *AccessMetrics) TransactionReceived(txID flow.Identifier, when time.Time)
- func (_m *AccessMetrics) TransactionResultFetched(dur time.Duration, size int)
- func (_m *AccessMetrics) TransactionSubmissionFailed()
- func (_m *AccessMetrics) UpdateExecutionReceiptMaxHeight(height uint64)
- func (_m *AccessMetrics) UpdateLastFullBlockHeight(height uint64)
- type AlspMetrics
- type BackendScriptsMetrics
- func (_m *BackendScriptsMetrics) ScriptExecuted(dur time.Duration, size int)
- func (_m *BackendScriptsMetrics) ScriptExecutionErrorLocal()
- func (_m *BackendScriptsMetrics) ScriptExecutionErrorMatch()
- func (_m *BackendScriptsMetrics) ScriptExecutionErrorMismatch()
- func (_m *BackendScriptsMetrics) ScriptExecutionErrorOnExecutionNode()
- func (_m *BackendScriptsMetrics) ScriptExecutionNotIndexed()
- func (_m *BackendScriptsMetrics) ScriptExecutionResultMatch()
- func (_m *BackendScriptsMetrics) ScriptExecutionResultMismatch()
- type BitswapMetrics
- func (_m *BitswapMetrics) BlobsReceived(prefix string, n uint64)
- func (_m *BitswapMetrics) BlobsSent(prefix string, n uint64)
- func (_m *BitswapMetrics) DataReceived(prefix string, n uint64)
- func (_m *BitswapMetrics) DataSent(prefix string, n uint64)
- func (_m *BitswapMetrics) DupBlobsReceived(prefix string, n uint64)
- func (_m *BitswapMetrics) DupDataReceived(prefix string, n uint64)
- func (_m *BitswapMetrics) MessagesReceived(prefix string, n uint64)
- func (_m *BitswapMetrics) Peers(prefix string, n int)
- func (_m *BitswapMetrics) Wantlist(prefix string, n int)
- type BlockRequester
- type Builder
- type CacheMetrics
- type ChainSyncMetrics
- func (_m *ChainSyncMetrics) BatchRequested(batch chainsync.Batch)
- func (_m *ChainSyncMetrics) PrunedBlockByHeight(status *chainsync.Status)
- func (_m *ChainSyncMetrics) PrunedBlockById(status *chainsync.Status)
- func (_m *ChainSyncMetrics) PrunedBlocks(totalByHeight int, totalById int, storedByHeight int, storedById int)
- func (_m *ChainSyncMetrics) RangeRequested(ran chainsync.Range)
- type ChunkAssigner
- type ChunkVerifier
- type CleanerMetrics
- type ClusterRootQCVoter
- type CollectionExecutedMetric
- func (_m *CollectionExecutedMetric) BlockFinalized(block *flow.Block)
- func (_m *CollectionExecutedMetric) CollectionExecuted(light flow.LightCollection)
- func (_m *CollectionExecutedMetric) CollectionFinalized(light flow.LightCollection)
- func (_m *CollectionExecutedMetric) ExecutionReceiptReceived(r *flow.ExecutionReceipt)
- func (_m *CollectionExecutedMetric) UpdateLastFullBlockHeight(height uint64)
- type CollectionMetrics
- type ComplianceMetrics
- func (_m *ComplianceMetrics) BlockFinalized(_a0 *flow.Block)
- func (_m *ComplianceMetrics) BlockSealed(_a0 *flow.Block)
- func (_m *ComplianceMetrics) CurrentDKGPhaseViews(phase1FinalView uint64, phase2FinalView uint64, phase3FinalView uint64)
- func (_m *ComplianceMetrics) CurrentEpochCounter(counter uint64)
- func (_m *ComplianceMetrics) CurrentEpochFinalView(view uint64)
- func (_m *ComplianceMetrics) CurrentEpochPhase(phase flow.EpochPhase)
- func (_m *ComplianceMetrics) EpochFallbackModeExited()
- func (_m *ComplianceMetrics) EpochFallbackModeTriggered()
- func (_m *ComplianceMetrics) EpochTransitionHeight(height uint64)
- func (_m *ComplianceMetrics) FinalizedHeight(height uint64)
- func (_m *ComplianceMetrics) SealedHeight(height uint64)
- type ConsensusMetrics
- func (_m *ConsensusMetrics) CheckSealingDuration(duration time.Duration)
- func (_m *ConsensusMetrics) EmergencySeal()
- func (_m *ConsensusMetrics) FinishBlockToSeal(blockID flow.Identifier)
- func (_m *ConsensusMetrics) FinishCollectionToFinalized(collectionID flow.Identifier)
- func (_m *ConsensusMetrics) OnApprovalProcessingDuration(duration time.Duration)
- func (_m *ConsensusMetrics) OnReceiptProcessingDuration(duration time.Duration)
- func (_m *ConsensusMetrics) StartBlockToSeal(blockID flow.Identifier)
- func (_m *ConsensusMetrics) StartCollectionToFinalized(collectionID flow.Identifier)
- type CruiseCtlMetrics
- type DHTMetrics
- type DKGBroker
- func (_m *DKGBroker) Broadcast(data []byte)
- func (_m *DKGBroker) Disqualify(participant int, log string)
- func (_m *DKGBroker) FlagMisbehavior(participant int, log string)
- func (_m *DKGBroker) GetBroadcastMsgCh() <-chan messages.BroadcastDKGMessage
- func (_m *DKGBroker) GetIndex() int
- func (_m *DKGBroker) GetPrivateMsgCh() <-chan messages.PrivDKGMessageIn
- func (_m *DKGBroker) Poll(referenceBlock flow.Identifier) error
- func (_m *DKGBroker) PrivateSend(dest int, data []byte)
- func (_m *DKGBroker) Shutdown()
- func (_m *DKGBroker) SubmitResult(_a0 crypto.PublicKey, _a1 []crypto.PublicKey) error
- type DKGContractClient
- func (_m *DKGContractClient) Broadcast(msg messages.BroadcastDKGMessage) error
- func (_m *DKGContractClient) ReadBroadcast(fromIndex uint, referenceBlock flow.Identifier) ([]messages.BroadcastDKGMessage, error)
- func (_m *DKGContractClient) SubmitResult(_a0 crypto.PublicKey, _a1 []crypto.PublicKey) error
- type DKGController
- func (_m *DKGController) End() error
- func (_m *DKGController) EndPhase1() error
- func (_m *DKGController) EndPhase2() error
- func (_m *DKGController) GetArtifacts() (crypto.PrivateKey, crypto.PublicKey, []crypto.PublicKey)
- func (_m *DKGController) GetIndex() int
- func (_m *DKGController) Poll(blockReference flow.Identifier) error
- func (_m *DKGController) Run() error
- func (_m *DKGController) Shutdown()
- func (_m *DKGController) SubmitResult() error
- type DKGControllerFactory
- type EVMMetrics
- type EngineMetrics
- func (_m *EngineMetrics) InboundMessageDropped(engine string, messages string)
- func (_m *EngineMetrics) MessageHandled(engine string, messages string)
- func (_m *EngineMetrics) MessageReceived(engine string, message string)
- func (_m *EngineMetrics) MessageSent(engine string, message string)
- func (_m *EngineMetrics) OutboundMessageDropped(engine string, messages string)
- type EntriesFunc
- type EpochLookup
- type ExecutionDataProviderMetrics
- type ExecutionDataPrunerMetrics
- type ExecutionDataRequesterMetrics
- func (_m *ExecutionDataRequesterMetrics) ExecutionDataFetchFinished(duration time.Duration, success bool, height uint64)
- func (_m *ExecutionDataRequesterMetrics) ExecutionDataFetchStarted()
- func (_m *ExecutionDataRequesterMetrics) FetchRetried()
- func (_m *ExecutionDataRequesterMetrics) NotificationSent(height uint64)
- type ExecutionDataRequesterV2Metrics
- func (_m *ExecutionDataRequesterV2Metrics) FulfilledHeight(blockHeight uint64)
- func (_m *ExecutionDataRequesterV2Metrics) ReceiptSkipped()
- func (_m *ExecutionDataRequesterV2Metrics) RequestCanceled()
- func (_m *ExecutionDataRequesterV2Metrics) RequestFailed(duration time.Duration, retryable bool)
- func (_m *ExecutionDataRequesterV2Metrics) RequestSucceeded(blockHeight uint64, duration time.Duration, totalSize uint64, ...)
- func (_m *ExecutionDataRequesterV2Metrics) ResponseDropped()
- type ExecutionMetrics
- func (_m *ExecutionMetrics) ChunkDataPackRequestProcessed()
- func (_m *ExecutionMetrics) EVMBlockExecuted(txCount int, totalGasUsed uint64, totalSupplyInFlow float64)
- func (_m *ExecutionMetrics) EVMTransactionExecuted(gasUsed uint64, isDirectCall bool, failed bool)
- func (_m *ExecutionMetrics) ExecutionBlockCachedPrograms(programs int)
- func (_m *ExecutionMetrics) ExecutionBlockDataUploadFinished(dur time.Duration)
- func (_m *ExecutionMetrics) ExecutionBlockDataUploadStarted()
- func (_m *ExecutionMetrics) ExecutionBlockExecuted(dur time.Duration, stats module.BlockExecutionResultStats)
- func (_m *ExecutionMetrics) ExecutionBlockExecutionEffortVectorComponent(_a0 string, _a1 uint)
- func (_m *ExecutionMetrics) ExecutionCheckpointSize(bytes uint64)
- func (_m *ExecutionMetrics) ExecutionChunkDataPackGenerated(proofSize int, numberOfTransactions int)
- func (_m *ExecutionMetrics) ExecutionCollectionExecuted(dur time.Duration, stats module.CollectionExecutionResultStats)
- func (_m *ExecutionMetrics) ExecutionCollectionRequestRetried()
- func (_m *ExecutionMetrics) ExecutionCollectionRequestSent()
- func (_m *ExecutionMetrics) ExecutionComputationResultUploadRetried()
- func (_m *ExecutionMetrics) ExecutionComputationResultUploaded()
- func (_m *ExecutionMetrics) ExecutionLastExecutedBlockHeight(height uint64)
- func (_m *ExecutionMetrics) ExecutionLastFinalizedExecutedBlockHeight(height uint64)
- func (_m *ExecutionMetrics) ExecutionScriptExecuted(dur time.Duration, compUsed uint64, memoryUsed uint64, memoryEstimate uint64)
- func (_m *ExecutionMetrics) ExecutionStorageStateCommitment(bytes int64)
- func (_m *ExecutionMetrics) ExecutionSync(syncing bool)
- func (_m *ExecutionMetrics) ExecutionTransactionExecuted(dur time.Duration, stats module.TransactionExecutionResultStats, ...)
- func (_m *ExecutionMetrics) FinishBlockReceivedToExecuted(blockID flow.Identifier)
- func (_m *ExecutionMetrics) ForestApproxMemorySize(bytes uint64)
- func (_m *ExecutionMetrics) ForestNumberOfTrees(number uint64)
- func (_m *ExecutionMetrics) LatestTrieMaxDepthTouched(maxDepth uint16)
- func (_m *ExecutionMetrics) LatestTrieRegCount(number uint64)
- func (_m *ExecutionMetrics) LatestTrieRegCountDiff(number int64)
- func (_m *ExecutionMetrics) LatestTrieRegSize(size uint64)
- func (_m *ExecutionMetrics) LatestTrieRegSizeDiff(size int64)
- func (_m *ExecutionMetrics) ProofSize(bytes uint32)
- func (_m *ExecutionMetrics) ReadDuration(duration time.Duration)
- func (_m *ExecutionMetrics) ReadDurationPerItem(duration time.Duration)
- func (_m *ExecutionMetrics) ReadValuesNumber(number uint64)
- func (_m *ExecutionMetrics) ReadValuesSize(byte uint64)
- func (_m *ExecutionMetrics) RuntimeSetNumberOfAccounts(count uint64)
- func (_m *ExecutionMetrics) RuntimeTransactionChecked(dur time.Duration)
- func (_m *ExecutionMetrics) RuntimeTransactionInterpreted(dur time.Duration)
- func (_m *ExecutionMetrics) RuntimeTransactionParsed(dur time.Duration)
- func (_m *ExecutionMetrics) RuntimeTransactionProgramsCacheHit()
- func (_m *ExecutionMetrics) RuntimeTransactionProgramsCacheMiss()
- func (_m *ExecutionMetrics) SetNumberOfDeployedCOAs(count uint64)
- func (_m *ExecutionMetrics) StartBlockReceivedToExecuted(blockID flow.Identifier)
- func (_m *ExecutionMetrics) UpdateCollectionMaxHeight(height uint64)
- func (_m *ExecutionMetrics) UpdateCount()
- func (_m *ExecutionMetrics) UpdateDuration(duration time.Duration)
- func (_m *ExecutionMetrics) UpdateDurationPerItem(duration time.Duration)
- func (_m *ExecutionMetrics) UpdateValuesNumber(number uint64)
- func (_m *ExecutionMetrics) UpdateValuesSize(byte uint64)
- type ExecutionStateIndexerMetrics
- type FinalizedHeaderCache
- type Finalizer
- type GRPCConnectionPoolMetrics
- func (_m *GRPCConnectionPoolMetrics) ConnectionAddedToPool()
- func (_m *GRPCConnectionPoolMetrics) ConnectionFromPoolEvicted()
- func (_m *GRPCConnectionPoolMetrics) ConnectionFromPoolInvalidated()
- func (_m *GRPCConnectionPoolMetrics) ConnectionFromPoolReused()
- func (_m *GRPCConnectionPoolMetrics) ConnectionFromPoolUpdated()
- func (_m *GRPCConnectionPoolMetrics) NewConnectionEstablished()
- func (_m *GRPCConnectionPoolMetrics) TotalConnectionsInPool(connectionCount uint, connectionPoolSize uint)
- type GossipSubMetrics
- func (_m *GossipSubMetrics) AsyncProcessingFinished(duration time.Duration)
- func (_m *GossipSubMetrics) AsyncProcessingStarted()
- func (_m *GossipSubMetrics) OnActiveClusterIDsNotSetErr()
- func (_m *GossipSubMetrics) OnAppSpecificScoreUpdated(_a0 float64)
- func (_m *GossipSubMetrics) OnBehaviourPenaltyUpdated(_a0 float64)
- func (_m *GossipSubMetrics) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
- func (_m *GossipSubMetrics) OnFirstMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *GossipSubMetrics) OnGraftDuplicateTopicIdsExceedThreshold()
- func (_m *GossipSubMetrics) OnGraftInvalidTopicIdsExceedThreshold()
- func (_m *GossipSubMetrics) OnGraftMessageInspected(duplicateTopicIds int, invalidTopicIds int)
- func (_m *GossipSubMetrics) OnIHaveControlMessageIdsTruncated(diff int)
- func (_m *GossipSubMetrics) OnIHaveDuplicateMessageIdsExceedThreshold()
- func (_m *GossipSubMetrics) OnIHaveDuplicateTopicIdsExceedThreshold()
- func (_m *GossipSubMetrics) OnIHaveInvalidTopicIdsExceedThreshold()
- func (_m *GossipSubMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
- func (_m *GossipSubMetrics) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int, invalidTopicIds int)
- func (_m *GossipSubMetrics) OnIPColocationFactorUpdated(_a0 float64)
- func (_m *GossipSubMetrics) OnIWantCacheMissMessageIdsExceedThreshold()
- func (_m *GossipSubMetrics) OnIWantControlMessageIdsTruncated(diff int)
- func (_m *GossipSubMetrics) OnIWantDuplicateMessageIdsExceedThreshold()
- func (_m *GossipSubMetrics) OnIWantMessageIDsReceived(msgIdCount int)
- func (_m *GossipSubMetrics) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
- func (_m *GossipSubMetrics) OnIncomingRpcReceived(iHaveCount int, iWantCount int, graftCount int, pruneCount int, msgCount int)
- func (_m *GossipSubMetrics) OnInvalidControlMessageNotificationSent()
- func (_m *GossipSubMetrics) OnInvalidMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *GossipSubMetrics) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
- func (_m *GossipSubMetrics) OnLocalMeshSizeUpdated(topic string, size int)
- func (_m *GossipSubMetrics) OnLocalPeerJoinedTopic()
- func (_m *GossipSubMetrics) OnLocalPeerLeftTopic()
- func (_m *GossipSubMetrics) OnMeshMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *GossipSubMetrics) OnMessageDeliveredToAllSubscribers(size int)
- func (_m *GossipSubMetrics) OnMessageDuplicate(size int)
- func (_m *GossipSubMetrics) OnMessageEnteredValidation(size int)
- func (_m *GossipSubMetrics) OnMessageRejected(size int, reason string)
- func (_m *GossipSubMetrics) OnOutboundRpcDropped()
- func (_m *GossipSubMetrics) OnOverallPeerScoreUpdated(_a0 float64)
- func (_m *GossipSubMetrics) OnPeerAddedToProtocol(protocol string)
- func (_m *GossipSubMetrics) OnPeerGraftTopic(topic string)
- func (_m *GossipSubMetrics) OnPeerPruneTopic(topic string)
- func (_m *GossipSubMetrics) OnPeerRemovedFromProtocol()
- func (_m *GossipSubMetrics) OnPeerThrottled()
- func (_m *GossipSubMetrics) OnPruneDuplicateTopicIdsExceedThreshold()
- func (_m *GossipSubMetrics) OnPruneInvalidTopicIdsExceedThreshold()
- func (_m *GossipSubMetrics) OnPruneMessageInspected(duplicateTopicIds int, invalidTopicIds int)
- func (_m *GossipSubMetrics) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, ...)
- func (_m *GossipSubMetrics) OnPublishMessagesInspectionErrorExceedsThreshold()
- func (_m *GossipSubMetrics) OnRpcReceived(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (_m *GossipSubMetrics) OnRpcRejectedFromUnknownSender()
- func (_m *GossipSubMetrics) OnRpcSent(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (_m *GossipSubMetrics) OnTimeInMeshUpdated(_a0 channels.Topic, _a1 time.Duration)
- func (_m *GossipSubMetrics) OnUndeliveredMessage()
- func (_m *GossipSubMetrics) OnUnstakedPeerInspectionFailed()
- func (_m *GossipSubMetrics) SetWarningStateCount(_a0 uint)
- type GossipSubRpcInspectorMetrics
- func (_m *GossipSubRpcInspectorMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
- func (_m *GossipSubRpcInspectorMetrics) OnIWantMessageIDsReceived(msgIdCount int)
- func (_m *GossipSubRpcInspectorMetrics) OnIncomingRpcReceived(iHaveCount int, iWantCount int, graftCount int, pruneCount int, msgCount int)
- type GossipSubRpcValidationInspectorMetrics
- func (_m *GossipSubRpcValidationInspectorMetrics) AsyncProcessingFinished(duration time.Duration)
- func (_m *GossipSubRpcValidationInspectorMetrics) AsyncProcessingStarted()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnActiveClusterIDsNotSetErr()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnGraftDuplicateTopicIdsExceedThreshold()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnGraftInvalidTopicIdsExceedThreshold()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnGraftMessageInspected(duplicateTopicIds int, invalidTopicIds int)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveControlMessageIdsTruncated(diff int)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateMessageIdsExceedThreshold()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateTopicIdsExceedThreshold()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveInvalidTopicIdsExceedThreshold()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int, invalidTopicIds int)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIWantCacheMissMessageIdsExceedThreshold()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIWantControlMessageIdsTruncated(diff int)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIWantDuplicateMessageIdsExceedThreshold()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIWantMessageIDsReceived(msgIdCount int)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnIncomingRpcReceived(iHaveCount int, iWantCount int, graftCount int, pruneCount int, msgCount int)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnInvalidControlMessageNotificationSent()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnPruneDuplicateTopicIdsExceedThreshold()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnPruneInvalidTopicIdsExceedThreshold()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnPruneMessageInspected(duplicateTopicIds int, invalidTopicIds int)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, ...)
- func (_m *GossipSubRpcValidationInspectorMetrics) OnPublishMessagesInspectionErrorExceedsThreshold()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnRpcRejectedFromUnknownSender()
- func (_m *GossipSubRpcValidationInspectorMetrics) OnUnstakedPeerInspectionFailed()
- type GossipSubScoringMetrics
- func (_m *GossipSubScoringMetrics) OnAppSpecificScoreUpdated(_a0 float64)
- func (_m *GossipSubScoringMetrics) OnBehaviourPenaltyUpdated(_a0 float64)
- func (_m *GossipSubScoringMetrics) OnFirstMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *GossipSubScoringMetrics) OnIPColocationFactorUpdated(_a0 float64)
- func (_m *GossipSubScoringMetrics) OnInvalidMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *GossipSubScoringMetrics) OnMeshMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *GossipSubScoringMetrics) OnOverallPeerScoreUpdated(_a0 float64)
- func (_m *GossipSubScoringMetrics) OnTimeInMeshUpdated(_a0 channels.Topic, _a1 time.Duration)
- func (_m *GossipSubScoringMetrics) SetWarningStateCount(_a0 uint)
- type GossipSubScoringRegistryMetrics
- type HeroCacheMetrics
- func (_m *HeroCacheMetrics) BucketAvailableSlots(_a0 uint64, _a1 uint64)
- func (_m *HeroCacheMetrics) OnEntityEjectionDueToEmergency()
- func (_m *HeroCacheMetrics) OnEntityEjectionDueToFullCapacity()
- func (_m *HeroCacheMetrics) OnKeyGetFailure()
- func (_m *HeroCacheMetrics) OnKeyGetSuccess()
- func (_m *HeroCacheMetrics) OnKeyPutAttempt(size uint32)
- func (_m *HeroCacheMetrics) OnKeyPutDeduplicated()
- func (_m *HeroCacheMetrics) OnKeyPutDrop()
- func (_m *HeroCacheMetrics) OnKeyPutSuccess(size uint32)
- func (_m *HeroCacheMetrics) OnKeyRemoved(size uint32)
- type HotStuff
- type HotStuffFollower
- type HotstuffMetrics
- func (_m *HotstuffMetrics) BlockProcessingDuration(duration time.Duration)
- func (_m *HotstuffMetrics) CommitteeProcessingDuration(duration time.Duration)
- func (_m *HotstuffMetrics) CountSkipped()
- func (_m *HotstuffMetrics) CountTimeout()
- func (_m *HotstuffMetrics) HotStuffBusyDuration(duration time.Duration, event string)
- func (_m *HotstuffMetrics) HotStuffIdleDuration(duration time.Duration)
- func (_m *HotstuffMetrics) HotStuffWaitDuration(duration time.Duration, event string)
- func (_m *HotstuffMetrics) PayloadProductionDuration(duration time.Duration)
- func (_m *HotstuffMetrics) SetCurView(view uint64)
- func (_m *HotstuffMetrics) SetQCView(view uint64)
- func (_m *HotstuffMetrics) SetTCView(view uint64)
- func (_m *HotstuffMetrics) SetTimeout(duration time.Duration)
- func (_m *HotstuffMetrics) SignerProcessingDuration(duration time.Duration)
- func (_m *HotstuffMetrics) TimeoutCollectorsRange(lowestRetainedView uint64, newestViewCreatedCollector uint64, ...)
- func (_m *HotstuffMetrics) TimeoutObjectProcessingDuration(duration time.Duration)
- func (_m *HotstuffMetrics) ValidatorProcessingDuration(duration time.Duration)
- func (_m *HotstuffMetrics) VoteProcessingDuration(duration time.Duration)
- type IdentifierProvider
- type IdentityProvider
- type Job
- type JobConsumer
- type JobQueue
- type Jobs
- type LedgerMetrics
- func (_m *LedgerMetrics) ForestApproxMemorySize(bytes uint64)
- func (_m *LedgerMetrics) ForestNumberOfTrees(number uint64)
- func (_m *LedgerMetrics) LatestTrieMaxDepthTouched(maxDepth uint16)
- func (_m *LedgerMetrics) LatestTrieRegCount(number uint64)
- func (_m *LedgerMetrics) LatestTrieRegCountDiff(number int64)
- func (_m *LedgerMetrics) LatestTrieRegSize(size uint64)
- func (_m *LedgerMetrics) LatestTrieRegSizeDiff(size int64)
- func (_m *LedgerMetrics) ProofSize(bytes uint32)
- func (_m *LedgerMetrics) ReadDuration(duration time.Duration)
- func (_m *LedgerMetrics) ReadDurationPerItem(duration time.Duration)
- func (_m *LedgerMetrics) ReadValuesNumber(number uint64)
- func (_m *LedgerMetrics) ReadValuesSize(byte uint64)
- func (_m *LedgerMetrics) UpdateCount()
- func (_m *LedgerMetrics) UpdateDuration(duration time.Duration)
- func (_m *LedgerMetrics) UpdateDurationPerItem(duration time.Duration)
- func (_m *LedgerMetrics) UpdateValuesNumber(number uint64)
- func (_m *LedgerMetrics) UpdateValuesSize(byte uint64)
- type LibP2PConnectionMetrics
- type LibP2PMetrics
- func (_m *LibP2PMetrics) AllowConn(dir network.Direction, usefd bool)
- func (_m *LibP2PMetrics) AllowMemory(size int)
- func (_m *LibP2PMetrics) AllowPeer(p peer.ID)
- func (_m *LibP2PMetrics) AllowProtocol(proto protocol.ID)
- func (_m *LibP2PMetrics) AllowService(svc string)
- func (_m *LibP2PMetrics) AllowStream(p peer.ID, dir network.Direction)
- func (_m *LibP2PMetrics) AsyncProcessingFinished(duration time.Duration)
- func (_m *LibP2PMetrics) AsyncProcessingStarted()
- func (_m *LibP2PMetrics) BlockConn(dir network.Direction, usefd bool)
- func (_m *LibP2PMetrics) BlockMemory(size int)
- func (_m *LibP2PMetrics) BlockPeer(p peer.ID)
- func (_m *LibP2PMetrics) BlockProtocol(proto protocol.ID)
- func (_m *LibP2PMetrics) BlockProtocolPeer(proto protocol.ID, p peer.ID)
- func (_m *LibP2PMetrics) BlockService(svc string)
- func (_m *LibP2PMetrics) BlockServicePeer(svc string, p peer.ID)
- func (_m *LibP2PMetrics) BlockStream(p peer.ID, dir network.Direction)
- func (_m *LibP2PMetrics) DNSLookupDuration(duration time.Duration)
- func (_m *LibP2PMetrics) DuplicateMessagePenalties(penalty float64)
- func (_m *LibP2PMetrics) DuplicateMessagesCounts(count float64)
- func (_m *LibP2PMetrics) InboundConnections(connectionCount uint)
- func (_m *LibP2PMetrics) OnActiveClusterIDsNotSetErr()
- func (_m *LibP2PMetrics) OnAppSpecificScoreUpdated(_a0 float64)
- func (_m *LibP2PMetrics) OnBehaviourPenaltyUpdated(_a0 float64)
- func (_m *LibP2PMetrics) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
- func (_m *LibP2PMetrics) OnDNSCacheHit()
- func (_m *LibP2PMetrics) OnDNSCacheInvalidated()
- func (_m *LibP2PMetrics) OnDNSCacheMiss()
- func (_m *LibP2PMetrics) OnDNSLookupRequestDropped()
- func (_m *LibP2PMetrics) OnDialRetryBudgetResetToDefault()
- func (_m *LibP2PMetrics) OnDialRetryBudgetUpdated(budget uint64)
- func (_m *LibP2PMetrics) OnEstablishStreamFailure(duration time.Duration, attempts int)
- func (_m *LibP2PMetrics) OnFirstMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *LibP2PMetrics) OnGraftDuplicateTopicIdsExceedThreshold()
- func (_m *LibP2PMetrics) OnGraftInvalidTopicIdsExceedThreshold()
- func (_m *LibP2PMetrics) OnGraftMessageInspected(duplicateTopicIds int, invalidTopicIds int)
- func (_m *LibP2PMetrics) OnIHaveControlMessageIdsTruncated(diff int)
- func (_m *LibP2PMetrics) OnIHaveDuplicateMessageIdsExceedThreshold()
- func (_m *LibP2PMetrics) OnIHaveDuplicateTopicIdsExceedThreshold()
- func (_m *LibP2PMetrics) OnIHaveInvalidTopicIdsExceedThreshold()
- func (_m *LibP2PMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
- func (_m *LibP2PMetrics) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int, invalidTopicIds int)
- func (_m *LibP2PMetrics) OnIPColocationFactorUpdated(_a0 float64)
- func (_m *LibP2PMetrics) OnIWantCacheMissMessageIdsExceedThreshold()
- func (_m *LibP2PMetrics) OnIWantControlMessageIdsTruncated(diff int)
- func (_m *LibP2PMetrics) OnIWantDuplicateMessageIdsExceedThreshold()
- func (_m *LibP2PMetrics) OnIWantMessageIDsReceived(msgIdCount int)
- func (_m *LibP2PMetrics) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
- func (_m *LibP2PMetrics) OnIncomingRpcReceived(iHaveCount int, iWantCount int, graftCount int, pruneCount int, msgCount int)
- func (_m *LibP2PMetrics) OnInvalidControlMessageNotificationSent()
- func (_m *LibP2PMetrics) OnInvalidMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *LibP2PMetrics) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
- func (_m *LibP2PMetrics) OnLocalMeshSizeUpdated(topic string, size int)
- func (_m *LibP2PMetrics) OnLocalPeerJoinedTopic()
- func (_m *LibP2PMetrics) OnLocalPeerLeftTopic()
- func (_m *LibP2PMetrics) OnMeshMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *LibP2PMetrics) OnMessageDeliveredToAllSubscribers(size int)
- func (_m *LibP2PMetrics) OnMessageDuplicate(size int)
- func (_m *LibP2PMetrics) OnMessageEnteredValidation(size int)
- func (_m *LibP2PMetrics) OnMessageRejected(size int, reason string)
- func (_m *LibP2PMetrics) OnOutboundRpcDropped()
- func (_m *LibP2PMetrics) OnOverallPeerScoreUpdated(_a0 float64)
- func (_m *LibP2PMetrics) OnPeerAddedToProtocol(_a0 string)
- func (_m *LibP2PMetrics) OnPeerDialFailure(duration time.Duration, attempts int)
- func (_m *LibP2PMetrics) OnPeerDialed(duration time.Duration, attempts int)
- func (_m *LibP2PMetrics) OnPeerGraftTopic(topic string)
- func (_m *LibP2PMetrics) OnPeerPruneTopic(topic string)
- func (_m *LibP2PMetrics) OnPeerRemovedFromProtocol()
- func (_m *LibP2PMetrics) OnPeerThrottled()
- func (_m *LibP2PMetrics) OnPruneDuplicateTopicIdsExceedThreshold()
- func (_m *LibP2PMetrics) OnPruneInvalidTopicIdsExceedThreshold()
- func (_m *LibP2PMetrics) OnPruneMessageInspected(duplicateTopicIds int, invalidTopicIds int)
- func (_m *LibP2PMetrics) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, ...)
- func (_m *LibP2PMetrics) OnPublishMessagesInspectionErrorExceedsThreshold()
- func (_m *LibP2PMetrics) OnRpcReceived(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (_m *LibP2PMetrics) OnRpcRejectedFromUnknownSender()
- func (_m *LibP2PMetrics) OnRpcSent(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (_m *LibP2PMetrics) OnStreamCreated(duration time.Duration, attempts int)
- func (_m *LibP2PMetrics) OnStreamCreationFailure(duration time.Duration, attempts int)
- func (_m *LibP2PMetrics) OnStreamCreationRetryBudgetResetToDefault()
- func (_m *LibP2PMetrics) OnStreamCreationRetryBudgetUpdated(budget uint64)
- func (_m *LibP2PMetrics) OnStreamEstablished(duration time.Duration, attempts int)
- func (_m *LibP2PMetrics) OnTimeInMeshUpdated(_a0 channels.Topic, _a1 time.Duration)
- func (_m *LibP2PMetrics) OnUndeliveredMessage()
- func (_m *LibP2PMetrics) OnUnstakedPeerInspectionFailed()
- func (_m *LibP2PMetrics) OutboundConnections(connectionCount uint)
- func (_m *LibP2PMetrics) RoutingTablePeerAdded()
- func (_m *LibP2PMetrics) RoutingTablePeerRemoved()
- func (_m *LibP2PMetrics) SetWarningStateCount(_a0 uint)
- type Local
- func (_m *Local) Address() string
- func (_m *Local) NodeID() flow.Identifier
- func (_m *Local) NotMeFilter() flow.IdentityFilter[flow.Identity]
- func (_m *Local) Sign(_a0 []byte, _a1 hash.Hasher) (crypto.Signature, error)
- func (_m *Local) SignFunc(_a0 []byte, _a1 hash.Hasher, ...) (crypto.Signature, error)
- type LocalGossipSubRouterMetrics
- func (_m *LocalGossipSubRouterMetrics) OnLocalMeshSizeUpdated(topic string, size int)
- func (_m *LocalGossipSubRouterMetrics) OnLocalPeerJoinedTopic()
- func (_m *LocalGossipSubRouterMetrics) OnLocalPeerLeftTopic()
- func (_m *LocalGossipSubRouterMetrics) OnMessageDeliveredToAllSubscribers(size int)
- func (_m *LocalGossipSubRouterMetrics) OnMessageDuplicate(size int)
- func (_m *LocalGossipSubRouterMetrics) OnMessageEnteredValidation(size int)
- func (_m *LocalGossipSubRouterMetrics) OnMessageRejected(size int, reason string)
- func (_m *LocalGossipSubRouterMetrics) OnOutboundRpcDropped()
- func (_m *LocalGossipSubRouterMetrics) OnPeerAddedToProtocol(protocol string)
- func (_m *LocalGossipSubRouterMetrics) OnPeerGraftTopic(topic string)
- func (_m *LocalGossipSubRouterMetrics) OnPeerPruneTopic(topic string)
- func (_m *LocalGossipSubRouterMetrics) OnPeerRemovedFromProtocol()
- func (_m *LocalGossipSubRouterMetrics) OnPeerThrottled()
- func (_m *LocalGossipSubRouterMetrics) OnRpcReceived(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (_m *LocalGossipSubRouterMetrics) OnRpcSent(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (_m *LocalGossipSubRouterMetrics) OnUndeliveredMessage()
- type MachineAccountMetrics
- type MempoolMetrics
- type NetworkCoreMetrics
- func (_m *NetworkCoreMetrics) DuplicateInboundMessagesDropped(topic string, protocol string, messageType string)
- func (_m *NetworkCoreMetrics) InboundMessageReceived(sizeBytes int, topic string, protocol string, messageType string)
- func (_m *NetworkCoreMetrics) MessageAdded(priority int)
- func (_m *NetworkCoreMetrics) MessageProcessingFinished(topic string, duration time.Duration)
- func (_m *NetworkCoreMetrics) MessageProcessingStarted(topic string)
- func (_m *NetworkCoreMetrics) MessageRemoved(priority int)
- func (_m *NetworkCoreMetrics) OnMisbehaviorReported(channel string, misbehaviorType string)
- func (_m *NetworkCoreMetrics) OnRateLimitedPeer(pid peer.ID, role string, msgType string, topic string, reason string)
- func (_m *NetworkCoreMetrics) OnUnauthorizedMessage(role string, msgType string, topic string, offense string)
- func (_m *NetworkCoreMetrics) OnViolationReportSkipped()
- func (_m *NetworkCoreMetrics) OutboundMessageSent(sizeBytes int, topic string, protocol string, messageType string)
- func (_m *NetworkCoreMetrics) QueueDuration(duration time.Duration, priority int)
- func (_m *NetworkCoreMetrics) UnicastMessageSendingCompleted(topic string)
- func (_m *NetworkCoreMetrics) UnicastMessageSendingStarted(topic string)
- type NetworkInboundQueueMetrics
- type NetworkMetrics
- func (_m *NetworkMetrics) AllowConn(dir network.Direction, usefd bool)
- func (_m *NetworkMetrics) AllowMemory(size int)
- func (_m *NetworkMetrics) AllowPeer(p peer.ID)
- func (_m *NetworkMetrics) AllowProtocol(proto protocol.ID)
- func (_m *NetworkMetrics) AllowService(svc string)
- func (_m *NetworkMetrics) AllowStream(p peer.ID, dir network.Direction)
- func (_m *NetworkMetrics) AsyncProcessingFinished(duration time.Duration)
- func (_m *NetworkMetrics) AsyncProcessingStarted()
- func (_m *NetworkMetrics) BlockConn(dir network.Direction, usefd bool)
- func (_m *NetworkMetrics) BlockMemory(size int)
- func (_m *NetworkMetrics) BlockPeer(p peer.ID)
- func (_m *NetworkMetrics) BlockProtocol(proto protocol.ID)
- func (_m *NetworkMetrics) BlockProtocolPeer(proto protocol.ID, p peer.ID)
- func (_m *NetworkMetrics) BlockService(svc string)
- func (_m *NetworkMetrics) BlockServicePeer(svc string, p peer.ID)
- func (_m *NetworkMetrics) BlockStream(p peer.ID, dir network.Direction)
- func (_m *NetworkMetrics) DNSLookupDuration(duration time.Duration)
- func (_m *NetworkMetrics) DuplicateInboundMessagesDropped(topic string, _a1 string, messageType string)
- func (_m *NetworkMetrics) DuplicateMessagePenalties(penalty float64)
- func (_m *NetworkMetrics) DuplicateMessagesCounts(count float64)
- func (_m *NetworkMetrics) InboundConnections(connectionCount uint)
- func (_m *NetworkMetrics) InboundMessageReceived(sizeBytes int, topic string, _a2 string, messageType string)
- func (_m *NetworkMetrics) MessageAdded(priority int)
- func (_m *NetworkMetrics) MessageProcessingFinished(topic string, duration time.Duration)
- func (_m *NetworkMetrics) MessageProcessingStarted(topic string)
- func (_m *NetworkMetrics) MessageRemoved(priority int)
- func (_m *NetworkMetrics) OnActiveClusterIDsNotSetErr()
- func (_m *NetworkMetrics) OnAppSpecificScoreUpdated(_a0 float64)
- func (_m *NetworkMetrics) OnBehaviourPenaltyUpdated(_a0 float64)
- func (_m *NetworkMetrics) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
- func (_m *NetworkMetrics) OnDNSCacheHit()
- func (_m *NetworkMetrics) OnDNSCacheInvalidated()
- func (_m *NetworkMetrics) OnDNSCacheMiss()
- func (_m *NetworkMetrics) OnDNSLookupRequestDropped()
- func (_m *NetworkMetrics) OnDialRetryBudgetResetToDefault()
- func (_m *NetworkMetrics) OnDialRetryBudgetUpdated(budget uint64)
- func (_m *NetworkMetrics) OnEstablishStreamFailure(duration time.Duration, attempts int)
- func (_m *NetworkMetrics) OnFirstMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *NetworkMetrics) OnGraftDuplicateTopicIdsExceedThreshold()
- func (_m *NetworkMetrics) OnGraftInvalidTopicIdsExceedThreshold()
- func (_m *NetworkMetrics) OnGraftMessageInspected(duplicateTopicIds int, invalidTopicIds int)
- func (_m *NetworkMetrics) OnIHaveControlMessageIdsTruncated(diff int)
- func (_m *NetworkMetrics) OnIHaveDuplicateMessageIdsExceedThreshold()
- func (_m *NetworkMetrics) OnIHaveDuplicateTopicIdsExceedThreshold()
- func (_m *NetworkMetrics) OnIHaveInvalidTopicIdsExceedThreshold()
- func (_m *NetworkMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
- func (_m *NetworkMetrics) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int, invalidTopicIds int)
- func (_m *NetworkMetrics) OnIPColocationFactorUpdated(_a0 float64)
- func (_m *NetworkMetrics) OnIWantCacheMissMessageIdsExceedThreshold()
- func (_m *NetworkMetrics) OnIWantControlMessageIdsTruncated(diff int)
- func (_m *NetworkMetrics) OnIWantDuplicateMessageIdsExceedThreshold()
- func (_m *NetworkMetrics) OnIWantMessageIDsReceived(msgIdCount int)
- func (_m *NetworkMetrics) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
- func (_m *NetworkMetrics) OnIncomingRpcReceived(iHaveCount int, iWantCount int, graftCount int, pruneCount int, msgCount int)
- func (_m *NetworkMetrics) OnInvalidControlMessageNotificationSent()
- func (_m *NetworkMetrics) OnInvalidMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *NetworkMetrics) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
- func (_m *NetworkMetrics) OnLocalMeshSizeUpdated(topic string, size int)
- func (_m *NetworkMetrics) OnLocalPeerJoinedTopic()
- func (_m *NetworkMetrics) OnLocalPeerLeftTopic()
- func (_m *NetworkMetrics) OnMeshMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
- func (_m *NetworkMetrics) OnMessageDeliveredToAllSubscribers(size int)
- func (_m *NetworkMetrics) OnMessageDuplicate(size int)
- func (_m *NetworkMetrics) OnMessageEnteredValidation(size int)
- func (_m *NetworkMetrics) OnMessageRejected(size int, reason string)
- func (_m *NetworkMetrics) OnMisbehaviorReported(channel string, misbehaviorType string)
- func (_m *NetworkMetrics) OnOutboundRpcDropped()
- func (_m *NetworkMetrics) OnOverallPeerScoreUpdated(_a0 float64)
- func (_m *NetworkMetrics) OnPeerAddedToProtocol(_a0 string)
- func (_m *NetworkMetrics) OnPeerDialFailure(duration time.Duration, attempts int)
- func (_m *NetworkMetrics) OnPeerDialed(duration time.Duration, attempts int)
- func (_m *NetworkMetrics) OnPeerGraftTopic(topic string)
- func (_m *NetworkMetrics) OnPeerPruneTopic(topic string)
- func (_m *NetworkMetrics) OnPeerRemovedFromProtocol()
- func (_m *NetworkMetrics) OnPeerThrottled()
- func (_m *NetworkMetrics) OnPruneDuplicateTopicIdsExceedThreshold()
- func (_m *NetworkMetrics) OnPruneInvalidTopicIdsExceedThreshold()
- func (_m *NetworkMetrics) OnPruneMessageInspected(duplicateTopicIds int, invalidTopicIds int)
- func (_m *NetworkMetrics) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, ...)
- func (_m *NetworkMetrics) OnPublishMessagesInspectionErrorExceedsThreshold()
- func (_m *NetworkMetrics) OnRateLimitedPeer(pid peer.ID, role string, msgType string, topic string, reason string)
- func (_m *NetworkMetrics) OnRpcReceived(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (_m *NetworkMetrics) OnRpcRejectedFromUnknownSender()
- func (_m *NetworkMetrics) OnRpcSent(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
- func (_m *NetworkMetrics) OnStreamCreated(duration time.Duration, attempts int)
- func (_m *NetworkMetrics) OnStreamCreationFailure(duration time.Duration, attempts int)
- func (_m *NetworkMetrics) OnStreamCreationRetryBudgetResetToDefault()
- func (_m *NetworkMetrics) OnStreamCreationRetryBudgetUpdated(budget uint64)
- func (_m *NetworkMetrics) OnStreamEstablished(duration time.Duration, attempts int)
- func (_m *NetworkMetrics) OnTimeInMeshUpdated(_a0 channels.Topic, _a1 time.Duration)
- func (_m *NetworkMetrics) OnUnauthorizedMessage(role string, msgType string, topic string, offense string)
- func (_m *NetworkMetrics) OnUndeliveredMessage()
- func (_m *NetworkMetrics) OnUnstakedPeerInspectionFailed()
- func (_m *NetworkMetrics) OnViolationReportSkipped()
- func (_m *NetworkMetrics) OutboundConnections(connectionCount uint)
- func (_m *NetworkMetrics) OutboundMessageSent(sizeBytes int, topic string, _a2 string, messageType string)
- func (_m *NetworkMetrics) QueueDuration(duration time.Duration, priority int)
- func (_m *NetworkMetrics) RoutingTablePeerAdded()
- func (_m *NetworkMetrics) RoutingTablePeerRemoved()
- func (_m *NetworkMetrics) SetWarningStateCount(_a0 uint)
- func (_m *NetworkMetrics) UnicastMessageSendingCompleted(topic string)
- func (_m *NetworkMetrics) UnicastMessageSendingStarted(topic string)
- type NetworkSecurityMetrics
- type NewJobListener
- type PendingBlockBuffer
- func (_m *PendingBlockBuffer) Add(block flow.Slashable[*flow.Block]) bool
- func (_m *PendingBlockBuffer) ByID(blockID flow.Identifier) (flow.Slashable[*flow.Block], bool)
- func (_m *PendingBlockBuffer) ByParentID(parentID flow.Identifier) ([]flow.Slashable[*flow.Block], bool)
- func (_m *PendingBlockBuffer) DropForParent(parentID flow.Identifier)
- func (_m *PendingBlockBuffer) PruneByView(view uint64)
- func (_m *PendingBlockBuffer) Size() uint
- type PendingClusterBlockBuffer
- func (_m *PendingClusterBlockBuffer) Add(block flow.Slashable[*cluster.Block]) bool
- func (_m *PendingClusterBlockBuffer) ByID(blockID flow.Identifier) (flow.Slashable[*cluster.Block], bool)
- func (_m *PendingClusterBlockBuffer) ByParentID(parentID flow.Identifier) ([]flow.Slashable[*cluster.Block], bool)
- func (_m *PendingClusterBlockBuffer) DropForParent(parentID flow.Identifier)
- func (_m *PendingClusterBlockBuffer) PruneByView(view uint64)
- func (_m *PendingClusterBlockBuffer) Size() uint
- type PingMetrics
- type ProcessingNotifier
- type ProviderMetrics
- type PublicKey
- func (_m *PublicKey) Algorithm() crypto.SigningAlgorithm
- func (_m *PublicKey) Encode() []byte
- func (_m *PublicKey) EncodeCompressed() []byte
- func (_m *PublicKey) Equals(_a0 crypto.PublicKey) bool
- func (_m *PublicKey) Size() int
- func (_m *PublicKey) String() string
- func (_m *PublicKey) Verify(_a0 crypto.Signature, _a1 []byte, _a2 hash.Hasher) (bool, error)
- type QCContractClient
- type RandomBeaconKeyStore
- type RateLimitedBlockstoreMetrics
- type ReadyDoneAware
- type ReceiptValidator
- type Requester
- type ResolverMetrics
- type RestMetrics
- func (_m *RestMetrics) AddInflightRequests(ctx context.Context, props metrics.HTTPProperties, quantity int)
- func (_m *RestMetrics) AddTotalRequests(ctx context.Context, method string, routeName string)
- func (_m *RestMetrics) ObserveHTTPRequestDuration(ctx context.Context, props metrics.HTTPReqProperties, duration time.Duration)
- func (_m *RestMetrics) ObserveHTTPResponseSize(ctx context.Context, props metrics.HTTPReqProperties, sizeBytes int64)
- type RuntimeMetrics
- func (_m *RuntimeMetrics) RuntimeSetNumberOfAccounts(count uint64)
- func (_m *RuntimeMetrics) RuntimeTransactionChecked(dur time.Duration)
- func (_m *RuntimeMetrics) RuntimeTransactionInterpreted(dur time.Duration)
- func (_m *RuntimeMetrics) RuntimeTransactionParsed(dur time.Duration)
- func (_m *RuntimeMetrics) RuntimeTransactionProgramsCacheHit()
- func (_m *RuntimeMetrics) RuntimeTransactionProgramsCacheMiss()
- type SDKClientWrapper
- func (_m *SDKClientWrapper) ExecuteScriptAtBlockID(_a0 context.Context, _a1 flow.Identifier, _a2 []byte, _a3 []cadence.Value) (cadence.Value, error)
- func (_m *SDKClientWrapper) ExecuteScriptAtLatestBlock(_a0 context.Context, _a1 []byte, _a2 []cadence.Value) (cadence.Value, error)
- func (_m *SDKClientWrapper) GetAccount(_a0 context.Context, _a1 flow.Address) (*flow.Account, error)
- func (_m *SDKClientWrapper) GetAccountAtLatestBlock(_a0 context.Context, _a1 flow.Address) (*flow.Account, error)
- func (_m *SDKClientWrapper) GetLatestBlock(_a0 context.Context, _a1 bool) (*flow.Block, error)
- func (_m *SDKClientWrapper) GetTransactionResult(_a0 context.Context, _a1 flow.Identifier) (*flow.TransactionResult, error)
- func (_m *SDKClientWrapper) SendTransaction(_a0 context.Context, _a1 flow.Transaction) error
- type SealValidator
- type SealingConfigsGetter
- func (_m *SealingConfigsGetter) ApprovalRequestsThresholdConst() uint64
- func (_m *SealingConfigsGetter) ChunkAlphaConst() uint
- func (_m *SealingConfigsGetter) EmergencySealingActiveConst() bool
- func (_m *SealingConfigsGetter) RequireApprovalsForSealConstructionDynamicValue() uint
- func (_m *SealingConfigsGetter) RequireApprovalsForSealVerificationConst() uint
- type SealingConfigsSetter
- func (_m *SealingConfigsSetter) ApprovalRequestsThresholdConst() uint64
- func (_m *SealingConfigsSetter) ChunkAlphaConst() uint
- func (_m *SealingConfigsSetter) EmergencySealingActiveConst() bool
- func (_m *SealingConfigsSetter) RequireApprovalsForSealConstructionDynamicValue() uint
- func (_m *SealingConfigsSetter) RequireApprovalsForSealVerificationConst() uint
- func (_m *SealingConfigsSetter) SetRequiredApprovalsForSealingConstruction(newVal uint) error
- type Startable
- type SyncCore
- func (_m *SyncCore) BatchRequested(batch chainsync.Batch)
- func (_m *SyncCore) HandleBlock(header *flow.Header) bool
- func (_m *SyncCore) HandleHeight(final *flow.Header, height uint64)
- func (_m *SyncCore) RangeRequested(ran chainsync.Range)
- func (_m *SyncCore) ScanPending(final *flow.Header) ([]chainsync.Range, []chainsync.Batch)
- func (_m *SyncCore) WithinTolerance(final *flow.Header, height uint64) bool
- type Tracer
- func (_m *Tracer) BlockRootSpan(blockID flow.Identifier) trace.Span
- func (_m *Tracer) Done() <-chan struct{}
- func (_m *Tracer) Ready() <-chan struct{}
- func (_m *Tracer) ShouldSample(entityID flow.Identifier) bool
- func (_m *Tracer) StartBlockSpan(ctx context.Context, blockID flow.Identifier, spanName moduletrace.SpanName, ...) (trace.Span, context.Context)
- func (_m *Tracer) StartCollectionSpan(ctx context.Context, collectionID flow.Identifier, ...) (trace.Span, context.Context)
- func (_m *Tracer) StartSampledSpanFromParent(parentSpan trace.Span, entityID flow.Identifier, ...) trace.Span
- func (_m *Tracer) StartSpanFromContext(ctx context.Context, operationName moduletrace.SpanName, ...) (trace.Span, context.Context)
- func (_m *Tracer) StartSpanFromParent(parentSpan trace.Span, operationName moduletrace.SpanName, ...) trace.Span
- func (_m *Tracer) WithSpanFromContext(ctx context.Context, operationName moduletrace.SpanName, f func(), ...)
- type TransactionMetrics
- func (_m *TransactionMetrics) TransactionExecuted(txID flow.Identifier, when time.Time)
- func (_m *TransactionMetrics) TransactionExpired(txID flow.Identifier)
- func (_m *TransactionMetrics) TransactionFinalized(txID flow.Identifier, when time.Time)
- func (_m *TransactionMetrics) TransactionReceived(txID flow.Identifier, when time.Time)
- func (_m *TransactionMetrics) TransactionResultFetched(dur time.Duration, size int)
- func (_m *TransactionMetrics) TransactionSubmissionFailed()
- type UnicastManagerMetrics
- func (_m *UnicastManagerMetrics) OnDialRetryBudgetResetToDefault()
- func (_m *UnicastManagerMetrics) OnDialRetryBudgetUpdated(budget uint64)
- func (_m *UnicastManagerMetrics) OnEstablishStreamFailure(duration time.Duration, attempts int)
- func (_m *UnicastManagerMetrics) OnPeerDialFailure(duration time.Duration, attempts int)
- func (_m *UnicastManagerMetrics) OnPeerDialed(duration time.Duration, attempts int)
- func (_m *UnicastManagerMetrics) OnStreamCreated(duration time.Duration, attempts int)
- func (_m *UnicastManagerMetrics) OnStreamCreationFailure(duration time.Duration, attempts int)
- func (_m *UnicastManagerMetrics) OnStreamCreationRetryBudgetResetToDefault()
- func (_m *UnicastManagerMetrics) OnStreamCreationRetryBudgetUpdated(budget uint64)
- func (_m *UnicastManagerMetrics) OnStreamEstablished(duration time.Duration, attempts int)
- type VerificationMetrics
- func (_m *VerificationMetrics) OnAssignedChunkProcessedAtAssigner()
- func (_m *VerificationMetrics) OnAssignedChunkReceivedAtFetcher()
- func (_m *VerificationMetrics) OnBlockConsumerJobDone(_a0 uint64)
- func (_m *VerificationMetrics) OnChunkConsumerJobDone(_a0 uint64)
- func (_m *VerificationMetrics) OnChunkDataPackArrivedAtFetcher()
- func (_m *VerificationMetrics) OnChunkDataPackRequestDispatchedInNetworkByRequester()
- func (_m *VerificationMetrics) OnChunkDataPackRequestReceivedByRequester()
- func (_m *VerificationMetrics) OnChunkDataPackRequestSentByFetcher()
- func (_m *VerificationMetrics) OnChunkDataPackResponseReceivedFromNetworkByRequester()
- func (_m *VerificationMetrics) OnChunkDataPackSentToFetcher()
- func (_m *VerificationMetrics) OnChunksAssignmentDoneAtAssigner(chunks int)
- func (_m *VerificationMetrics) OnExecutionResultReceivedAtAssignerEngine()
- func (_m *VerificationMetrics) OnFinalizedBlockArrivedAtAssigner(height uint64)
- func (_m *VerificationMetrics) OnResultApprovalDispatchedInNetworkByVerifier()
- func (_m *VerificationMetrics) OnVerifiableChunkReceivedAtVerifierEngine()
- func (_m *VerificationMetrics) OnVerifiableChunkSentToVerifier()
- func (_m *VerificationMetrics) SetMaxChunkDataPackAttemptsForNextUnsealedHeightAtRequester(attempts uint64)
- type WALMetrics
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
This section is empty.
Types ¶
type AccessMetrics ¶ added in v0.26.16
AccessMetrics is an autogenerated mock type for the AccessMetrics type
func NewAccessMetrics ¶ added in v0.26.16
func NewAccessMetrics(t interface { mock.TestingT Cleanup(func()) }) *AccessMetrics
NewAccessMetrics creates a new instance of AccessMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*AccessMetrics) AddInflightRequests ¶ added in v0.31.0
func (_m *AccessMetrics) AddInflightRequests(ctx context.Context, props metrics.HTTPProperties, quantity int)
AddInflightRequests provides a mock function with given fields: ctx, props, quantity
func (*AccessMetrics) AddTotalRequests ¶ added in v0.31.0
func (_m *AccessMetrics) AddTotalRequests(ctx context.Context, method string, routeName string)
AddTotalRequests provides a mock function with given fields: ctx, method, routeName
func (*AccessMetrics) ConnectionAddedToPool ¶ added in v0.26.17
func (_m *AccessMetrics) ConnectionAddedToPool()
ConnectionAddedToPool provides a mock function with given fields:
func (*AccessMetrics) ConnectionFromPoolEvicted ¶ added in v0.26.17
func (_m *AccessMetrics) ConnectionFromPoolEvicted()
ConnectionFromPoolEvicted provides a mock function with given fields:
func (*AccessMetrics) ConnectionFromPoolInvalidated ¶ added in v0.26.17
func (_m *AccessMetrics) ConnectionFromPoolInvalidated()
ConnectionFromPoolInvalidated provides a mock function with given fields:
func (*AccessMetrics) ConnectionFromPoolReused ¶ added in v0.26.17
func (_m *AccessMetrics) ConnectionFromPoolReused()
ConnectionFromPoolReused provides a mock function with given fields:
func (*AccessMetrics) ConnectionFromPoolUpdated ¶ added in v0.26.17
func (_m *AccessMetrics) ConnectionFromPoolUpdated()
ConnectionFromPoolUpdated provides a mock function with given fields:
func (*AccessMetrics) NewConnectionEstablished ¶ added in v0.26.17
func (_m *AccessMetrics) NewConnectionEstablished()
NewConnectionEstablished provides a mock function with given fields:
func (*AccessMetrics) ObserveHTTPRequestDuration ¶ added in v0.31.0
func (_m *AccessMetrics) ObserveHTTPRequestDuration(ctx context.Context, props metrics.HTTPReqProperties, duration time.Duration)
ObserveHTTPRequestDuration provides a mock function with given fields: ctx, props, duration
func (*AccessMetrics) ObserveHTTPResponseSize ¶ added in v0.31.0
func (_m *AccessMetrics) ObserveHTTPResponseSize(ctx context.Context, props metrics.HTTPReqProperties, sizeBytes int64)
ObserveHTTPResponseSize provides a mock function with given fields: ctx, props, sizeBytes
func (*AccessMetrics) ScriptExecuted ¶ added in v0.31.0
func (_m *AccessMetrics) ScriptExecuted(dur time.Duration, size int)
ScriptExecuted provides a mock function with given fields: dur, size
func (*AccessMetrics) ScriptExecutionErrorLocal ¶ added in v0.32.2
func (_m *AccessMetrics) ScriptExecutionErrorLocal()
ScriptExecutionErrorLocal provides a mock function with given fields:
func (*AccessMetrics) ScriptExecutionErrorMatch ¶ added in v0.32.0
func (_m *AccessMetrics) ScriptExecutionErrorMatch()
ScriptExecutionErrorMatch provides a mock function with given fields:
func (*AccessMetrics) ScriptExecutionErrorMismatch ¶ added in v0.32.0
func (_m *AccessMetrics) ScriptExecutionErrorMismatch()
ScriptExecutionErrorMismatch provides a mock function with given fields:
func (*AccessMetrics) ScriptExecutionErrorOnExecutionNode ¶ added in v0.31.11
func (_m *AccessMetrics) ScriptExecutionErrorOnExecutionNode()
ScriptExecutionErrorOnExecutionNode provides a mock function with given fields:
func (*AccessMetrics) ScriptExecutionNotIndexed ¶ added in v0.32.7
func (_m *AccessMetrics) ScriptExecutionNotIndexed()
ScriptExecutionNotIndexed provides a mock function with given fields:
func (*AccessMetrics) ScriptExecutionResultMatch ¶ added in v0.32.0
func (_m *AccessMetrics) ScriptExecutionResultMatch()
ScriptExecutionResultMatch provides a mock function with given fields:
func (*AccessMetrics) ScriptExecutionResultMismatch ¶ added in v0.32.0
func (_m *AccessMetrics) ScriptExecutionResultMismatch()
ScriptExecutionResultMismatch provides a mock function with given fields:
func (*AccessMetrics) TotalConnectionsInPool ¶ added in v0.26.16
func (_m *AccessMetrics) TotalConnectionsInPool(connectionCount uint, connectionPoolSize uint)
TotalConnectionsInPool provides a mock function with given fields: connectionCount, connectionPoolSize
func (*AccessMetrics) TransactionExecuted ¶ added in v0.31.0
func (_m *AccessMetrics) TransactionExecuted(txID flow.Identifier, when time.Time)
TransactionExecuted provides a mock function with given fields: txID, when
func (*AccessMetrics) TransactionExpired ¶ added in v0.31.0
func (_m *AccessMetrics) TransactionExpired(txID flow.Identifier)
TransactionExpired provides a mock function with given fields: txID
func (*AccessMetrics) TransactionFinalized ¶ added in v0.31.0
func (_m *AccessMetrics) TransactionFinalized(txID flow.Identifier, when time.Time)
TransactionFinalized provides a mock function with given fields: txID, when
func (*AccessMetrics) TransactionReceived ¶ added in v0.31.0
func (_m *AccessMetrics) TransactionReceived(txID flow.Identifier, when time.Time)
TransactionReceived provides a mock function with given fields: txID, when
func (*AccessMetrics) TransactionResultFetched ¶ added in v0.31.0
func (_m *AccessMetrics) TransactionResultFetched(dur time.Duration, size int)
TransactionResultFetched provides a mock function with given fields: dur, size
func (*AccessMetrics) TransactionSubmissionFailed ¶ added in v0.31.0
func (_m *AccessMetrics) TransactionSubmissionFailed()
TransactionSubmissionFailed provides a mock function with given fields:
func (*AccessMetrics) UpdateExecutionReceiptMaxHeight ¶ added in v0.31.0
func (_m *AccessMetrics) UpdateExecutionReceiptMaxHeight(height uint64)
UpdateExecutionReceiptMaxHeight provides a mock function with given fields: height
func (*AccessMetrics) UpdateLastFullBlockHeight ¶ added in v0.31.0
func (_m *AccessMetrics) UpdateLastFullBlockHeight(height uint64)
UpdateLastFullBlockHeight provides a mock function with given fields: height
type AlspMetrics ¶ added in v0.31.0
AlspMetrics is an autogenerated mock type for the AlspMetrics type
func NewAlspMetrics ¶ added in v0.31.0
func NewAlspMetrics(t interface { mock.TestingT Cleanup(func()) }) *AlspMetrics
NewAlspMetrics creates a new instance of AlspMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*AlspMetrics) OnMisbehaviorReported ¶ added in v0.31.0
func (_m *AlspMetrics) OnMisbehaviorReported(channel string, misbehaviorType string)
OnMisbehaviorReported provides a mock function with given fields: channel, misbehaviorType
type BackendScriptsMetrics ¶ added in v0.26.1
BackendScriptsMetrics is an autogenerated mock type for the BackendScriptsMetrics type
func NewBackendScriptsMetrics ¶ added in v0.26.2
func NewBackendScriptsMetrics(t interface { mock.TestingT Cleanup(func()) }) *BackendScriptsMetrics
NewBackendScriptsMetrics creates a new instance of BackendScriptsMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*BackendScriptsMetrics) ScriptExecuted ¶ added in v0.26.1
func (_m *BackendScriptsMetrics) ScriptExecuted(dur time.Duration, size int)
ScriptExecuted provides a mock function with given fields: dur, size
func (*BackendScriptsMetrics) ScriptExecutionErrorLocal ¶ added in v0.32.2
func (_m *BackendScriptsMetrics) ScriptExecutionErrorLocal()
ScriptExecutionErrorLocal provides a mock function with given fields:
func (*BackendScriptsMetrics) ScriptExecutionErrorMatch ¶ added in v0.32.0
func (_m *BackendScriptsMetrics) ScriptExecutionErrorMatch()
ScriptExecutionErrorMatch provides a mock function with given fields:
func (*BackendScriptsMetrics) ScriptExecutionErrorMismatch ¶ added in v0.32.0
func (_m *BackendScriptsMetrics) ScriptExecutionErrorMismatch()
ScriptExecutionErrorMismatch provides a mock function with given fields:
func (*BackendScriptsMetrics) ScriptExecutionErrorOnExecutionNode ¶ added in v0.31.11
func (_m *BackendScriptsMetrics) ScriptExecutionErrorOnExecutionNode()
ScriptExecutionErrorOnExecutionNode provides a mock function with given fields:
func (*BackendScriptsMetrics) ScriptExecutionNotIndexed ¶ added in v0.32.7
func (_m *BackendScriptsMetrics) ScriptExecutionNotIndexed()
ScriptExecutionNotIndexed provides a mock function with given fields:
func (*BackendScriptsMetrics) ScriptExecutionResultMatch ¶ added in v0.32.0
func (_m *BackendScriptsMetrics) ScriptExecutionResultMatch()
ScriptExecutionResultMatch provides a mock function with given fields:
func (*BackendScriptsMetrics) ScriptExecutionResultMismatch ¶ added in v0.32.0
func (_m *BackendScriptsMetrics) ScriptExecutionResultMismatch()
ScriptExecutionResultMismatch provides a mock function with given fields:
type BitswapMetrics ¶ added in v0.27.3
BitswapMetrics is an autogenerated mock type for the BitswapMetrics type
func NewBitswapMetrics ¶ added in v0.27.3
func NewBitswapMetrics(t interface { mock.TestingT Cleanup(func()) }) *BitswapMetrics
NewBitswapMetrics creates a new instance of BitswapMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*BitswapMetrics) BlobsReceived ¶ added in v0.27.3
func (_m *BitswapMetrics) BlobsReceived(prefix string, n uint64)
BlobsReceived provides a mock function with given fields: prefix, n
func (*BitswapMetrics) BlobsSent ¶ added in v0.27.3
func (_m *BitswapMetrics) BlobsSent(prefix string, n uint64)
BlobsSent provides a mock function with given fields: prefix, n
func (*BitswapMetrics) DataReceived ¶ added in v0.27.3
func (_m *BitswapMetrics) DataReceived(prefix string, n uint64)
DataReceived provides a mock function with given fields: prefix, n
func (*BitswapMetrics) DataSent ¶ added in v0.27.3
func (_m *BitswapMetrics) DataSent(prefix string, n uint64)
DataSent provides a mock function with given fields: prefix, n
func (*BitswapMetrics) DupBlobsReceived ¶ added in v0.27.3
func (_m *BitswapMetrics) DupBlobsReceived(prefix string, n uint64)
DupBlobsReceived provides a mock function with given fields: prefix, n
func (*BitswapMetrics) DupDataReceived ¶ added in v0.27.3
func (_m *BitswapMetrics) DupDataReceived(prefix string, n uint64)
DupDataReceived provides a mock function with given fields: prefix, n
func (*BitswapMetrics) MessagesReceived ¶ added in v0.27.3
func (_m *BitswapMetrics) MessagesReceived(prefix string, n uint64)
MessagesReceived provides a mock function with given fields: prefix, n
func (*BitswapMetrics) Peers ¶ added in v0.27.3
func (_m *BitswapMetrics) Peers(prefix string, n int)
Peers provides a mock function with given fields: prefix, n
func (*BitswapMetrics) Wantlist ¶ added in v0.27.3
func (_m *BitswapMetrics) Wantlist(prefix string, n int)
Wantlist provides a mock function with given fields: prefix, n
type BlockRequester ¶
BlockRequester is an autogenerated mock type for the BlockRequester type
func NewBlockRequester ¶ added in v0.26.1
func NewBlockRequester(t interface { mock.TestingT Cleanup(func()) }) *BlockRequester
NewBlockRequester creates a new instance of BlockRequester. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*BlockRequester) Prune ¶
func (_m *BlockRequester) Prune(final *flow.Header)
Prune provides a mock function with given fields: final
func (*BlockRequester) RequestBlock ¶
func (_m *BlockRequester) RequestBlock(blockID flow.Identifier, height uint64)
RequestBlock provides a mock function with given fields: blockID, height
func (*BlockRequester) RequestHeight ¶
func (_m *BlockRequester) RequestHeight(height uint64)
RequestHeight provides a mock function with given fields: height
type Builder ¶
Builder is an autogenerated mock type for the Builder type
func NewBuilder ¶ added in v0.26.1
NewBuilder creates a new instance of Builder. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
type CacheMetrics ¶
CacheMetrics is an autogenerated mock type for the CacheMetrics type
func NewCacheMetrics ¶ added in v0.26.1
func NewCacheMetrics(t interface { mock.TestingT Cleanup(func()) }) *CacheMetrics
NewCacheMetrics creates a new instance of CacheMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*CacheMetrics) CacheEntries ¶
func (_m *CacheMetrics) CacheEntries(resource string, entries uint)
CacheEntries provides a mock function with given fields: resource, entries
func (*CacheMetrics) CacheHit ¶
func (_m *CacheMetrics) CacheHit(resource string)
CacheHit provides a mock function with given fields: resource
func (*CacheMetrics) CacheMiss ¶
func (_m *CacheMetrics) CacheMiss(resource string)
CacheMiss provides a mock function with given fields: resource
func (*CacheMetrics) CacheNotFound ¶ added in v0.16.0
func (_m *CacheMetrics) CacheNotFound(resource string)
CacheNotFound provides a mock function with given fields: resource
type ChainSyncMetrics ¶ added in v0.27.0
ChainSyncMetrics is an autogenerated mock type for the ChainSyncMetrics type
func NewChainSyncMetrics ¶ added in v0.27.0
func NewChainSyncMetrics(t interface { mock.TestingT Cleanup(func()) }) *ChainSyncMetrics
NewChainSyncMetrics creates a new instance of ChainSyncMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ChainSyncMetrics) BatchRequested ¶ added in v0.27.0
func (_m *ChainSyncMetrics) BatchRequested(batch chainsync.Batch)
BatchRequested provides a mock function with given fields: batch
func (*ChainSyncMetrics) PrunedBlockByHeight ¶ added in v0.27.0
func (_m *ChainSyncMetrics) PrunedBlockByHeight(status *chainsync.Status)
PrunedBlockByHeight provides a mock function with given fields: status
func (*ChainSyncMetrics) PrunedBlockById ¶ added in v0.27.0
func (_m *ChainSyncMetrics) PrunedBlockById(status *chainsync.Status)
PrunedBlockById provides a mock function with given fields: status
func (*ChainSyncMetrics) PrunedBlocks ¶ added in v0.27.0
func (_m *ChainSyncMetrics) PrunedBlocks(totalByHeight int, totalById int, storedByHeight int, storedById int)
PrunedBlocks provides a mock function with given fields: totalByHeight, totalById, storedByHeight, storedById
func (*ChainSyncMetrics) RangeRequested ¶ added in v0.27.0
func (_m *ChainSyncMetrics) RangeRequested(ran chainsync.Range)
RangeRequested provides a mock function with given fields: ran
type ChunkAssigner ¶
ChunkAssigner is an autogenerated mock type for the ChunkAssigner type
func NewChunkAssigner ¶ added in v0.26.1
func NewChunkAssigner(t interface { mock.TestingT Cleanup(func()) }) *ChunkAssigner
NewChunkAssigner creates a new instance of ChunkAssigner. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ChunkAssigner) Assign ¶
func (_m *ChunkAssigner) Assign(result *flow.ExecutionResult, blockID flow.Identifier) (*chunks.Assignment, error)
Assign provides a mock function with given fields: result, blockID
type ChunkVerifier ¶
ChunkVerifier is an autogenerated mock type for the ChunkVerifier type
func NewChunkVerifier ¶ added in v0.26.1
func NewChunkVerifier(t interface { mock.TestingT Cleanup(func()) }) *ChunkVerifier
NewChunkVerifier creates a new instance of ChunkVerifier. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ChunkVerifier) Verify ¶
func (_m *ChunkVerifier) Verify(ch *verification.VerifiableChunkData) ([]byte, error)
Verify provides a mock function with given fields: ch
type CleanerMetrics ¶
CleanerMetrics is an autogenerated mock type for the CleanerMetrics type
func NewCleanerMetrics ¶ added in v0.26.1
func NewCleanerMetrics(t interface { mock.TestingT Cleanup(func()) }) *CleanerMetrics
NewCleanerMetrics creates a new instance of CleanerMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*CleanerMetrics) RanGC ¶
func (_m *CleanerMetrics) RanGC(took time.Duration)
RanGC provides a mock function with given fields: took
type ClusterRootQCVoter ¶
ClusterRootQCVoter is an autogenerated mock type for the ClusterRootQCVoter type
func NewClusterRootQCVoter ¶ added in v0.26.1
func NewClusterRootQCVoter(t interface { mock.TestingT Cleanup(func()) }) *ClusterRootQCVoter
NewClusterRootQCVoter creates a new instance of ClusterRootQCVoter. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
type CollectionExecutedMetric ¶ added in v0.33.15
CollectionExecutedMetric is an autogenerated mock type for the CollectionExecutedMetric type
func NewCollectionExecutedMetric ¶ added in v0.33.15
func NewCollectionExecutedMetric(t interface { mock.TestingT Cleanup(func()) }) *CollectionExecutedMetric
NewCollectionExecutedMetric creates a new instance of CollectionExecutedMetric. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*CollectionExecutedMetric) BlockFinalized ¶ added in v0.33.15
func (_m *CollectionExecutedMetric) BlockFinalized(block *flow.Block)
BlockFinalized provides a mock function with given fields: block
func (*CollectionExecutedMetric) CollectionExecuted ¶ added in v0.33.15
func (_m *CollectionExecutedMetric) CollectionExecuted(light flow.LightCollection)
CollectionExecuted provides a mock function with given fields: light
func (*CollectionExecutedMetric) CollectionFinalized ¶ added in v0.33.15
func (_m *CollectionExecutedMetric) CollectionFinalized(light flow.LightCollection)
CollectionFinalized provides a mock function with given fields: light
func (*CollectionExecutedMetric) ExecutionReceiptReceived ¶ added in v0.33.15
func (_m *CollectionExecutedMetric) ExecutionReceiptReceived(r *flow.ExecutionReceipt)
ExecutionReceiptReceived provides a mock function with given fields: r
func (*CollectionExecutedMetric) UpdateLastFullBlockHeight ¶ added in v0.33.15
func (_m *CollectionExecutedMetric) UpdateLastFullBlockHeight(height uint64)
UpdateLastFullBlockHeight provides a mock function with given fields: height
type CollectionMetrics ¶
CollectionMetrics is an autogenerated mock type for the CollectionMetrics type
func NewCollectionMetrics ¶ added in v0.26.1
func NewCollectionMetrics(t interface { mock.TestingT Cleanup(func()) }) *CollectionMetrics
NewCollectionMetrics creates a new instance of CollectionMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*CollectionMetrics) ClusterBlockFinalized ¶
func (_m *CollectionMetrics) ClusterBlockFinalized(block *cluster.Block)
ClusterBlockFinalized provides a mock function with given fields: block
func (*CollectionMetrics) ClusterBlockProposed ¶
func (_m *CollectionMetrics) ClusterBlockProposed(block *cluster.Block)
ClusterBlockProposed provides a mock function with given fields: block
func (*CollectionMetrics) TransactionIngested ¶
func (_m *CollectionMetrics) TransactionIngested(txID flow.Identifier)
TransactionIngested provides a mock function with given fields: txID
type ComplianceMetrics ¶
ComplianceMetrics is an autogenerated mock type for the ComplianceMetrics type
func NewComplianceMetrics ¶ added in v0.26.1
func NewComplianceMetrics(t interface { mock.TestingT Cleanup(func()) }) *ComplianceMetrics
NewComplianceMetrics creates a new instance of ComplianceMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ComplianceMetrics) BlockFinalized ¶
func (_m *ComplianceMetrics) BlockFinalized(_a0 *flow.Block)
BlockFinalized provides a mock function with given fields: _a0
func (*ComplianceMetrics) BlockSealed ¶
func (_m *ComplianceMetrics) BlockSealed(_a0 *flow.Block)
BlockSealed provides a mock function with given fields: _a0
func (*ComplianceMetrics) CurrentDKGPhaseViews ¶ added in v0.37.1
func (_m *ComplianceMetrics) CurrentDKGPhaseViews(phase1FinalView uint64, phase2FinalView uint64, phase3FinalView uint64)
CurrentDKGPhaseViews provides a mock function with given fields: phase1FinalView, phase2FinalView, phase3FinalView
func (*ComplianceMetrics) CurrentEpochCounter ¶ added in v0.20.0
func (_m *ComplianceMetrics) CurrentEpochCounter(counter uint64)
CurrentEpochCounter provides a mock function with given fields: counter
func (*ComplianceMetrics) CurrentEpochFinalView ¶ added in v0.21.0
func (_m *ComplianceMetrics) CurrentEpochFinalView(view uint64)
CurrentEpochFinalView provides a mock function with given fields: view
func (*ComplianceMetrics) CurrentEpochPhase ¶ added in v0.20.0
func (_m *ComplianceMetrics) CurrentEpochPhase(phase flow.EpochPhase)
CurrentEpochPhase provides a mock function with given fields: phase
func (*ComplianceMetrics) EpochFallbackModeExited ¶ added in v0.37.1
func (_m *ComplianceMetrics) EpochFallbackModeExited()
EpochFallbackModeExited provides a mock function with given fields:
func (*ComplianceMetrics) EpochFallbackModeTriggered ¶ added in v0.37.1
func (_m *ComplianceMetrics) EpochFallbackModeTriggered()
EpochFallbackModeTriggered provides a mock function with given fields:
func (*ComplianceMetrics) EpochTransitionHeight ¶ added in v0.30.0
func (_m *ComplianceMetrics) EpochTransitionHeight(height uint64)
EpochTransitionHeight provides a mock function with given fields: height
func (*ComplianceMetrics) FinalizedHeight ¶
func (_m *ComplianceMetrics) FinalizedHeight(height uint64)
FinalizedHeight provides a mock function with given fields: height
func (*ComplianceMetrics) SealedHeight ¶
func (_m *ComplianceMetrics) SealedHeight(height uint64)
SealedHeight provides a mock function with given fields: height
type ConsensusMetrics ¶
ConsensusMetrics is an autogenerated mock type for the ConsensusMetrics type
func NewConsensusMetrics ¶ added in v0.26.1
func NewConsensusMetrics(t interface { mock.TestingT Cleanup(func()) }) *ConsensusMetrics
NewConsensusMetrics creates a new instance of ConsensusMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ConsensusMetrics) CheckSealingDuration ¶ added in v0.11.0
func (_m *ConsensusMetrics) CheckSealingDuration(duration time.Duration)
CheckSealingDuration provides a mock function with given fields: duration
func (*ConsensusMetrics) EmergencySeal ¶ added in v0.14.0
func (_m *ConsensusMetrics) EmergencySeal()
EmergencySeal provides a mock function with given fields:
func (*ConsensusMetrics) FinishBlockToSeal ¶
func (_m *ConsensusMetrics) FinishBlockToSeal(blockID flow.Identifier)
FinishBlockToSeal provides a mock function with given fields: blockID
func (*ConsensusMetrics) FinishCollectionToFinalized ¶
func (_m *ConsensusMetrics) FinishCollectionToFinalized(collectionID flow.Identifier)
FinishCollectionToFinalized provides a mock function with given fields: collectionID
func (*ConsensusMetrics) OnApprovalProcessingDuration ¶ added in v0.14.1
func (_m *ConsensusMetrics) OnApprovalProcessingDuration(duration time.Duration)
OnApprovalProcessingDuration provides a mock function with given fields: duration
func (*ConsensusMetrics) OnReceiptProcessingDuration ¶ added in v0.14.1
func (_m *ConsensusMetrics) OnReceiptProcessingDuration(duration time.Duration)
OnReceiptProcessingDuration provides a mock function with given fields: duration
func (*ConsensusMetrics) StartBlockToSeal ¶
func (_m *ConsensusMetrics) StartBlockToSeal(blockID flow.Identifier)
StartBlockToSeal provides a mock function with given fields: blockID
func (*ConsensusMetrics) StartCollectionToFinalized ¶
func (_m *ConsensusMetrics) StartCollectionToFinalized(collectionID flow.Identifier)
StartCollectionToFinalized provides a mock function with given fields: collectionID
type CruiseCtlMetrics ¶ added in v0.31.0
CruiseCtlMetrics is an autogenerated mock type for the CruiseCtlMetrics type
func NewCruiseCtlMetrics ¶ added in v0.31.0
func NewCruiseCtlMetrics(t interface { mock.TestingT Cleanup(func()) }) *CruiseCtlMetrics
NewCruiseCtlMetrics creates a new instance of CruiseCtlMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*CruiseCtlMetrics) ControllerOutput ¶ added in v0.31.0
func (_m *CruiseCtlMetrics) ControllerOutput(duration time.Duration)
ControllerOutput provides a mock function with given fields: duration
func (*CruiseCtlMetrics) PIDError ¶ added in v0.31.0
func (_m *CruiseCtlMetrics) PIDError(p float64, i float64, d float64)
PIDError provides a mock function with given fields: p, i, d
func (*CruiseCtlMetrics) ProposalPublicationDelay ¶ added in v0.33.30
func (_m *CruiseCtlMetrics) ProposalPublicationDelay(duration time.Duration)
ProposalPublicationDelay provides a mock function with given fields: duration
func (*CruiseCtlMetrics) TargetProposalDuration ¶ added in v0.31.0
func (_m *CruiseCtlMetrics) TargetProposalDuration(duration time.Duration)
TargetProposalDuration provides a mock function with given fields: duration
type DHTMetrics ¶ added in v0.26.17
DHTMetrics is an autogenerated mock type for the DHTMetrics type
func NewDHTMetrics ¶ added in v0.26.17
func NewDHTMetrics(t interface { mock.TestingT Cleanup(func()) }) *DHTMetrics
NewDHTMetrics creates a new instance of DHTMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*DHTMetrics) RoutingTablePeerAdded ¶ added in v0.26.17
func (_m *DHTMetrics) RoutingTablePeerAdded()
RoutingTablePeerAdded provides a mock function with given fields:
func (*DHTMetrics) RoutingTablePeerRemoved ¶ added in v0.26.17
func (_m *DHTMetrics) RoutingTablePeerRemoved()
RoutingTablePeerRemoved provides a mock function with given fields:
type DKGBroker ¶ added in v0.20.0
DKGBroker is an autogenerated mock type for the DKGBroker type
func NewDKGBroker ¶ added in v0.26.1
NewDKGBroker creates a new instance of DKGBroker. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*DKGBroker) Broadcast ¶ added in v0.20.0
Broadcast provides a mock function with given fields: data
func (*DKGBroker) Disqualify ¶ added in v0.20.0
Disqualify provides a mock function with given fields: participant, log
func (*DKGBroker) FlagMisbehavior ¶ added in v0.20.0
FlagMisbehavior provides a mock function with given fields: participant, log
func (*DKGBroker) GetBroadcastMsgCh ¶ added in v0.20.0
func (_m *DKGBroker) GetBroadcastMsgCh() <-chan messages.BroadcastDKGMessage
GetBroadcastMsgCh provides a mock function with given fields:
func (*DKGBroker) GetPrivateMsgCh ¶ added in v0.20.0
func (_m *DKGBroker) GetPrivateMsgCh() <-chan messages.PrivDKGMessageIn
GetPrivateMsgCh provides a mock function with given fields:
func (*DKGBroker) Poll ¶ added in v0.20.0
func (_m *DKGBroker) Poll(referenceBlock flow.Identifier) error
Poll provides a mock function with given fields: referenceBlock
func (*DKGBroker) PrivateSend ¶ added in v0.20.0
PrivateSend provides a mock function with given fields: dest, data
type DKGContractClient ¶ added in v0.20.0
DKGContractClient is an autogenerated mock type for the DKGContractClient type
func NewDKGContractClient ¶ added in v0.26.1
func NewDKGContractClient(t interface { mock.TestingT Cleanup(func()) }) *DKGContractClient
NewDKGContractClient creates a new instance of DKGContractClient. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*DKGContractClient) Broadcast ¶ added in v0.20.0
func (_m *DKGContractClient) Broadcast(msg messages.BroadcastDKGMessage) error
Broadcast provides a mock function with given fields: msg
func (*DKGContractClient) ReadBroadcast ¶ added in v0.20.0
func (_m *DKGContractClient) ReadBroadcast(fromIndex uint, referenceBlock flow.Identifier) ([]messages.BroadcastDKGMessage, error)
ReadBroadcast provides a mock function with given fields: fromIndex, referenceBlock
func (*DKGContractClient) SubmitResult ¶ added in v0.20.0
SubmitResult provides a mock function with given fields: _a0, _a1
type DKGController ¶ added in v0.20.0
DKGController is an autogenerated mock type for the DKGController type
func NewDKGController ¶ added in v0.26.1
func NewDKGController(t interface { mock.TestingT Cleanup(func()) }) *DKGController
NewDKGController creates a new instance of DKGController. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*DKGController) End ¶ added in v0.20.0
func (_m *DKGController) End() error
End provides a mock function with given fields:
func (*DKGController) EndPhase1 ¶ added in v0.20.0
func (_m *DKGController) EndPhase1() error
EndPhase1 provides a mock function with given fields:
func (*DKGController) EndPhase2 ¶ added in v0.20.0
func (_m *DKGController) EndPhase2() error
EndPhase2 provides a mock function with given fields:
func (*DKGController) GetArtifacts ¶ added in v0.20.0
func (_m *DKGController) GetArtifacts() (crypto.PrivateKey, crypto.PublicKey, []crypto.PublicKey)
GetArtifacts provides a mock function with given fields:
func (*DKGController) GetIndex ¶ added in v0.20.0
func (_m *DKGController) GetIndex() int
GetIndex provides a mock function with given fields:
func (*DKGController) Poll ¶ added in v0.20.0
func (_m *DKGController) Poll(blockReference flow.Identifier) error
Poll provides a mock function with given fields: blockReference
func (*DKGController) Run ¶ added in v0.20.0
func (_m *DKGController) Run() error
Run provides a mock function with given fields:
func (*DKGController) Shutdown ¶ added in v0.20.0
func (_m *DKGController) Shutdown()
Shutdown provides a mock function with given fields:
func (*DKGController) SubmitResult ¶ added in v0.20.0
func (_m *DKGController) SubmitResult() error
SubmitResult provides a mock function with given fields:
type DKGControllerFactory ¶ added in v0.20.0
DKGControllerFactory is an autogenerated mock type for the DKGControllerFactory type
func NewDKGControllerFactory ¶ added in v0.26.1
func NewDKGControllerFactory(t interface { mock.TestingT Cleanup(func()) }) *DKGControllerFactory
NewDKGControllerFactory creates a new instance of DKGControllerFactory. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*DKGControllerFactory) Create ¶ added in v0.20.0
func (_m *DKGControllerFactory) Create(dkgInstanceID string, participants flow.GenericIdentityList[flow.IdentitySkeleton], seed []byte) (module.DKGController, error)
Create provides a mock function with given fields: dkgInstanceID, participants, seed
type EVMMetrics ¶ added in v0.36.3
EVMMetrics is an autogenerated mock type for the EVMMetrics type
func NewEVMMetrics ¶ added in v0.36.3
func NewEVMMetrics(t interface { mock.TestingT Cleanup(func()) }) *EVMMetrics
NewEVMMetrics creates a new instance of EVMMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*EVMMetrics) EVMBlockExecuted ¶ added in v0.36.3
func (_m *EVMMetrics) EVMBlockExecuted(txCount int, totalGasUsed uint64, totalSupplyInFlow float64)
EVMBlockExecuted provides a mock function with given fields: txCount, totalGasUsed, totalSupplyInFlow
func (*EVMMetrics) EVMTransactionExecuted ¶ added in v0.36.3
func (_m *EVMMetrics) EVMTransactionExecuted(gasUsed uint64, isDirectCall bool, failed bool)
EVMTransactionExecuted provides a mock function with given fields: gasUsed, isDirectCall, failed
func (*EVMMetrics) SetNumberOfDeployedCOAs ¶ added in v0.36.3
func (_m *EVMMetrics) SetNumberOfDeployedCOAs(count uint64)
SetNumberOfDeployedCOAs provides a mock function with given fields: count
type EngineMetrics ¶
EngineMetrics is an autogenerated mock type for the EngineMetrics type
func NewEngineMetrics ¶ added in v0.26.1
func NewEngineMetrics(t interface { mock.TestingT Cleanup(func()) }) *EngineMetrics
NewEngineMetrics creates a new instance of EngineMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*EngineMetrics) InboundMessageDropped ¶ added in v0.29.0
func (_m *EngineMetrics) InboundMessageDropped(engine string, messages string)
InboundMessageDropped provides a mock function with given fields: engine, messages
func (*EngineMetrics) MessageHandled ¶
func (_m *EngineMetrics) MessageHandled(engine string, messages string)
MessageHandled provides a mock function with given fields: engine, messages
func (*EngineMetrics) MessageReceived ¶
func (_m *EngineMetrics) MessageReceived(engine string, message string)
MessageReceived provides a mock function with given fields: engine, message
func (*EngineMetrics) MessageSent ¶
func (_m *EngineMetrics) MessageSent(engine string, message string)
MessageSent provides a mock function with given fields: engine, message
func (*EngineMetrics) OutboundMessageDropped ¶ added in v0.29.0
func (_m *EngineMetrics) OutboundMessageDropped(engine string, messages string)
OutboundMessageDropped provides a mock function with given fields: engine, messages
type EntriesFunc ¶ added in v0.26.1
EntriesFunc is an autogenerated mock type for the EntriesFunc type
func NewEntriesFunc ¶ added in v0.26.1
func NewEntriesFunc(t interface { mock.TestingT Cleanup(func()) }) *EntriesFunc
NewEntriesFunc creates a new instance of EntriesFunc. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*EntriesFunc) Execute ¶ added in v0.26.1
func (_m *EntriesFunc) Execute() uint
Execute provides a mock function with given fields:
type EpochLookup ¶ added in v0.20.0
EpochLookup is an autogenerated mock type for the EpochLookup type
func NewEpochLookup ¶ added in v0.26.1
func NewEpochLookup(t interface { mock.TestingT Cleanup(func()) }) *EpochLookup
NewEpochLookup creates a new instance of EpochLookup. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*EpochLookup) EpochForView ¶ added in v0.20.0
func (_m *EpochLookup) EpochForView(view uint64) (uint64, error)
EpochForView provides a mock function with given fields: view
type ExecutionDataProviderMetrics ¶ added in v0.27.2
ExecutionDataProviderMetrics is an autogenerated mock type for the ExecutionDataProviderMetrics type
func NewExecutionDataProviderMetrics ¶ added in v0.27.2
func NewExecutionDataProviderMetrics(t interface { mock.TestingT Cleanup(func()) }) *ExecutionDataProviderMetrics
NewExecutionDataProviderMetrics creates a new instance of ExecutionDataProviderMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ExecutionDataProviderMetrics) AddBlobsFailed ¶ added in v0.27.2
func (_m *ExecutionDataProviderMetrics) AddBlobsFailed()
AddBlobsFailed provides a mock function with given fields:
func (*ExecutionDataProviderMetrics) AddBlobsSucceeded ¶ added in v0.27.2
func (_m *ExecutionDataProviderMetrics) AddBlobsSucceeded(duration time.Duration, totalSize uint64)
AddBlobsSucceeded provides a mock function with given fields: duration, totalSize
func (*ExecutionDataProviderMetrics) RootIDComputed ¶ added in v0.27.2
func (_m *ExecutionDataProviderMetrics) RootIDComputed(duration time.Duration, numberOfChunks int)
RootIDComputed provides a mock function with given fields: duration, numberOfChunks
type ExecutionDataPrunerMetrics ¶ added in v0.27.2
ExecutionDataPrunerMetrics is an autogenerated mock type for the ExecutionDataPrunerMetrics type
func NewExecutionDataPrunerMetrics ¶ added in v0.27.2
func NewExecutionDataPrunerMetrics(t interface { mock.TestingT Cleanup(func()) }) *ExecutionDataPrunerMetrics
NewExecutionDataPrunerMetrics creates a new instance of ExecutionDataPrunerMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
type ExecutionDataRequesterMetrics ¶ added in v0.26.2
ExecutionDataRequesterMetrics is an autogenerated mock type for the ExecutionDataRequesterMetrics type
func NewExecutionDataRequesterMetrics ¶ added in v0.26.2
func NewExecutionDataRequesterMetrics(t interface { mock.TestingT Cleanup(func()) }) *ExecutionDataRequesterMetrics
NewExecutionDataRequesterMetrics creates a new instance of ExecutionDataRequesterMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ExecutionDataRequesterMetrics) ExecutionDataFetchFinished ¶ added in v0.26.2
func (_m *ExecutionDataRequesterMetrics) ExecutionDataFetchFinished(duration time.Duration, success bool, height uint64)
ExecutionDataFetchFinished provides a mock function with given fields: duration, success, height
func (*ExecutionDataRequesterMetrics) ExecutionDataFetchStarted ¶ added in v0.26.2
func (_m *ExecutionDataRequesterMetrics) ExecutionDataFetchStarted()
ExecutionDataFetchStarted provides a mock function with given fields:
func (*ExecutionDataRequesterMetrics) FetchRetried ¶ added in v0.26.2
func (_m *ExecutionDataRequesterMetrics) FetchRetried()
FetchRetried provides a mock function with given fields:
func (*ExecutionDataRequesterMetrics) NotificationSent ¶ added in v0.26.2
func (_m *ExecutionDataRequesterMetrics) NotificationSent(height uint64)
NotificationSent provides a mock function with given fields: height
type ExecutionDataRequesterV2Metrics ¶ added in v0.27.2
ExecutionDataRequesterV2Metrics is an autogenerated mock type for the ExecutionDataRequesterV2Metrics type
func NewExecutionDataRequesterV2Metrics ¶ added in v0.27.2
func NewExecutionDataRequesterV2Metrics(t interface { mock.TestingT Cleanup(func()) }) *ExecutionDataRequesterV2Metrics
NewExecutionDataRequesterV2Metrics creates a new instance of ExecutionDataRequesterV2Metrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ExecutionDataRequesterV2Metrics) FulfilledHeight ¶ added in v0.27.2
func (_m *ExecutionDataRequesterV2Metrics) FulfilledHeight(blockHeight uint64)
FulfilledHeight provides a mock function with given fields: blockHeight
func (*ExecutionDataRequesterV2Metrics) ReceiptSkipped ¶ added in v0.27.2
func (_m *ExecutionDataRequesterV2Metrics) ReceiptSkipped()
ReceiptSkipped provides a mock function with given fields:
func (*ExecutionDataRequesterV2Metrics) RequestCanceled ¶ added in v0.27.2
func (_m *ExecutionDataRequesterV2Metrics) RequestCanceled()
RequestCanceled provides a mock function with given fields:
func (*ExecutionDataRequesterV2Metrics) RequestFailed ¶ added in v0.27.2
func (_m *ExecutionDataRequesterV2Metrics) RequestFailed(duration time.Duration, retryable bool)
RequestFailed provides a mock function with given fields: duration, retryable
func (*ExecutionDataRequesterV2Metrics) RequestSucceeded ¶ added in v0.27.2
func (_m *ExecutionDataRequesterV2Metrics) RequestSucceeded(blockHeight uint64, duration time.Duration, totalSize uint64, numberOfAttempts int)
RequestSucceeded provides a mock function with given fields: blockHeight, duration, totalSize, numberOfAttempts
func (*ExecutionDataRequesterV2Metrics) ResponseDropped ¶ added in v0.27.2
func (_m *ExecutionDataRequesterV2Metrics) ResponseDropped()
ResponseDropped provides a mock function with given fields:
type ExecutionMetrics ¶
ExecutionMetrics is an autogenerated mock type for the ExecutionMetrics type
func NewExecutionMetrics ¶ added in v0.26.1
func NewExecutionMetrics(t interface { mock.TestingT Cleanup(func()) }) *ExecutionMetrics
NewExecutionMetrics creates a new instance of ExecutionMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ExecutionMetrics) ChunkDataPackRequestProcessed ¶ added in v0.28.0
func (_m *ExecutionMetrics) ChunkDataPackRequestProcessed()
ChunkDataPackRequestProcessed provides a mock function with given fields:
func (*ExecutionMetrics) EVMBlockExecuted ¶ added in v0.36.3
func (_m *ExecutionMetrics) EVMBlockExecuted(txCount int, totalGasUsed uint64, totalSupplyInFlow float64)
EVMBlockExecuted provides a mock function with given fields: txCount, totalGasUsed, totalSupplyInFlow
func (*ExecutionMetrics) EVMTransactionExecuted ¶ added in v0.36.3
func (_m *ExecutionMetrics) EVMTransactionExecuted(gasUsed uint64, isDirectCall bool, failed bool)
EVMTransactionExecuted provides a mock function with given fields: gasUsed, isDirectCall, failed
func (*ExecutionMetrics) ExecutionBlockCachedPrograms ¶ added in v0.29.17
func (_m *ExecutionMetrics) ExecutionBlockCachedPrograms(programs int)
ExecutionBlockCachedPrograms provides a mock function with given fields: programs
func (*ExecutionMetrics) ExecutionBlockDataUploadFinished ¶ added in v0.20.6
func (_m *ExecutionMetrics) ExecutionBlockDataUploadFinished(dur time.Duration)
ExecutionBlockDataUploadFinished provides a mock function with given fields: dur
func (*ExecutionMetrics) ExecutionBlockDataUploadStarted ¶ added in v0.20.6
func (_m *ExecutionMetrics) ExecutionBlockDataUploadStarted()
ExecutionBlockDataUploadStarted provides a mock function with given fields:
func (*ExecutionMetrics) ExecutionBlockExecuted ¶ added in v0.18.3
func (_m *ExecutionMetrics) ExecutionBlockExecuted(dur time.Duration, stats module.BlockExecutionResultStats)
ExecutionBlockExecuted provides a mock function with given fields: dur, stats
func (*ExecutionMetrics) ExecutionBlockExecutionEffortVectorComponent ¶ added in v0.28.2
func (_m *ExecutionMetrics) ExecutionBlockExecutionEffortVectorComponent(_a0 string, _a1 uint)
ExecutionBlockExecutionEffortVectorComponent provides a mock function with given fields: _a0, _a1
func (*ExecutionMetrics) ExecutionCheckpointSize ¶ added in v0.33.10
func (_m *ExecutionMetrics) ExecutionCheckpointSize(bytes uint64)
ExecutionCheckpointSize provides a mock function with given fields: bytes
func (*ExecutionMetrics) ExecutionChunkDataPackGenerated ¶ added in v0.28.7
func (_m *ExecutionMetrics) ExecutionChunkDataPackGenerated(proofSize int, numberOfTransactions int)
ExecutionChunkDataPackGenerated provides a mock function with given fields: proofSize, numberOfTransactions
func (*ExecutionMetrics) ExecutionCollectionExecuted ¶ added in v0.18.3
func (_m *ExecutionMetrics) ExecutionCollectionExecuted(dur time.Duration, stats module.CollectionExecutionResultStats)
ExecutionCollectionExecuted provides a mock function with given fields: dur, stats
func (*ExecutionMetrics) ExecutionCollectionRequestRetried ¶
func (_m *ExecutionMetrics) ExecutionCollectionRequestRetried()
ExecutionCollectionRequestRetried provides a mock function with given fields:
func (*ExecutionMetrics) ExecutionCollectionRequestSent ¶
func (_m *ExecutionMetrics) ExecutionCollectionRequestSent()
ExecutionCollectionRequestSent provides a mock function with given fields:
func (*ExecutionMetrics) ExecutionComputationResultUploadRetried ¶ added in v0.28.0
func (_m *ExecutionMetrics) ExecutionComputationResultUploadRetried()
ExecutionComputationResultUploadRetried provides a mock function with given fields:
func (*ExecutionMetrics) ExecutionComputationResultUploaded ¶ added in v0.28.0
func (_m *ExecutionMetrics) ExecutionComputationResultUploaded()
ExecutionComputationResultUploaded provides a mock function with given fields:
func (*ExecutionMetrics) ExecutionLastExecutedBlockHeight ¶
func (_m *ExecutionMetrics) ExecutionLastExecutedBlockHeight(height uint64)
ExecutionLastExecutedBlockHeight provides a mock function with given fields: height
func (*ExecutionMetrics) ExecutionLastFinalizedExecutedBlockHeight ¶ added in v0.33.1
func (_m *ExecutionMetrics) ExecutionLastFinalizedExecutedBlockHeight(height uint64)
ExecutionLastFinalizedExecutedBlockHeight provides a mock function with given fields: height
func (*ExecutionMetrics) ExecutionScriptExecuted ¶ added in v0.18.3
func (_m *ExecutionMetrics) ExecutionScriptExecuted(dur time.Duration, compUsed uint64, memoryUsed uint64, memoryEstimate uint64)
ExecutionScriptExecuted provides a mock function with given fields: dur, compUsed, memoryUsed, memoryEstimate
func (*ExecutionMetrics) ExecutionStorageStateCommitment ¶
func (_m *ExecutionMetrics) ExecutionStorageStateCommitment(bytes int64)
ExecutionStorageStateCommitment provides a mock function with given fields: bytes
func (*ExecutionMetrics) ExecutionSync ¶
func (_m *ExecutionMetrics) ExecutionSync(syncing bool)
ExecutionSync provides a mock function with given fields: syncing
func (*ExecutionMetrics) ExecutionTransactionExecuted ¶ added in v0.18.3
func (_m *ExecutionMetrics) ExecutionTransactionExecuted(dur time.Duration, stats module.TransactionExecutionResultStats, info module.TransactionExecutionResultInfo)
ExecutionTransactionExecuted provides a mock function with given fields: dur, stats, info
func (*ExecutionMetrics) FinishBlockReceivedToExecuted ¶
func (_m *ExecutionMetrics) FinishBlockReceivedToExecuted(blockID flow.Identifier)
FinishBlockReceivedToExecuted provides a mock function with given fields: blockID
func (*ExecutionMetrics) ForestApproxMemorySize ¶
func (_m *ExecutionMetrics) ForestApproxMemorySize(bytes uint64)
ForestApproxMemorySize provides a mock function with given fields: bytes
func (*ExecutionMetrics) ForestNumberOfTrees ¶
func (_m *ExecutionMetrics) ForestNumberOfTrees(number uint64)
ForestNumberOfTrees provides a mock function with given fields: number
func (*ExecutionMetrics) LatestTrieMaxDepthTouched ¶ added in v0.25.2
func (_m *ExecutionMetrics) LatestTrieMaxDepthTouched(maxDepth uint16)
LatestTrieMaxDepthTouched provides a mock function with given fields: maxDepth
func (*ExecutionMetrics) LatestTrieRegCount ¶
func (_m *ExecutionMetrics) LatestTrieRegCount(number uint64)
LatestTrieRegCount provides a mock function with given fields: number
func (*ExecutionMetrics) LatestTrieRegCountDiff ¶
func (_m *ExecutionMetrics) LatestTrieRegCountDiff(number int64)
LatestTrieRegCountDiff provides a mock function with given fields: number
func (*ExecutionMetrics) LatestTrieRegSize ¶ added in v0.25.2
func (_m *ExecutionMetrics) LatestTrieRegSize(size uint64)
LatestTrieRegSize provides a mock function with given fields: size
func (*ExecutionMetrics) LatestTrieRegSizeDiff ¶ added in v0.25.2
func (_m *ExecutionMetrics) LatestTrieRegSizeDiff(size int64)
LatestTrieRegSizeDiff provides a mock function with given fields: size
func (*ExecutionMetrics) ProofSize ¶
func (_m *ExecutionMetrics) ProofSize(bytes uint32)
ProofSize provides a mock function with given fields: bytes
func (*ExecutionMetrics) ReadDuration ¶
func (_m *ExecutionMetrics) ReadDuration(duration time.Duration)
ReadDuration provides a mock function with given fields: duration
func (*ExecutionMetrics) ReadDurationPerItem ¶
func (_m *ExecutionMetrics) ReadDurationPerItem(duration time.Duration)
ReadDurationPerItem provides a mock function with given fields: duration
func (*ExecutionMetrics) ReadValuesNumber ¶
func (_m *ExecutionMetrics) ReadValuesNumber(number uint64)
ReadValuesNumber provides a mock function with given fields: number
func (*ExecutionMetrics) ReadValuesSize ¶
func (_m *ExecutionMetrics) ReadValuesSize(byte uint64)
ReadValuesSize provides a mock function with given fields: byte
func (*ExecutionMetrics) RuntimeSetNumberOfAccounts ¶ added in v0.18.3
func (_m *ExecutionMetrics) RuntimeSetNumberOfAccounts(count uint64)
RuntimeSetNumberOfAccounts provides a mock function with given fields: count
func (*ExecutionMetrics) RuntimeTransactionChecked ¶ added in v0.18.3
func (_m *ExecutionMetrics) RuntimeTransactionChecked(dur time.Duration)
RuntimeTransactionChecked provides a mock function with given fields: dur
func (*ExecutionMetrics) RuntimeTransactionInterpreted ¶ added in v0.18.3
func (_m *ExecutionMetrics) RuntimeTransactionInterpreted(dur time.Duration)
RuntimeTransactionInterpreted provides a mock function with given fields: dur
func (*ExecutionMetrics) RuntimeTransactionParsed ¶ added in v0.18.3
func (_m *ExecutionMetrics) RuntimeTransactionParsed(dur time.Duration)
RuntimeTransactionParsed provides a mock function with given fields: dur
func (*ExecutionMetrics) RuntimeTransactionProgramsCacheHit ¶ added in v0.29.17
func (_m *ExecutionMetrics) RuntimeTransactionProgramsCacheHit()
RuntimeTransactionProgramsCacheHit provides a mock function with given fields:
func (*ExecutionMetrics) RuntimeTransactionProgramsCacheMiss ¶ added in v0.29.17
func (_m *ExecutionMetrics) RuntimeTransactionProgramsCacheMiss()
RuntimeTransactionProgramsCacheMiss provides a mock function with given fields:
func (*ExecutionMetrics) SetNumberOfDeployedCOAs ¶ added in v0.36.3
func (_m *ExecutionMetrics) SetNumberOfDeployedCOAs(count uint64)
SetNumberOfDeployedCOAs provides a mock function with given fields: count
func (*ExecutionMetrics) StartBlockReceivedToExecuted ¶
func (_m *ExecutionMetrics) StartBlockReceivedToExecuted(blockID flow.Identifier)
StartBlockReceivedToExecuted provides a mock function with given fields: blockID
func (*ExecutionMetrics) UpdateCollectionMaxHeight ¶ added in v0.27.0
func (_m *ExecutionMetrics) UpdateCollectionMaxHeight(height uint64)
UpdateCollectionMaxHeight provides a mock function with given fields: height
func (*ExecutionMetrics) UpdateCount ¶
func (_m *ExecutionMetrics) UpdateCount()
UpdateCount provides a mock function with given fields:
func (*ExecutionMetrics) UpdateDuration ¶
func (_m *ExecutionMetrics) UpdateDuration(duration time.Duration)
UpdateDuration provides a mock function with given fields: duration
func (*ExecutionMetrics) UpdateDurationPerItem ¶
func (_m *ExecutionMetrics) UpdateDurationPerItem(duration time.Duration)
UpdateDurationPerItem provides a mock function with given fields: duration
func (*ExecutionMetrics) UpdateValuesNumber ¶
func (_m *ExecutionMetrics) UpdateValuesNumber(number uint64)
UpdateValuesNumber provides a mock function with given fields: number
func (*ExecutionMetrics) UpdateValuesSize ¶
func (_m *ExecutionMetrics) UpdateValuesSize(byte uint64)
UpdateValuesSize provides a mock function with given fields: byte
type ExecutionStateIndexerMetrics ¶ added in v0.32.1
ExecutionStateIndexerMetrics is an autogenerated mock type for the ExecutionStateIndexerMetrics type
func NewExecutionStateIndexerMetrics ¶ added in v0.32.1
func NewExecutionStateIndexerMetrics(t interface { mock.TestingT Cleanup(func()) }) *ExecutionStateIndexerMetrics
NewExecutionStateIndexerMetrics creates a new instance of ExecutionStateIndexerMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ExecutionStateIndexerMetrics) BlockIndexed ¶ added in v0.32.1
func (_m *ExecutionStateIndexerMetrics) BlockIndexed(height uint64, duration time.Duration, events int, registers int, transactionResults int)
BlockIndexed provides a mock function with given fields: height, duration, events, registers, transactionResults
func (*ExecutionStateIndexerMetrics) BlockReindexed ¶ added in v0.32.1
func (_m *ExecutionStateIndexerMetrics) BlockReindexed()
BlockReindexed provides a mock function with given fields:
func (*ExecutionStateIndexerMetrics) InitializeLatestHeight ¶ added in v0.32.2
func (_m *ExecutionStateIndexerMetrics) InitializeLatestHeight(height uint64)
InitializeLatestHeight provides a mock function with given fields: height
type FinalizedHeaderCache ¶ added in v0.31.0
FinalizedHeaderCache is an autogenerated mock type for the FinalizedHeaderCache type
func NewFinalizedHeaderCache ¶ added in v0.31.0
func NewFinalizedHeaderCache(t interface { mock.TestingT Cleanup(func()) }) *FinalizedHeaderCache
NewFinalizedHeaderCache creates a new instance of FinalizedHeaderCache. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*FinalizedHeaderCache) Get ¶ added in v0.31.0
func (_m *FinalizedHeaderCache) Get() *flow.Header
Get provides a mock function with given fields:
type Finalizer ¶
Finalizer is an autogenerated mock type for the Finalizer type
func NewFinalizer ¶ added in v0.26.1
NewFinalizer creates a new instance of Finalizer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
type GRPCConnectionPoolMetrics ¶ added in v0.31.10
GRPCConnectionPoolMetrics is an autogenerated mock type for the GRPCConnectionPoolMetrics type
func NewGRPCConnectionPoolMetrics ¶ added in v0.31.10
func NewGRPCConnectionPoolMetrics(t interface { mock.TestingT Cleanup(func()) }) *GRPCConnectionPoolMetrics
NewGRPCConnectionPoolMetrics creates a new instance of GRPCConnectionPoolMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GRPCConnectionPoolMetrics) ConnectionAddedToPool ¶ added in v0.31.10
func (_m *GRPCConnectionPoolMetrics) ConnectionAddedToPool()
ConnectionAddedToPool provides a mock function with given fields:
func (*GRPCConnectionPoolMetrics) ConnectionFromPoolEvicted ¶ added in v0.31.10
func (_m *GRPCConnectionPoolMetrics) ConnectionFromPoolEvicted()
ConnectionFromPoolEvicted provides a mock function with given fields:
func (*GRPCConnectionPoolMetrics) ConnectionFromPoolInvalidated ¶ added in v0.31.10
func (_m *GRPCConnectionPoolMetrics) ConnectionFromPoolInvalidated()
ConnectionFromPoolInvalidated provides a mock function with given fields:
func (*GRPCConnectionPoolMetrics) ConnectionFromPoolReused ¶ added in v0.31.10
func (_m *GRPCConnectionPoolMetrics) ConnectionFromPoolReused()
ConnectionFromPoolReused provides a mock function with given fields:
func (*GRPCConnectionPoolMetrics) ConnectionFromPoolUpdated ¶ added in v0.31.10
func (_m *GRPCConnectionPoolMetrics) ConnectionFromPoolUpdated()
ConnectionFromPoolUpdated provides a mock function with given fields:
func (*GRPCConnectionPoolMetrics) NewConnectionEstablished ¶ added in v0.31.10
func (_m *GRPCConnectionPoolMetrics) NewConnectionEstablished()
NewConnectionEstablished provides a mock function with given fields:
func (*GRPCConnectionPoolMetrics) TotalConnectionsInPool ¶ added in v0.31.10
func (_m *GRPCConnectionPoolMetrics) TotalConnectionsInPool(connectionCount uint, connectionPoolSize uint)
TotalConnectionsInPool provides a mock function with given fields: connectionCount, connectionPoolSize
type GossipSubMetrics ¶ added in v0.30.0
GossipSubMetrics is an autogenerated mock type for the GossipSubMetrics type
func NewGossipSubMetrics ¶ added in v0.30.0
func NewGossipSubMetrics(t interface { mock.TestingT Cleanup(func()) }) *GossipSubMetrics
NewGossipSubMetrics creates a new instance of GossipSubMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubMetrics) AsyncProcessingFinished ¶ added in v0.31.0
func (_m *GossipSubMetrics) AsyncProcessingFinished(duration time.Duration)
AsyncProcessingFinished provides a mock function with given fields: duration
func (*GossipSubMetrics) AsyncProcessingStarted ¶ added in v0.31.0
func (_m *GossipSubMetrics) AsyncProcessingStarted()
AsyncProcessingStarted provides a mock function with given fields:
func (*GossipSubMetrics) OnActiveClusterIDsNotSetErr ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnActiveClusterIDsNotSetErr()
OnActiveClusterIDsNotSetErr provides a mock function with given fields:
func (*GossipSubMetrics) OnAppSpecificScoreUpdated ¶ added in v0.30.0
func (_m *GossipSubMetrics) OnAppSpecificScoreUpdated(_a0 float64)
OnAppSpecificScoreUpdated provides a mock function with given fields: _a0
func (*GossipSubMetrics) OnBehaviourPenaltyUpdated ¶ added in v0.30.0
func (_m *GossipSubMetrics) OnBehaviourPenaltyUpdated(_a0 float64)
OnBehaviourPenaltyUpdated provides a mock function with given fields: _a0
func (*GossipSubMetrics) OnControlMessagesTruncated ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
OnControlMessagesTruncated provides a mock function with given fields: messageType, diff
func (*GossipSubMetrics) OnFirstMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *GossipSubMetrics) OnFirstMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnFirstMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*GossipSubMetrics) OnGraftDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnGraftDuplicateTopicIdsExceedThreshold()
OnGraftDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubMetrics) OnGraftInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *GossipSubMetrics) OnGraftInvalidTopicIdsExceedThreshold()
OnGraftInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubMetrics) OnGraftMessageInspected ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnGraftMessageInspected(duplicateTopicIds int, invalidTopicIds int)
OnGraftMessageInspected provides a mock function with given fields: duplicateTopicIds, invalidTopicIds
func (*GossipSubMetrics) OnIHaveControlMessageIdsTruncated ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnIHaveControlMessageIdsTruncated(diff int)
OnIHaveControlMessageIdsTruncated provides a mock function with given fields: diff
func (*GossipSubMetrics) OnIHaveDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnIHaveDuplicateMessageIdsExceedThreshold()
OnIHaveDuplicateMessageIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubMetrics) OnIHaveDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnIHaveDuplicateTopicIdsExceedThreshold()
OnIHaveDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubMetrics) OnIHaveInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *GossipSubMetrics) OnIHaveInvalidTopicIdsExceedThreshold()
OnIHaveInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubMetrics) OnIHaveMessageIDsReceived ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
OnIHaveMessageIDsReceived provides a mock function with given fields: channel, msgIdCount
func (*GossipSubMetrics) OnIHaveMessagesInspected ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int, invalidTopicIds int)
OnIHaveMessagesInspected provides a mock function with given fields: duplicateTopicIds, duplicateMessageIds, invalidTopicIds
func (*GossipSubMetrics) OnIPColocationFactorUpdated ¶ added in v0.30.0
func (_m *GossipSubMetrics) OnIPColocationFactorUpdated(_a0 float64)
OnIPColocationFactorUpdated provides a mock function with given fields: _a0
func (*GossipSubMetrics) OnIWantCacheMissMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnIWantCacheMissMessageIdsExceedThreshold()
OnIWantCacheMissMessageIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubMetrics) OnIWantControlMessageIdsTruncated ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnIWantControlMessageIdsTruncated(diff int)
OnIWantControlMessageIdsTruncated provides a mock function with given fields: diff
func (*GossipSubMetrics) OnIWantDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnIWantDuplicateMessageIdsExceedThreshold()
OnIWantDuplicateMessageIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubMetrics) OnIWantMessageIDsReceived ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnIWantMessageIDsReceived(msgIdCount int)
OnIWantMessageIDsReceived provides a mock function with given fields: msgIdCount
func (*GossipSubMetrics) OnIWantMessagesInspected ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
OnIWantMessagesInspected provides a mock function with given fields: duplicateCount, cacheMissCount
func (*GossipSubMetrics) OnIncomingRpcReceived ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnIncomingRpcReceived(iHaveCount int, iWantCount int, graftCount int, pruneCount int, msgCount int)
OnIncomingRpcReceived provides a mock function with given fields: iHaveCount, iWantCount, graftCount, pruneCount, msgCount
func (*GossipSubMetrics) OnInvalidControlMessageNotificationSent ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnInvalidControlMessageNotificationSent()
OnInvalidControlMessageNotificationSent provides a mock function with given fields:
func (*GossipSubMetrics) OnInvalidMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *GossipSubMetrics) OnInvalidMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnInvalidMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*GossipSubMetrics) OnInvalidTopicIdDetectedForControlMessage ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
OnInvalidTopicIdDetectedForControlMessage provides a mock function with given fields: messageType
func (*GossipSubMetrics) OnLocalMeshSizeUpdated ¶ added in v0.30.0
func (_m *GossipSubMetrics) OnLocalMeshSizeUpdated(topic string, size int)
OnLocalMeshSizeUpdated provides a mock function with given fields: topic, size
func (*GossipSubMetrics) OnLocalPeerJoinedTopic ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnLocalPeerJoinedTopic()
OnLocalPeerJoinedTopic provides a mock function with given fields:
func (*GossipSubMetrics) OnLocalPeerLeftTopic ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnLocalPeerLeftTopic()
OnLocalPeerLeftTopic provides a mock function with given fields:
func (*GossipSubMetrics) OnMeshMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *GossipSubMetrics) OnMeshMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnMeshMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*GossipSubMetrics) OnMessageDeliveredToAllSubscribers ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnMessageDeliveredToAllSubscribers(size int)
OnMessageDeliveredToAllSubscribers provides a mock function with given fields: size
func (*GossipSubMetrics) OnMessageDuplicate ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnMessageDuplicate(size int)
OnMessageDuplicate provides a mock function with given fields: size
func (*GossipSubMetrics) OnMessageEnteredValidation ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnMessageEnteredValidation(size int)
OnMessageEnteredValidation provides a mock function with given fields: size
func (*GossipSubMetrics) OnMessageRejected ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnMessageRejected(size int, reason string)
OnMessageRejected provides a mock function with given fields: size, reason
func (*GossipSubMetrics) OnOutboundRpcDropped ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnOutboundRpcDropped()
OnOutboundRpcDropped provides a mock function with given fields:
func (*GossipSubMetrics) OnOverallPeerScoreUpdated ¶ added in v0.30.0
func (_m *GossipSubMetrics) OnOverallPeerScoreUpdated(_a0 float64)
OnOverallPeerScoreUpdated provides a mock function with given fields: _a0
func (*GossipSubMetrics) OnPeerAddedToProtocol ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnPeerAddedToProtocol(protocol string)
OnPeerAddedToProtocol provides a mock function with given fields: protocol
func (*GossipSubMetrics) OnPeerGraftTopic ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnPeerGraftTopic(topic string)
OnPeerGraftTopic provides a mock function with given fields: topic
func (*GossipSubMetrics) OnPeerPruneTopic ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnPeerPruneTopic(topic string)
OnPeerPruneTopic provides a mock function with given fields: topic
func (*GossipSubMetrics) OnPeerRemovedFromProtocol ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnPeerRemovedFromProtocol()
OnPeerRemovedFromProtocol provides a mock function with given fields:
func (*GossipSubMetrics) OnPeerThrottled ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnPeerThrottled()
OnPeerThrottled provides a mock function with given fields:
func (*GossipSubMetrics) OnPruneDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnPruneDuplicateTopicIdsExceedThreshold()
OnPruneDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubMetrics) OnPruneInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *GossipSubMetrics) OnPruneInvalidTopicIdsExceedThreshold()
OnPruneInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubMetrics) OnPruneMessageInspected ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnPruneMessageInspected(duplicateTopicIds int, invalidTopicIds int)
OnPruneMessageInspected provides a mock function with given fields: duplicateTopicIds, invalidTopicIds
func (*GossipSubMetrics) OnPublishMessageInspected ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, invalidSendersCount int)
OnPublishMessageInspected provides a mock function with given fields: totalErrCount, invalidTopicIdsCount, invalidSubscriptionsCount, invalidSendersCount
func (*GossipSubMetrics) OnPublishMessagesInspectionErrorExceedsThreshold ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnPublishMessagesInspectionErrorExceedsThreshold()
OnPublishMessagesInspectionErrorExceedsThreshold provides a mock function with given fields:
func (*GossipSubMetrics) OnRpcReceived ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnRpcReceived(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
OnRpcReceived provides a mock function with given fields: msgCount, iHaveCount, iWantCount, graftCount, pruneCount
func (*GossipSubMetrics) OnRpcRejectedFromUnknownSender ¶ added in v0.33.30
func (_m *GossipSubMetrics) OnRpcRejectedFromUnknownSender()
OnRpcRejectedFromUnknownSender provides a mock function with given fields:
func (*GossipSubMetrics) OnRpcSent ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnRpcSent(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
OnRpcSent provides a mock function with given fields: msgCount, iHaveCount, iWantCount, graftCount, pruneCount
func (*GossipSubMetrics) OnTimeInMeshUpdated ¶ added in v0.30.0
func (_m *GossipSubMetrics) OnTimeInMeshUpdated(_a0 channels.Topic, _a1 time.Duration)
OnTimeInMeshUpdated provides a mock function with given fields: _a0, _a1
func (*GossipSubMetrics) OnUndeliveredMessage ¶ added in v0.33.1
func (_m *GossipSubMetrics) OnUndeliveredMessage()
OnUndeliveredMessage provides a mock function with given fields:
func (*GossipSubMetrics) OnUnstakedPeerInspectionFailed ¶ added in v0.33.7
func (_m *GossipSubMetrics) OnUnstakedPeerInspectionFailed()
OnUnstakedPeerInspectionFailed provides a mock function with given fields:
func (*GossipSubMetrics) SetWarningStateCount ¶ added in v0.30.0
func (_m *GossipSubMetrics) SetWarningStateCount(_a0 uint)
SetWarningStateCount provides a mock function with given fields: _a0
type GossipSubRpcInspectorMetrics ¶ added in v0.33.1
GossipSubRpcInspectorMetrics is an autogenerated mock type for the GossipSubRpcInspectorMetrics type
func NewGossipSubRpcInspectorMetrics ¶ added in v0.33.1
func NewGossipSubRpcInspectorMetrics(t interface { mock.TestingT Cleanup(func()) }) *GossipSubRpcInspectorMetrics
NewGossipSubRpcInspectorMetrics creates a new instance of GossipSubRpcInspectorMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubRpcInspectorMetrics) OnIHaveMessageIDsReceived ¶ added in v0.33.1
func (_m *GossipSubRpcInspectorMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
OnIHaveMessageIDsReceived provides a mock function with given fields: channel, msgIdCount
func (*GossipSubRpcInspectorMetrics) OnIWantMessageIDsReceived ¶ added in v0.33.1
func (_m *GossipSubRpcInspectorMetrics) OnIWantMessageIDsReceived(msgIdCount int)
OnIWantMessageIDsReceived provides a mock function with given fields: msgIdCount
func (*GossipSubRpcInspectorMetrics) OnIncomingRpcReceived ¶ added in v0.33.1
func (_m *GossipSubRpcInspectorMetrics) OnIncomingRpcReceived(iHaveCount int, iWantCount int, graftCount int, pruneCount int, msgCount int)
OnIncomingRpcReceived provides a mock function with given fields: iHaveCount, iWantCount, graftCount, pruneCount, msgCount
type GossipSubRpcValidationInspectorMetrics ¶ added in v0.31.0
GossipSubRpcValidationInspectorMetrics is an autogenerated mock type for the GossipSubRpcValidationInspectorMetrics type
func NewGossipSubRpcValidationInspectorMetrics ¶ added in v0.31.0
func NewGossipSubRpcValidationInspectorMetrics(t interface { mock.TestingT Cleanup(func()) }) *GossipSubRpcValidationInspectorMetrics
NewGossipSubRpcValidationInspectorMetrics creates a new instance of GossipSubRpcValidationInspectorMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubRpcValidationInspectorMetrics) AsyncProcessingFinished ¶ added in v0.31.0
func (_m *GossipSubRpcValidationInspectorMetrics) AsyncProcessingFinished(duration time.Duration)
AsyncProcessingFinished provides a mock function with given fields: duration
func (*GossipSubRpcValidationInspectorMetrics) AsyncProcessingStarted ¶ added in v0.31.0
func (_m *GossipSubRpcValidationInspectorMetrics) AsyncProcessingStarted()
AsyncProcessingStarted provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnActiveClusterIDsNotSetErr ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnActiveClusterIDsNotSetErr()
OnActiveClusterIDsNotSetErr provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnControlMessagesTruncated ¶ added in v0.33.1
func (_m *GossipSubRpcValidationInspectorMetrics) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
OnControlMessagesTruncated provides a mock function with given fields: messageType, diff
func (*GossipSubRpcValidationInspectorMetrics) OnGraftDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnGraftDuplicateTopicIdsExceedThreshold()
OnGraftDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnGraftInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *GossipSubRpcValidationInspectorMetrics) OnGraftInvalidTopicIdsExceedThreshold()
OnGraftInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnGraftMessageInspected ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnGraftMessageInspected(duplicateTopicIds int, invalidTopicIds int)
OnGraftMessageInspected provides a mock function with given fields: duplicateTopicIds, invalidTopicIds
func (*GossipSubRpcValidationInspectorMetrics) OnIHaveControlMessageIdsTruncated ¶ added in v0.33.1
func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveControlMessageIdsTruncated(diff int)
OnIHaveControlMessageIdsTruncated provides a mock function with given fields: diff
func (*GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateMessageIdsExceedThreshold()
OnIHaveDuplicateMessageIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveDuplicateTopicIdsExceedThreshold()
OnIHaveDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnIHaveInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveInvalidTopicIdsExceedThreshold()
OnIHaveInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnIHaveMessageIDsReceived ¶ added in v0.33.1
func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
OnIHaveMessageIDsReceived provides a mock function with given fields: channel, msgIdCount
func (*GossipSubRpcValidationInspectorMetrics) OnIHaveMessagesInspected ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int, invalidTopicIds int)
OnIHaveMessagesInspected provides a mock function with given fields: duplicateTopicIds, duplicateMessageIds, invalidTopicIds
func (*GossipSubRpcValidationInspectorMetrics) OnIWantCacheMissMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnIWantCacheMissMessageIdsExceedThreshold()
OnIWantCacheMissMessageIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnIWantControlMessageIdsTruncated ¶ added in v0.33.1
func (_m *GossipSubRpcValidationInspectorMetrics) OnIWantControlMessageIdsTruncated(diff int)
OnIWantControlMessageIdsTruncated provides a mock function with given fields: diff
func (*GossipSubRpcValidationInspectorMetrics) OnIWantDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnIWantDuplicateMessageIdsExceedThreshold()
OnIWantDuplicateMessageIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnIWantMessageIDsReceived ¶ added in v0.33.1
func (_m *GossipSubRpcValidationInspectorMetrics) OnIWantMessageIDsReceived(msgIdCount int)
OnIWantMessageIDsReceived provides a mock function with given fields: msgIdCount
func (*GossipSubRpcValidationInspectorMetrics) OnIWantMessagesInspected ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
OnIWantMessagesInspected provides a mock function with given fields: duplicateCount, cacheMissCount
func (*GossipSubRpcValidationInspectorMetrics) OnIncomingRpcReceived ¶ added in v0.33.1
func (_m *GossipSubRpcValidationInspectorMetrics) OnIncomingRpcReceived(iHaveCount int, iWantCount int, graftCount int, pruneCount int, msgCount int)
OnIncomingRpcReceived provides a mock function with given fields: iHaveCount, iWantCount, graftCount, pruneCount, msgCount
func (*GossipSubRpcValidationInspectorMetrics) OnInvalidControlMessageNotificationSent ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnInvalidControlMessageNotificationSent()
OnInvalidControlMessageNotificationSent provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnInvalidTopicIdDetectedForControlMessage ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
OnInvalidTopicIdDetectedForControlMessage provides a mock function with given fields: messageType
func (*GossipSubRpcValidationInspectorMetrics) OnPruneDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnPruneDuplicateTopicIdsExceedThreshold()
OnPruneDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnPruneInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *GossipSubRpcValidationInspectorMetrics) OnPruneInvalidTopicIdsExceedThreshold()
OnPruneInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnPruneMessageInspected ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnPruneMessageInspected(duplicateTopicIds int, invalidTopicIds int)
OnPruneMessageInspected provides a mock function with given fields: duplicateTopicIds, invalidTopicIds
func (*GossipSubRpcValidationInspectorMetrics) OnPublishMessageInspected ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, invalidSendersCount int)
OnPublishMessageInspected provides a mock function with given fields: totalErrCount, invalidTopicIdsCount, invalidSubscriptionsCount, invalidSendersCount
func (*GossipSubRpcValidationInspectorMetrics) OnPublishMessagesInspectionErrorExceedsThreshold ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnPublishMessagesInspectionErrorExceedsThreshold()
OnPublishMessagesInspectionErrorExceedsThreshold provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnRpcRejectedFromUnknownSender ¶ added in v0.33.30
func (_m *GossipSubRpcValidationInspectorMetrics) OnRpcRejectedFromUnknownSender()
OnRpcRejectedFromUnknownSender provides a mock function with given fields:
func (*GossipSubRpcValidationInspectorMetrics) OnUnstakedPeerInspectionFailed ¶ added in v0.33.7
func (_m *GossipSubRpcValidationInspectorMetrics) OnUnstakedPeerInspectionFailed()
OnUnstakedPeerInspectionFailed provides a mock function with given fields:
type GossipSubScoringMetrics ¶ added in v0.30.0
GossipSubScoringMetrics is an autogenerated mock type for the GossipSubScoringMetrics type
func NewGossipSubScoringMetrics ¶ added in v0.30.0
func NewGossipSubScoringMetrics(t interface { mock.TestingT Cleanup(func()) }) *GossipSubScoringMetrics
NewGossipSubScoringMetrics creates a new instance of GossipSubScoringMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubScoringMetrics) OnAppSpecificScoreUpdated ¶ added in v0.30.0
func (_m *GossipSubScoringMetrics) OnAppSpecificScoreUpdated(_a0 float64)
OnAppSpecificScoreUpdated provides a mock function with given fields: _a0
func (*GossipSubScoringMetrics) OnBehaviourPenaltyUpdated ¶ added in v0.30.0
func (_m *GossipSubScoringMetrics) OnBehaviourPenaltyUpdated(_a0 float64)
OnBehaviourPenaltyUpdated provides a mock function with given fields: _a0
func (*GossipSubScoringMetrics) OnFirstMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *GossipSubScoringMetrics) OnFirstMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnFirstMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*GossipSubScoringMetrics) OnIPColocationFactorUpdated ¶ added in v0.30.0
func (_m *GossipSubScoringMetrics) OnIPColocationFactorUpdated(_a0 float64)
OnIPColocationFactorUpdated provides a mock function with given fields: _a0
func (*GossipSubScoringMetrics) OnInvalidMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *GossipSubScoringMetrics) OnInvalidMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnInvalidMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*GossipSubScoringMetrics) OnMeshMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *GossipSubScoringMetrics) OnMeshMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnMeshMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*GossipSubScoringMetrics) OnOverallPeerScoreUpdated ¶ added in v0.30.0
func (_m *GossipSubScoringMetrics) OnOverallPeerScoreUpdated(_a0 float64)
OnOverallPeerScoreUpdated provides a mock function with given fields: _a0
func (*GossipSubScoringMetrics) OnTimeInMeshUpdated ¶ added in v0.30.0
func (_m *GossipSubScoringMetrics) OnTimeInMeshUpdated(_a0 channels.Topic, _a1 time.Duration)
OnTimeInMeshUpdated provides a mock function with given fields: _a0, _a1
func (*GossipSubScoringMetrics) SetWarningStateCount ¶ added in v0.30.0
func (_m *GossipSubScoringMetrics) SetWarningStateCount(_a0 uint)
SetWarningStateCount provides a mock function with given fields: _a0
type GossipSubScoringRegistryMetrics ¶ added in v0.33.30
GossipSubScoringRegistryMetrics is an autogenerated mock type for the GossipSubScoringRegistryMetrics type
func NewGossipSubScoringRegistryMetrics ¶ added in v0.33.30
func NewGossipSubScoringRegistryMetrics(t interface { mock.TestingT Cleanup(func()) }) *GossipSubScoringRegistryMetrics
NewGossipSubScoringRegistryMetrics creates a new instance of GossipSubScoringRegistryMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubScoringRegistryMetrics) DuplicateMessagePenalties ¶ added in v0.33.30
func (_m *GossipSubScoringRegistryMetrics) DuplicateMessagePenalties(penalty float64)
DuplicateMessagePenalties provides a mock function with given fields: penalty
func (*GossipSubScoringRegistryMetrics) DuplicateMessagesCounts ¶ added in v0.33.30
func (_m *GossipSubScoringRegistryMetrics) DuplicateMessagesCounts(count float64)
DuplicateMessagesCounts provides a mock function with given fields: count
type HeroCacheMetrics ¶ added in v0.24.11
HeroCacheMetrics is an autogenerated mock type for the HeroCacheMetrics type
func NewHeroCacheMetrics ¶ added in v0.26.1
func NewHeroCacheMetrics(t interface { mock.TestingT Cleanup(func()) }) *HeroCacheMetrics
NewHeroCacheMetrics creates a new instance of HeroCacheMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*HeroCacheMetrics) BucketAvailableSlots ¶ added in v0.24.11
func (_m *HeroCacheMetrics) BucketAvailableSlots(_a0 uint64, _a1 uint64)
BucketAvailableSlots provides a mock function with given fields: _a0, _a1
func (*HeroCacheMetrics) OnEntityEjectionDueToEmergency ¶ added in v0.24.11
func (_m *HeroCacheMetrics) OnEntityEjectionDueToEmergency()
OnEntityEjectionDueToEmergency provides a mock function with given fields:
func (*HeroCacheMetrics) OnEntityEjectionDueToFullCapacity ¶ added in v0.24.11
func (_m *HeroCacheMetrics) OnEntityEjectionDueToFullCapacity()
OnEntityEjectionDueToFullCapacity provides a mock function with given fields:
func (*HeroCacheMetrics) OnKeyGetFailure ¶ added in v0.24.11
func (_m *HeroCacheMetrics) OnKeyGetFailure()
OnKeyGetFailure provides a mock function with given fields:
func (*HeroCacheMetrics) OnKeyGetSuccess ¶ added in v0.24.11
func (_m *HeroCacheMetrics) OnKeyGetSuccess()
OnKeyGetSuccess provides a mock function with given fields:
func (*HeroCacheMetrics) OnKeyPutAttempt ¶ added in v0.29.0
func (_m *HeroCacheMetrics) OnKeyPutAttempt(size uint32)
OnKeyPutAttempt provides a mock function with given fields: size
func (*HeroCacheMetrics) OnKeyPutDeduplicated ¶ added in v0.29.0
func (_m *HeroCacheMetrics) OnKeyPutDeduplicated()
OnKeyPutDeduplicated provides a mock function with given fields:
func (*HeroCacheMetrics) OnKeyPutDrop ¶ added in v0.29.0
func (_m *HeroCacheMetrics) OnKeyPutDrop()
OnKeyPutDrop provides a mock function with given fields:
func (*HeroCacheMetrics) OnKeyPutSuccess ¶ added in v0.24.11
func (_m *HeroCacheMetrics) OnKeyPutSuccess(size uint32)
OnKeyPutSuccess provides a mock function with given fields: size
func (*HeroCacheMetrics) OnKeyRemoved ¶ added in v0.29.0
func (_m *HeroCacheMetrics) OnKeyRemoved(size uint32)
OnKeyRemoved provides a mock function with given fields: size
type HotStuff ¶
HotStuff is an autogenerated mock type for the HotStuff type
func NewHotStuff ¶ added in v0.26.1
NewHotStuff creates a new instance of HotStuff. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*HotStuff) Done ¶
func (_m *HotStuff) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*HotStuff) Ready ¶
func (_m *HotStuff) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*HotStuff) Start ¶ added in v0.23.9
func (_m *HotStuff) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
func (*HotStuff) SubmitProposal ¶
SubmitProposal provides a mock function with given fields: proposal
type HotStuffFollower ¶
HotStuffFollower is an autogenerated mock type for the HotStuffFollower type
func NewHotStuffFollower ¶ added in v0.26.1
func NewHotStuffFollower(t interface { mock.TestingT Cleanup(func()) }) *HotStuffFollower
NewHotStuffFollower creates a new instance of HotStuffFollower. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*HotStuffFollower) AddCertifiedBlock ¶ added in v0.31.0
func (_m *HotStuffFollower) AddCertifiedBlock(certifiedBlock *model.CertifiedBlock)
AddCertifiedBlock provides a mock function with given fields: certifiedBlock
func (*HotStuffFollower) Done ¶
func (_m *HotStuffFollower) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*HotStuffFollower) Ready ¶
func (_m *HotStuffFollower) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*HotStuffFollower) Start ¶ added in v0.29.0
func (_m *HotStuffFollower) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
type HotstuffMetrics ¶
HotstuffMetrics is an autogenerated mock type for the HotstuffMetrics type
func NewHotstuffMetrics ¶ added in v0.26.1
func NewHotstuffMetrics(t interface { mock.TestingT Cleanup(func()) }) *HotstuffMetrics
NewHotstuffMetrics creates a new instance of HotstuffMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*HotstuffMetrics) BlockProcessingDuration ¶ added in v0.29.0
func (_m *HotstuffMetrics) BlockProcessingDuration(duration time.Duration)
BlockProcessingDuration provides a mock function with given fields: duration
func (*HotstuffMetrics) CommitteeProcessingDuration ¶
func (_m *HotstuffMetrics) CommitteeProcessingDuration(duration time.Duration)
CommitteeProcessingDuration provides a mock function with given fields: duration
func (*HotstuffMetrics) CountSkipped ¶
func (_m *HotstuffMetrics) CountSkipped()
CountSkipped provides a mock function with given fields:
func (*HotstuffMetrics) CountTimeout ¶
func (_m *HotstuffMetrics) CountTimeout()
CountTimeout provides a mock function with given fields:
func (*HotstuffMetrics) HotStuffBusyDuration ¶
func (_m *HotstuffMetrics) HotStuffBusyDuration(duration time.Duration, event string)
HotStuffBusyDuration provides a mock function with given fields: duration, event
func (*HotstuffMetrics) HotStuffIdleDuration ¶
func (_m *HotstuffMetrics) HotStuffIdleDuration(duration time.Duration)
HotStuffIdleDuration provides a mock function with given fields: duration
func (*HotstuffMetrics) HotStuffWaitDuration ¶
func (_m *HotstuffMetrics) HotStuffWaitDuration(duration time.Duration, event string)
HotStuffWaitDuration provides a mock function with given fields: duration, event
func (*HotstuffMetrics) PayloadProductionDuration ¶
func (_m *HotstuffMetrics) PayloadProductionDuration(duration time.Duration)
PayloadProductionDuration provides a mock function with given fields: duration
func (*HotstuffMetrics) SetCurView ¶
func (_m *HotstuffMetrics) SetCurView(view uint64)
SetCurView provides a mock function with given fields: view
func (*HotstuffMetrics) SetQCView ¶
func (_m *HotstuffMetrics) SetQCView(view uint64)
SetQCView provides a mock function with given fields: view
func (*HotstuffMetrics) SetTCView ¶ added in v0.29.0
func (_m *HotstuffMetrics) SetTCView(view uint64)
SetTCView provides a mock function with given fields: view
func (*HotstuffMetrics) SetTimeout ¶
func (_m *HotstuffMetrics) SetTimeout(duration time.Duration)
SetTimeout provides a mock function with given fields: duration
func (*HotstuffMetrics) SignerProcessingDuration ¶
func (_m *HotstuffMetrics) SignerProcessingDuration(duration time.Duration)
SignerProcessingDuration provides a mock function with given fields: duration
func (*HotstuffMetrics) TimeoutCollectorsRange ¶ added in v0.32.0
func (_m *HotstuffMetrics) TimeoutCollectorsRange(lowestRetainedView uint64, newestViewCreatedCollector uint64, activeCollectors int)
TimeoutCollectorsRange provides a mock function with given fields: lowestRetainedView, newestViewCreatedCollector, activeCollectors
func (*HotstuffMetrics) TimeoutObjectProcessingDuration ¶ added in v0.29.0
func (_m *HotstuffMetrics) TimeoutObjectProcessingDuration(duration time.Duration)
TimeoutObjectProcessingDuration provides a mock function with given fields: duration
func (*HotstuffMetrics) ValidatorProcessingDuration ¶
func (_m *HotstuffMetrics) ValidatorProcessingDuration(duration time.Duration)
ValidatorProcessingDuration provides a mock function with given fields: duration
func (*HotstuffMetrics) VoteProcessingDuration ¶ added in v0.29.0
func (_m *HotstuffMetrics) VoteProcessingDuration(duration time.Duration)
VoteProcessingDuration provides a mock function with given fields: duration
type IdentifierProvider ¶ added in v0.28.0
IdentifierProvider is an autogenerated mock type for the IdentifierProvider type
func NewIdentifierProvider ¶ added in v0.28.0
func NewIdentifierProvider(t interface { mock.TestingT Cleanup(func()) }) *IdentifierProvider
NewIdentifierProvider creates a new instance of IdentifierProvider. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*IdentifierProvider) Identifiers ¶ added in v0.28.0
func (_m *IdentifierProvider) Identifiers() flow.IdentifierList
Identifiers provides a mock function with given fields:
type IdentityProvider ¶ added in v0.28.0
IdentityProvider is an autogenerated mock type for the IdentityProvider type
func NewIdentityProvider ¶ added in v0.28.0
func NewIdentityProvider(t interface { mock.TestingT Cleanup(func()) }) *IdentityProvider
NewIdentityProvider creates a new instance of IdentityProvider. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*IdentityProvider) ByNodeID ¶ added in v0.28.0
func (_m *IdentityProvider) ByNodeID(_a0 flow.Identifier) (*flow.Identity, bool)
ByNodeID provides a mock function with given fields: _a0
func (*IdentityProvider) ByPeerID ¶ added in v0.28.0
ByPeerID provides a mock function with given fields: _a0
func (*IdentityProvider) Identities ¶ added in v0.28.0
func (_m *IdentityProvider) Identities(_a0 flow.IdentityFilter[flow.Identity]) flow.GenericIdentityList[flow.Identity]
Identities provides a mock function with given fields: _a0
type Job ¶ added in v0.15.0
Job is an autogenerated mock type for the Job type
type JobConsumer ¶ added in v0.15.0
JobConsumer is an autogenerated mock type for the JobConsumer type
func NewJobConsumer ¶ added in v0.26.1
func NewJobConsumer(t interface { mock.TestingT Cleanup(func()) }) *JobConsumer
NewJobConsumer creates a new instance of JobConsumer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*JobConsumer) Check ¶ added in v0.15.0
func (_m *JobConsumer) Check()
Check provides a mock function with given fields:
func (*JobConsumer) LastProcessedIndex ¶ added in v0.26.2
func (_m *JobConsumer) LastProcessedIndex() uint64
LastProcessedIndex provides a mock function with given fields:
func (*JobConsumer) NotifyJobIsDone ¶ added in v0.15.0
func (_m *JobConsumer) NotifyJobIsDone(_a0 module.JobID) uint64
NotifyJobIsDone provides a mock function with given fields: _a0
func (*JobConsumer) Size ¶ added in v0.17.6
func (_m *JobConsumer) Size() uint
Size provides a mock function with given fields:
func (*JobConsumer) Start ¶ added in v0.15.0
func (_m *JobConsumer) Start() error
Start provides a mock function with given fields:
func (*JobConsumer) Stop ¶ added in v0.15.0
func (_m *JobConsumer) Stop()
Stop provides a mock function with given fields:
type JobQueue ¶ added in v0.15.0
JobQueue is an autogenerated mock type for the JobQueue type
func NewJobQueue ¶ added in v0.26.1
NewJobQueue creates a new instance of JobQueue. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
type Jobs ¶ added in v0.15.0
Jobs is an autogenerated mock type for the Jobs type
func NewJobs ¶ added in v0.26.1
NewJobs creates a new instance of Jobs. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
type LedgerMetrics ¶
LedgerMetrics is an autogenerated mock type for the LedgerMetrics type
func NewLedgerMetrics ¶ added in v0.26.1
func NewLedgerMetrics(t interface { mock.TestingT Cleanup(func()) }) *LedgerMetrics
NewLedgerMetrics creates a new instance of LedgerMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*LedgerMetrics) ForestApproxMemorySize ¶
func (_m *LedgerMetrics) ForestApproxMemorySize(bytes uint64)
ForestApproxMemorySize provides a mock function with given fields: bytes
func (*LedgerMetrics) ForestNumberOfTrees ¶
func (_m *LedgerMetrics) ForestNumberOfTrees(number uint64)
ForestNumberOfTrees provides a mock function with given fields: number
func (*LedgerMetrics) LatestTrieMaxDepthTouched ¶ added in v0.25.2
func (_m *LedgerMetrics) LatestTrieMaxDepthTouched(maxDepth uint16)
LatestTrieMaxDepthTouched provides a mock function with given fields: maxDepth
func (*LedgerMetrics) LatestTrieRegCount ¶
func (_m *LedgerMetrics) LatestTrieRegCount(number uint64)
LatestTrieRegCount provides a mock function with given fields: number
func (*LedgerMetrics) LatestTrieRegCountDiff ¶
func (_m *LedgerMetrics) LatestTrieRegCountDiff(number int64)
LatestTrieRegCountDiff provides a mock function with given fields: number
func (*LedgerMetrics) LatestTrieRegSize ¶ added in v0.25.2
func (_m *LedgerMetrics) LatestTrieRegSize(size uint64)
LatestTrieRegSize provides a mock function with given fields: size
func (*LedgerMetrics) LatestTrieRegSizeDiff ¶ added in v0.25.2
func (_m *LedgerMetrics) LatestTrieRegSizeDiff(size int64)
LatestTrieRegSizeDiff provides a mock function with given fields: size
func (*LedgerMetrics) ProofSize ¶
func (_m *LedgerMetrics) ProofSize(bytes uint32)
ProofSize provides a mock function with given fields: bytes
func (*LedgerMetrics) ReadDuration ¶
func (_m *LedgerMetrics) ReadDuration(duration time.Duration)
ReadDuration provides a mock function with given fields: duration
func (*LedgerMetrics) ReadDurationPerItem ¶
func (_m *LedgerMetrics) ReadDurationPerItem(duration time.Duration)
ReadDurationPerItem provides a mock function with given fields: duration
func (*LedgerMetrics) ReadValuesNumber ¶
func (_m *LedgerMetrics) ReadValuesNumber(number uint64)
ReadValuesNumber provides a mock function with given fields: number
func (*LedgerMetrics) ReadValuesSize ¶
func (_m *LedgerMetrics) ReadValuesSize(byte uint64)
ReadValuesSize provides a mock function with given fields: byte
func (*LedgerMetrics) UpdateCount ¶
func (_m *LedgerMetrics) UpdateCount()
UpdateCount provides a mock function with given fields:
func (*LedgerMetrics) UpdateDuration ¶
func (_m *LedgerMetrics) UpdateDuration(duration time.Duration)
UpdateDuration provides a mock function with given fields: duration
func (*LedgerMetrics) UpdateDurationPerItem ¶
func (_m *LedgerMetrics) UpdateDurationPerItem(duration time.Duration)
UpdateDurationPerItem provides a mock function with given fields: duration
func (*LedgerMetrics) UpdateValuesNumber ¶
func (_m *LedgerMetrics) UpdateValuesNumber(number uint64)
UpdateValuesNumber provides a mock function with given fields: number
func (*LedgerMetrics) UpdateValuesSize ¶
func (_m *LedgerMetrics) UpdateValuesSize(byte uint64)
UpdateValuesSize provides a mock function with given fields: byte
type LibP2PConnectionMetrics ¶ added in v0.29.1
LibP2PConnectionMetrics is an autogenerated mock type for the LibP2PConnectionMetrics type
func NewLibP2PConnectionMetrics ¶ added in v0.29.1
func NewLibP2PConnectionMetrics(t interface { mock.TestingT Cleanup(func()) }) *LibP2PConnectionMetrics
NewLibP2PConnectionMetrics creates a new instance of LibP2PConnectionMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*LibP2PConnectionMetrics) InboundConnections ¶ added in v0.29.1
func (_m *LibP2PConnectionMetrics) InboundConnections(connectionCount uint)
InboundConnections provides a mock function with given fields: connectionCount
func (*LibP2PConnectionMetrics) OutboundConnections ¶ added in v0.29.1
func (_m *LibP2PConnectionMetrics) OutboundConnections(connectionCount uint)
OutboundConnections provides a mock function with given fields: connectionCount
type LibP2PMetrics ¶ added in v0.29.0
LibP2PMetrics is an autogenerated mock type for the LibP2PMetrics type
func NewLibP2PMetrics ¶ added in v0.29.0
func NewLibP2PMetrics(t interface { mock.TestingT Cleanup(func()) }) *LibP2PMetrics
NewLibP2PMetrics creates a new instance of LibP2PMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*LibP2PMetrics) AllowConn ¶ added in v0.29.0
func (_m *LibP2PMetrics) AllowConn(dir network.Direction, usefd bool)
AllowConn provides a mock function with given fields: dir, usefd
func (*LibP2PMetrics) AllowMemory ¶ added in v0.29.0
func (_m *LibP2PMetrics) AllowMemory(size int)
AllowMemory provides a mock function with given fields: size
func (*LibP2PMetrics) AllowPeer ¶ added in v0.29.0
func (_m *LibP2PMetrics) AllowPeer(p peer.ID)
AllowPeer provides a mock function with given fields: p
func (*LibP2PMetrics) AllowProtocol ¶ added in v0.29.0
func (_m *LibP2PMetrics) AllowProtocol(proto protocol.ID)
AllowProtocol provides a mock function with given fields: proto
func (*LibP2PMetrics) AllowService ¶ added in v0.29.0
func (_m *LibP2PMetrics) AllowService(svc string)
AllowService provides a mock function with given fields: svc
func (*LibP2PMetrics) AllowStream ¶ added in v0.29.0
func (_m *LibP2PMetrics) AllowStream(p peer.ID, dir network.Direction)
AllowStream provides a mock function with given fields: p, dir
func (*LibP2PMetrics) AsyncProcessingFinished ¶ added in v0.31.0
func (_m *LibP2PMetrics) AsyncProcessingFinished(duration time.Duration)
AsyncProcessingFinished provides a mock function with given fields: duration
func (*LibP2PMetrics) AsyncProcessingStarted ¶ added in v0.31.0
func (_m *LibP2PMetrics) AsyncProcessingStarted()
AsyncProcessingStarted provides a mock function with given fields:
func (*LibP2PMetrics) BlockConn ¶ added in v0.29.0
func (_m *LibP2PMetrics) BlockConn(dir network.Direction, usefd bool)
BlockConn provides a mock function with given fields: dir, usefd
func (*LibP2PMetrics) BlockMemory ¶ added in v0.29.0
func (_m *LibP2PMetrics) BlockMemory(size int)
BlockMemory provides a mock function with given fields: size
func (*LibP2PMetrics) BlockPeer ¶ added in v0.29.0
func (_m *LibP2PMetrics) BlockPeer(p peer.ID)
BlockPeer provides a mock function with given fields: p
func (*LibP2PMetrics) BlockProtocol ¶ added in v0.29.0
func (_m *LibP2PMetrics) BlockProtocol(proto protocol.ID)
BlockProtocol provides a mock function with given fields: proto
func (*LibP2PMetrics) BlockProtocolPeer ¶ added in v0.29.0
func (_m *LibP2PMetrics) BlockProtocolPeer(proto protocol.ID, p peer.ID)
BlockProtocolPeer provides a mock function with given fields: proto, p
func (*LibP2PMetrics) BlockService ¶ added in v0.29.0
func (_m *LibP2PMetrics) BlockService(svc string)
BlockService provides a mock function with given fields: svc
func (*LibP2PMetrics) BlockServicePeer ¶ added in v0.29.0
func (_m *LibP2PMetrics) BlockServicePeer(svc string, p peer.ID)
BlockServicePeer provides a mock function with given fields: svc, p
func (*LibP2PMetrics) BlockStream ¶ added in v0.29.0
func (_m *LibP2PMetrics) BlockStream(p peer.ID, dir network.Direction)
BlockStream provides a mock function with given fields: p, dir
func (*LibP2PMetrics) DNSLookupDuration ¶ added in v0.29.0
func (_m *LibP2PMetrics) DNSLookupDuration(duration time.Duration)
DNSLookupDuration provides a mock function with given fields: duration
func (*LibP2PMetrics) DuplicateMessagePenalties ¶ added in v0.33.30
func (_m *LibP2PMetrics) DuplicateMessagePenalties(penalty float64)
DuplicateMessagePenalties provides a mock function with given fields: penalty
func (*LibP2PMetrics) DuplicateMessagesCounts ¶ added in v0.33.30
func (_m *LibP2PMetrics) DuplicateMessagesCounts(count float64)
DuplicateMessagesCounts provides a mock function with given fields: count
func (*LibP2PMetrics) InboundConnections ¶ added in v0.29.1
func (_m *LibP2PMetrics) InboundConnections(connectionCount uint)
InboundConnections provides a mock function with given fields: connectionCount
func (*LibP2PMetrics) OnActiveClusterIDsNotSetErr ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnActiveClusterIDsNotSetErr()
OnActiveClusterIDsNotSetErr provides a mock function with given fields:
func (*LibP2PMetrics) OnAppSpecificScoreUpdated ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnAppSpecificScoreUpdated(_a0 float64)
OnAppSpecificScoreUpdated provides a mock function with given fields: _a0
func (*LibP2PMetrics) OnBehaviourPenaltyUpdated ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnBehaviourPenaltyUpdated(_a0 float64)
OnBehaviourPenaltyUpdated provides a mock function with given fields: _a0
func (*LibP2PMetrics) OnControlMessagesTruncated ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
OnControlMessagesTruncated provides a mock function with given fields: messageType, diff
func (*LibP2PMetrics) OnDNSCacheHit ¶ added in v0.29.0
func (_m *LibP2PMetrics) OnDNSCacheHit()
OnDNSCacheHit provides a mock function with given fields:
func (*LibP2PMetrics) OnDNSCacheInvalidated ¶ added in v0.29.0
func (_m *LibP2PMetrics) OnDNSCacheInvalidated()
OnDNSCacheInvalidated provides a mock function with given fields:
func (*LibP2PMetrics) OnDNSCacheMiss ¶ added in v0.29.0
func (_m *LibP2PMetrics) OnDNSCacheMiss()
OnDNSCacheMiss provides a mock function with given fields:
func (*LibP2PMetrics) OnDNSLookupRequestDropped ¶ added in v0.29.0
func (_m *LibP2PMetrics) OnDNSLookupRequestDropped()
OnDNSLookupRequestDropped provides a mock function with given fields:
func (*LibP2PMetrics) OnDialRetryBudgetResetToDefault ¶ added in v0.32.2
func (_m *LibP2PMetrics) OnDialRetryBudgetResetToDefault()
OnDialRetryBudgetResetToDefault provides a mock function with given fields:
func (*LibP2PMetrics) OnDialRetryBudgetUpdated ¶ added in v0.32.2
func (_m *LibP2PMetrics) OnDialRetryBudgetUpdated(budget uint64)
OnDialRetryBudgetUpdated provides a mock function with given fields: budget
func (*LibP2PMetrics) OnEstablishStreamFailure ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnEstablishStreamFailure(duration time.Duration, attempts int)
OnEstablishStreamFailure provides a mock function with given fields: duration, attempts
func (*LibP2PMetrics) OnFirstMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnFirstMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnFirstMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*LibP2PMetrics) OnGraftDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnGraftDuplicateTopicIdsExceedThreshold()
OnGraftDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*LibP2PMetrics) OnGraftInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *LibP2PMetrics) OnGraftInvalidTopicIdsExceedThreshold()
OnGraftInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*LibP2PMetrics) OnGraftMessageInspected ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnGraftMessageInspected(duplicateTopicIds int, invalidTopicIds int)
OnGraftMessageInspected provides a mock function with given fields: duplicateTopicIds, invalidTopicIds
func (*LibP2PMetrics) OnIHaveControlMessageIdsTruncated ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnIHaveControlMessageIdsTruncated(diff int)
OnIHaveControlMessageIdsTruncated provides a mock function with given fields: diff
func (*LibP2PMetrics) OnIHaveDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnIHaveDuplicateMessageIdsExceedThreshold()
OnIHaveDuplicateMessageIdsExceedThreshold provides a mock function with given fields:
func (*LibP2PMetrics) OnIHaveDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnIHaveDuplicateTopicIdsExceedThreshold()
OnIHaveDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*LibP2PMetrics) OnIHaveInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *LibP2PMetrics) OnIHaveInvalidTopicIdsExceedThreshold()
OnIHaveInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*LibP2PMetrics) OnIHaveMessageIDsReceived ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
OnIHaveMessageIDsReceived provides a mock function with given fields: channel, msgIdCount
func (*LibP2PMetrics) OnIHaveMessagesInspected ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int, invalidTopicIds int)
OnIHaveMessagesInspected provides a mock function with given fields: duplicateTopicIds, duplicateMessageIds, invalidTopicIds
func (*LibP2PMetrics) OnIPColocationFactorUpdated ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnIPColocationFactorUpdated(_a0 float64)
OnIPColocationFactorUpdated provides a mock function with given fields: _a0
func (*LibP2PMetrics) OnIWantCacheMissMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnIWantCacheMissMessageIdsExceedThreshold()
OnIWantCacheMissMessageIdsExceedThreshold provides a mock function with given fields:
func (*LibP2PMetrics) OnIWantControlMessageIdsTruncated ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnIWantControlMessageIdsTruncated(diff int)
OnIWantControlMessageIdsTruncated provides a mock function with given fields: diff
func (*LibP2PMetrics) OnIWantDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnIWantDuplicateMessageIdsExceedThreshold()
OnIWantDuplicateMessageIdsExceedThreshold provides a mock function with given fields:
func (*LibP2PMetrics) OnIWantMessageIDsReceived ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnIWantMessageIDsReceived(msgIdCount int)
OnIWantMessageIDsReceived provides a mock function with given fields: msgIdCount
func (*LibP2PMetrics) OnIWantMessagesInspected ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
OnIWantMessagesInspected provides a mock function with given fields: duplicateCount, cacheMissCount
func (*LibP2PMetrics) OnIncomingRpcReceived ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnIncomingRpcReceived(iHaveCount int, iWantCount int, graftCount int, pruneCount int, msgCount int)
OnIncomingRpcReceived provides a mock function with given fields: iHaveCount, iWantCount, graftCount, pruneCount, msgCount
func (*LibP2PMetrics) OnInvalidControlMessageNotificationSent ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnInvalidControlMessageNotificationSent()
OnInvalidControlMessageNotificationSent provides a mock function with given fields:
func (*LibP2PMetrics) OnInvalidMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnInvalidMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnInvalidMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*LibP2PMetrics) OnInvalidTopicIdDetectedForControlMessage ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
OnInvalidTopicIdDetectedForControlMessage provides a mock function with given fields: messageType
func (*LibP2PMetrics) OnLocalMeshSizeUpdated ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnLocalMeshSizeUpdated(topic string, size int)
OnLocalMeshSizeUpdated provides a mock function with given fields: topic, size
func (*LibP2PMetrics) OnLocalPeerJoinedTopic ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnLocalPeerJoinedTopic()
OnLocalPeerJoinedTopic provides a mock function with given fields:
func (*LibP2PMetrics) OnLocalPeerLeftTopic ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnLocalPeerLeftTopic()
OnLocalPeerLeftTopic provides a mock function with given fields:
func (*LibP2PMetrics) OnMeshMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnMeshMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnMeshMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*LibP2PMetrics) OnMessageDeliveredToAllSubscribers ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnMessageDeliveredToAllSubscribers(size int)
OnMessageDeliveredToAllSubscribers provides a mock function with given fields: size
func (*LibP2PMetrics) OnMessageDuplicate ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnMessageDuplicate(size int)
OnMessageDuplicate provides a mock function with given fields: size
func (*LibP2PMetrics) OnMessageEnteredValidation ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnMessageEnteredValidation(size int)
OnMessageEnteredValidation provides a mock function with given fields: size
func (*LibP2PMetrics) OnMessageRejected ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnMessageRejected(size int, reason string)
OnMessageRejected provides a mock function with given fields: size, reason
func (*LibP2PMetrics) OnOutboundRpcDropped ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnOutboundRpcDropped()
OnOutboundRpcDropped provides a mock function with given fields:
func (*LibP2PMetrics) OnOverallPeerScoreUpdated ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnOverallPeerScoreUpdated(_a0 float64)
OnOverallPeerScoreUpdated provides a mock function with given fields: _a0
func (*LibP2PMetrics) OnPeerAddedToProtocol ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnPeerAddedToProtocol(_a0 string)
OnPeerAddedToProtocol provides a mock function with given fields: _a0
func (*LibP2PMetrics) OnPeerDialFailure ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnPeerDialFailure(duration time.Duration, attempts int)
OnPeerDialFailure provides a mock function with given fields: duration, attempts
func (*LibP2PMetrics) OnPeerDialed ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnPeerDialed(duration time.Duration, attempts int)
OnPeerDialed provides a mock function with given fields: duration, attempts
func (*LibP2PMetrics) OnPeerGraftTopic ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnPeerGraftTopic(topic string)
OnPeerGraftTopic provides a mock function with given fields: topic
func (*LibP2PMetrics) OnPeerPruneTopic ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnPeerPruneTopic(topic string)
OnPeerPruneTopic provides a mock function with given fields: topic
func (*LibP2PMetrics) OnPeerRemovedFromProtocol ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnPeerRemovedFromProtocol()
OnPeerRemovedFromProtocol provides a mock function with given fields:
func (*LibP2PMetrics) OnPeerThrottled ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnPeerThrottled()
OnPeerThrottled provides a mock function with given fields:
func (*LibP2PMetrics) OnPruneDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnPruneDuplicateTopicIdsExceedThreshold()
OnPruneDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*LibP2PMetrics) OnPruneInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *LibP2PMetrics) OnPruneInvalidTopicIdsExceedThreshold()
OnPruneInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*LibP2PMetrics) OnPruneMessageInspected ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnPruneMessageInspected(duplicateTopicIds int, invalidTopicIds int)
OnPruneMessageInspected provides a mock function with given fields: duplicateTopicIds, invalidTopicIds
func (*LibP2PMetrics) OnPublishMessageInspected ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, invalidSendersCount int)
OnPublishMessageInspected provides a mock function with given fields: totalErrCount, invalidTopicIdsCount, invalidSubscriptionsCount, invalidSendersCount
func (*LibP2PMetrics) OnPublishMessagesInspectionErrorExceedsThreshold ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnPublishMessagesInspectionErrorExceedsThreshold()
OnPublishMessagesInspectionErrorExceedsThreshold provides a mock function with given fields:
func (*LibP2PMetrics) OnRpcReceived ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnRpcReceived(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
OnRpcReceived provides a mock function with given fields: msgCount, iHaveCount, iWantCount, graftCount, pruneCount
func (*LibP2PMetrics) OnRpcRejectedFromUnknownSender ¶ added in v0.33.30
func (_m *LibP2PMetrics) OnRpcRejectedFromUnknownSender()
OnRpcRejectedFromUnknownSender provides a mock function with given fields:
func (*LibP2PMetrics) OnRpcSent ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnRpcSent(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
OnRpcSent provides a mock function with given fields: msgCount, iHaveCount, iWantCount, graftCount, pruneCount
func (*LibP2PMetrics) OnStreamCreated ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnStreamCreated(duration time.Duration, attempts int)
OnStreamCreated provides a mock function with given fields: duration, attempts
func (*LibP2PMetrics) OnStreamCreationFailure ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnStreamCreationFailure(duration time.Duration, attempts int)
OnStreamCreationFailure provides a mock function with given fields: duration, attempts
func (*LibP2PMetrics) OnStreamCreationRetryBudgetResetToDefault ¶ added in v0.32.2
func (_m *LibP2PMetrics) OnStreamCreationRetryBudgetResetToDefault()
OnStreamCreationRetryBudgetResetToDefault provides a mock function with given fields:
func (*LibP2PMetrics) OnStreamCreationRetryBudgetUpdated ¶ added in v0.32.2
func (_m *LibP2PMetrics) OnStreamCreationRetryBudgetUpdated(budget uint64)
OnStreamCreationRetryBudgetUpdated provides a mock function with given fields: budget
func (*LibP2PMetrics) OnStreamEstablished ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnStreamEstablished(duration time.Duration, attempts int)
OnStreamEstablished provides a mock function with given fields: duration, attempts
func (*LibP2PMetrics) OnTimeInMeshUpdated ¶ added in v0.30.0
func (_m *LibP2PMetrics) OnTimeInMeshUpdated(_a0 channels.Topic, _a1 time.Duration)
OnTimeInMeshUpdated provides a mock function with given fields: _a0, _a1
func (*LibP2PMetrics) OnUndeliveredMessage ¶ added in v0.33.1
func (_m *LibP2PMetrics) OnUndeliveredMessage()
OnUndeliveredMessage provides a mock function with given fields:
func (*LibP2PMetrics) OnUnstakedPeerInspectionFailed ¶ added in v0.33.7
func (_m *LibP2PMetrics) OnUnstakedPeerInspectionFailed()
OnUnstakedPeerInspectionFailed provides a mock function with given fields:
func (*LibP2PMetrics) OutboundConnections ¶ added in v0.29.1
func (_m *LibP2PMetrics) OutboundConnections(connectionCount uint)
OutboundConnections provides a mock function with given fields: connectionCount
func (*LibP2PMetrics) RoutingTablePeerAdded ¶ added in v0.29.0
func (_m *LibP2PMetrics) RoutingTablePeerAdded()
RoutingTablePeerAdded provides a mock function with given fields:
func (*LibP2PMetrics) RoutingTablePeerRemoved ¶ added in v0.29.0
func (_m *LibP2PMetrics) RoutingTablePeerRemoved()
RoutingTablePeerRemoved provides a mock function with given fields:
func (*LibP2PMetrics) SetWarningStateCount ¶ added in v0.30.0
func (_m *LibP2PMetrics) SetWarningStateCount(_a0 uint)
SetWarningStateCount provides a mock function with given fields: _a0
type Local ¶
Local is an autogenerated mock type for the Local type
func NewLocal ¶ added in v0.26.1
NewLocal creates a new instance of Local. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*Local) NodeID ¶
func (_m *Local) NodeID() flow.Identifier
NodeID provides a mock function with given fields:
func (*Local) NotMeFilter ¶
func (_m *Local) NotMeFilter() flow.IdentityFilter[flow.Identity]
NotMeFilter provides a mock function with given fields:
type LocalGossipSubRouterMetrics ¶ added in v0.33.1
LocalGossipSubRouterMetrics is an autogenerated mock type for the LocalGossipSubRouterMetrics type
func NewLocalGossipSubRouterMetrics ¶ added in v0.33.1
func NewLocalGossipSubRouterMetrics(t interface { mock.TestingT Cleanup(func()) }) *LocalGossipSubRouterMetrics
NewLocalGossipSubRouterMetrics creates a new instance of LocalGossipSubRouterMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*LocalGossipSubRouterMetrics) OnLocalMeshSizeUpdated ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnLocalMeshSizeUpdated(topic string, size int)
OnLocalMeshSizeUpdated provides a mock function with given fields: topic, size
func (*LocalGossipSubRouterMetrics) OnLocalPeerJoinedTopic ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnLocalPeerJoinedTopic()
OnLocalPeerJoinedTopic provides a mock function with given fields:
func (*LocalGossipSubRouterMetrics) OnLocalPeerLeftTopic ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnLocalPeerLeftTopic()
OnLocalPeerLeftTopic provides a mock function with given fields:
func (*LocalGossipSubRouterMetrics) OnMessageDeliveredToAllSubscribers ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnMessageDeliveredToAllSubscribers(size int)
OnMessageDeliveredToAllSubscribers provides a mock function with given fields: size
func (*LocalGossipSubRouterMetrics) OnMessageDuplicate ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnMessageDuplicate(size int)
OnMessageDuplicate provides a mock function with given fields: size
func (*LocalGossipSubRouterMetrics) OnMessageEnteredValidation ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnMessageEnteredValidation(size int)
OnMessageEnteredValidation provides a mock function with given fields: size
func (*LocalGossipSubRouterMetrics) OnMessageRejected ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnMessageRejected(size int, reason string)
OnMessageRejected provides a mock function with given fields: size, reason
func (*LocalGossipSubRouterMetrics) OnOutboundRpcDropped ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnOutboundRpcDropped()
OnOutboundRpcDropped provides a mock function with given fields:
func (*LocalGossipSubRouterMetrics) OnPeerAddedToProtocol ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnPeerAddedToProtocol(protocol string)
OnPeerAddedToProtocol provides a mock function with given fields: protocol
func (*LocalGossipSubRouterMetrics) OnPeerGraftTopic ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnPeerGraftTopic(topic string)
OnPeerGraftTopic provides a mock function with given fields: topic
func (*LocalGossipSubRouterMetrics) OnPeerPruneTopic ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnPeerPruneTopic(topic string)
OnPeerPruneTopic provides a mock function with given fields: topic
func (*LocalGossipSubRouterMetrics) OnPeerRemovedFromProtocol ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnPeerRemovedFromProtocol()
OnPeerRemovedFromProtocol provides a mock function with given fields:
func (*LocalGossipSubRouterMetrics) OnPeerThrottled ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnPeerThrottled()
OnPeerThrottled provides a mock function with given fields:
func (*LocalGossipSubRouterMetrics) OnRpcReceived ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnRpcReceived(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
OnRpcReceived provides a mock function with given fields: msgCount, iHaveCount, iWantCount, graftCount, pruneCount
func (*LocalGossipSubRouterMetrics) OnRpcSent ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnRpcSent(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
OnRpcSent provides a mock function with given fields: msgCount, iHaveCount, iWantCount, graftCount, pruneCount
func (*LocalGossipSubRouterMetrics) OnUndeliveredMessage ¶ added in v0.33.1
func (_m *LocalGossipSubRouterMetrics) OnUndeliveredMessage()
OnUndeliveredMessage provides a mock function with given fields:
type MachineAccountMetrics ¶ added in v0.33.22
MachineAccountMetrics is an autogenerated mock type for the MachineAccountMetrics type
func NewMachineAccountMetrics ¶ added in v0.33.22
func NewMachineAccountMetrics(t interface { mock.TestingT Cleanup(func()) }) *MachineAccountMetrics
NewMachineAccountMetrics creates a new instance of MachineAccountMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*MachineAccountMetrics) AccountBalance ¶ added in v0.33.22
func (_m *MachineAccountMetrics) AccountBalance(bal float64)
AccountBalance provides a mock function with given fields: bal
func (*MachineAccountMetrics) IsMisconfigured ¶ added in v0.33.22
func (_m *MachineAccountMetrics) IsMisconfigured(misconfigured bool)
IsMisconfigured provides a mock function with given fields: misconfigured
func (*MachineAccountMetrics) RecommendedMinBalance ¶ added in v0.33.22
func (_m *MachineAccountMetrics) RecommendedMinBalance(bal float64)
RecommendedMinBalance provides a mock function with given fields: bal
type MempoolMetrics ¶
MempoolMetrics is an autogenerated mock type for the MempoolMetrics type
func NewMempoolMetrics ¶ added in v0.26.1
func NewMempoolMetrics(t interface { mock.TestingT Cleanup(func()) }) *MempoolMetrics
NewMempoolMetrics creates a new instance of MempoolMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*MempoolMetrics) MempoolEntries ¶
func (_m *MempoolMetrics) MempoolEntries(resource string, entries uint)
MempoolEntries provides a mock function with given fields: resource, entries
func (*MempoolMetrics) Register ¶
func (_m *MempoolMetrics) Register(resource string, entriesFunc module.EntriesFunc) error
Register provides a mock function with given fields: resource, entriesFunc
type NetworkCoreMetrics ¶ added in v0.29.1
NetworkCoreMetrics is an autogenerated mock type for the NetworkCoreMetrics type
func NewNetworkCoreMetrics ¶ added in v0.29.1
func NewNetworkCoreMetrics(t interface { mock.TestingT Cleanup(func()) }) *NetworkCoreMetrics
NewNetworkCoreMetrics creates a new instance of NetworkCoreMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*NetworkCoreMetrics) DuplicateInboundMessagesDropped ¶ added in v0.29.1
func (_m *NetworkCoreMetrics) DuplicateInboundMessagesDropped(topic string, protocol string, messageType string)
DuplicateInboundMessagesDropped provides a mock function with given fields: topic, protocol, messageType
func (*NetworkCoreMetrics) InboundMessageReceived ¶ added in v0.29.1
func (_m *NetworkCoreMetrics) InboundMessageReceived(sizeBytes int, topic string, protocol string, messageType string)
InboundMessageReceived provides a mock function with given fields: sizeBytes, topic, protocol, messageType
func (*NetworkCoreMetrics) MessageAdded ¶ added in v0.29.1
func (_m *NetworkCoreMetrics) MessageAdded(priority int)
MessageAdded provides a mock function with given fields: priority
func (*NetworkCoreMetrics) MessageProcessingFinished ¶ added in v0.29.1
func (_m *NetworkCoreMetrics) MessageProcessingFinished(topic string, duration time.Duration)
MessageProcessingFinished provides a mock function with given fields: topic, duration
func (*NetworkCoreMetrics) MessageProcessingStarted ¶ added in v0.29.1
func (_m *NetworkCoreMetrics) MessageProcessingStarted(topic string)
MessageProcessingStarted provides a mock function with given fields: topic
func (*NetworkCoreMetrics) MessageRemoved ¶ added in v0.29.1
func (_m *NetworkCoreMetrics) MessageRemoved(priority int)
MessageRemoved provides a mock function with given fields: priority
func (*NetworkCoreMetrics) OnMisbehaviorReported ¶ added in v0.31.0
func (_m *NetworkCoreMetrics) OnMisbehaviorReported(channel string, misbehaviorType string)
OnMisbehaviorReported provides a mock function with given fields: channel, misbehaviorType
func (*NetworkCoreMetrics) OnRateLimitedPeer ¶ added in v0.32.0
func (_m *NetworkCoreMetrics) OnRateLimitedPeer(pid peer.ID, role string, msgType string, topic string, reason string)
OnRateLimitedPeer provides a mock function with given fields: pid, role, msgType, topic, reason
func (*NetworkCoreMetrics) OnUnauthorizedMessage ¶ added in v0.32.0
func (_m *NetworkCoreMetrics) OnUnauthorizedMessage(role string, msgType string, topic string, offense string)
OnUnauthorizedMessage provides a mock function with given fields: role, msgType, topic, offense
func (*NetworkCoreMetrics) OnViolationReportSkipped ¶ added in v0.32.0
func (_m *NetworkCoreMetrics) OnViolationReportSkipped()
OnViolationReportSkipped provides a mock function with given fields:
func (*NetworkCoreMetrics) OutboundMessageSent ¶ added in v0.29.1
func (_m *NetworkCoreMetrics) OutboundMessageSent(sizeBytes int, topic string, protocol string, messageType string)
OutboundMessageSent provides a mock function with given fields: sizeBytes, topic, protocol, messageType
func (*NetworkCoreMetrics) QueueDuration ¶ added in v0.29.1
func (_m *NetworkCoreMetrics) QueueDuration(duration time.Duration, priority int)
QueueDuration provides a mock function with given fields: duration, priority
func (*NetworkCoreMetrics) UnicastMessageSendingCompleted ¶ added in v0.29.1
func (_m *NetworkCoreMetrics) UnicastMessageSendingCompleted(topic string)
UnicastMessageSendingCompleted provides a mock function with given fields: topic
func (*NetworkCoreMetrics) UnicastMessageSendingStarted ¶ added in v0.29.1
func (_m *NetworkCoreMetrics) UnicastMessageSendingStarted(topic string)
UnicastMessageSendingStarted provides a mock function with given fields: topic
type NetworkInboundQueueMetrics ¶ added in v0.29.1
NetworkInboundQueueMetrics is an autogenerated mock type for the NetworkInboundQueueMetrics type
func NewNetworkInboundQueueMetrics ¶ added in v0.29.1
func NewNetworkInboundQueueMetrics(t interface { mock.TestingT Cleanup(func()) }) *NetworkInboundQueueMetrics
NewNetworkInboundQueueMetrics creates a new instance of NetworkInboundQueueMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*NetworkInboundQueueMetrics) MessageAdded ¶ added in v0.29.1
func (_m *NetworkInboundQueueMetrics) MessageAdded(priority int)
MessageAdded provides a mock function with given fields: priority
func (*NetworkInboundQueueMetrics) MessageRemoved ¶ added in v0.29.1
func (_m *NetworkInboundQueueMetrics) MessageRemoved(priority int)
MessageRemoved provides a mock function with given fields: priority
func (*NetworkInboundQueueMetrics) QueueDuration ¶ added in v0.29.1
func (_m *NetworkInboundQueueMetrics) QueueDuration(duration time.Duration, priority int)
QueueDuration provides a mock function with given fields: duration, priority
type NetworkMetrics ¶
NetworkMetrics is an autogenerated mock type for the NetworkMetrics type
func NewNetworkMetrics ¶ added in v0.26.1
func NewNetworkMetrics(t interface { mock.TestingT Cleanup(func()) }) *NetworkMetrics
NewNetworkMetrics creates a new instance of NetworkMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*NetworkMetrics) AllowConn ¶ added in v0.29.0
func (_m *NetworkMetrics) AllowConn(dir network.Direction, usefd bool)
AllowConn provides a mock function with given fields: dir, usefd
func (*NetworkMetrics) AllowMemory ¶ added in v0.29.0
func (_m *NetworkMetrics) AllowMemory(size int)
AllowMemory provides a mock function with given fields: size
func (*NetworkMetrics) AllowPeer ¶ added in v0.29.0
func (_m *NetworkMetrics) AllowPeer(p peer.ID)
AllowPeer provides a mock function with given fields: p
func (*NetworkMetrics) AllowProtocol ¶ added in v0.29.0
func (_m *NetworkMetrics) AllowProtocol(proto protocol.ID)
AllowProtocol provides a mock function with given fields: proto
func (*NetworkMetrics) AllowService ¶ added in v0.29.0
func (_m *NetworkMetrics) AllowService(svc string)
AllowService provides a mock function with given fields: svc
func (*NetworkMetrics) AllowStream ¶ added in v0.29.0
func (_m *NetworkMetrics) AllowStream(p peer.ID, dir network.Direction)
AllowStream provides a mock function with given fields: p, dir
func (*NetworkMetrics) AsyncProcessingFinished ¶ added in v0.31.0
func (_m *NetworkMetrics) AsyncProcessingFinished(duration time.Duration)
AsyncProcessingFinished provides a mock function with given fields: duration
func (*NetworkMetrics) AsyncProcessingStarted ¶ added in v0.31.0
func (_m *NetworkMetrics) AsyncProcessingStarted()
AsyncProcessingStarted provides a mock function with given fields:
func (*NetworkMetrics) BlockConn ¶ added in v0.29.0
func (_m *NetworkMetrics) BlockConn(dir network.Direction, usefd bool)
BlockConn provides a mock function with given fields: dir, usefd
func (*NetworkMetrics) BlockMemory ¶ added in v0.29.0
func (_m *NetworkMetrics) BlockMemory(size int)
BlockMemory provides a mock function with given fields: size
func (*NetworkMetrics) BlockPeer ¶ added in v0.29.0
func (_m *NetworkMetrics) BlockPeer(p peer.ID)
BlockPeer provides a mock function with given fields: p
func (*NetworkMetrics) BlockProtocol ¶ added in v0.29.0
func (_m *NetworkMetrics) BlockProtocol(proto protocol.ID)
BlockProtocol provides a mock function with given fields: proto
func (*NetworkMetrics) BlockProtocolPeer ¶ added in v0.29.0
func (_m *NetworkMetrics) BlockProtocolPeer(proto protocol.ID, p peer.ID)
BlockProtocolPeer provides a mock function with given fields: proto, p
func (*NetworkMetrics) BlockService ¶ added in v0.29.0
func (_m *NetworkMetrics) BlockService(svc string)
BlockService provides a mock function with given fields: svc
func (*NetworkMetrics) BlockServicePeer ¶ added in v0.29.0
func (_m *NetworkMetrics) BlockServicePeer(svc string, p peer.ID)
BlockServicePeer provides a mock function with given fields: svc, p
func (*NetworkMetrics) BlockStream ¶ added in v0.29.0
func (_m *NetworkMetrics) BlockStream(p peer.ID, dir network.Direction)
BlockStream provides a mock function with given fields: p, dir
func (*NetworkMetrics) DNSLookupDuration ¶ added in v0.21.0
func (_m *NetworkMetrics) DNSLookupDuration(duration time.Duration)
DNSLookupDuration provides a mock function with given fields: duration
func (*NetworkMetrics) DuplicateInboundMessagesDropped ¶ added in v0.29.1
func (_m *NetworkMetrics) DuplicateInboundMessagesDropped(topic string, _a1 string, messageType string)
DuplicateInboundMessagesDropped provides a mock function with given fields: topic, _a1, messageType
func (*NetworkMetrics) DuplicateMessagePenalties ¶ added in v0.33.30
func (_m *NetworkMetrics) DuplicateMessagePenalties(penalty float64)
DuplicateMessagePenalties provides a mock function with given fields: penalty
func (*NetworkMetrics) DuplicateMessagesCounts ¶ added in v0.33.30
func (_m *NetworkMetrics) DuplicateMessagesCounts(count float64)
DuplicateMessagesCounts provides a mock function with given fields: count
func (*NetworkMetrics) InboundConnections ¶ added in v0.12.0
func (_m *NetworkMetrics) InboundConnections(connectionCount uint)
InboundConnections provides a mock function with given fields: connectionCount
func (*NetworkMetrics) InboundMessageReceived ¶ added in v0.29.1
func (_m *NetworkMetrics) InboundMessageReceived(sizeBytes int, topic string, _a2 string, messageType string)
InboundMessageReceived provides a mock function with given fields: sizeBytes, topic, _a2, messageType
func (*NetworkMetrics) MessageAdded ¶
func (_m *NetworkMetrics) MessageAdded(priority int)
MessageAdded provides a mock function with given fields: priority
func (*NetworkMetrics) MessageProcessingFinished ¶ added in v0.24.7
func (_m *NetworkMetrics) MessageProcessingFinished(topic string, duration time.Duration)
MessageProcessingFinished provides a mock function with given fields: topic, duration
func (*NetworkMetrics) MessageProcessingStarted ¶ added in v0.24.7
func (_m *NetworkMetrics) MessageProcessingStarted(topic string)
MessageProcessingStarted provides a mock function with given fields: topic
func (*NetworkMetrics) MessageRemoved ¶
func (_m *NetworkMetrics) MessageRemoved(priority int)
MessageRemoved provides a mock function with given fields: priority
func (*NetworkMetrics) OnActiveClusterIDsNotSetErr ¶ added in v0.33.7
func (_m *NetworkMetrics) OnActiveClusterIDsNotSetErr()
OnActiveClusterIDsNotSetErr provides a mock function with given fields:
func (*NetworkMetrics) OnAppSpecificScoreUpdated ¶ added in v0.30.0
func (_m *NetworkMetrics) OnAppSpecificScoreUpdated(_a0 float64)
OnAppSpecificScoreUpdated provides a mock function with given fields: _a0
func (*NetworkMetrics) OnBehaviourPenaltyUpdated ¶ added in v0.30.0
func (_m *NetworkMetrics) OnBehaviourPenaltyUpdated(_a0 float64)
OnBehaviourPenaltyUpdated provides a mock function with given fields: _a0
func (*NetworkMetrics) OnControlMessagesTruncated ¶ added in v0.33.1
func (_m *NetworkMetrics) OnControlMessagesTruncated(messageType p2pmsg.ControlMessageType, diff int)
OnControlMessagesTruncated provides a mock function with given fields: messageType, diff
func (*NetworkMetrics) OnDNSCacheHit ¶ added in v0.21.0
func (_m *NetworkMetrics) OnDNSCacheHit()
OnDNSCacheHit provides a mock function with given fields:
func (*NetworkMetrics) OnDNSCacheInvalidated ¶ added in v0.21.1
func (_m *NetworkMetrics) OnDNSCacheInvalidated()
OnDNSCacheInvalidated provides a mock function with given fields:
func (*NetworkMetrics) OnDNSCacheMiss ¶ added in v0.21.0
func (_m *NetworkMetrics) OnDNSCacheMiss()
OnDNSCacheMiss provides a mock function with given fields:
func (*NetworkMetrics) OnDNSLookupRequestDropped ¶ added in v0.23.9
func (_m *NetworkMetrics) OnDNSLookupRequestDropped()
OnDNSLookupRequestDropped provides a mock function with given fields:
func (*NetworkMetrics) OnDialRetryBudgetResetToDefault ¶ added in v0.32.2
func (_m *NetworkMetrics) OnDialRetryBudgetResetToDefault()
OnDialRetryBudgetResetToDefault provides a mock function with given fields:
func (*NetworkMetrics) OnDialRetryBudgetUpdated ¶ added in v0.32.2
func (_m *NetworkMetrics) OnDialRetryBudgetUpdated(budget uint64)
OnDialRetryBudgetUpdated provides a mock function with given fields: budget
func (*NetworkMetrics) OnEstablishStreamFailure ¶ added in v0.30.0
func (_m *NetworkMetrics) OnEstablishStreamFailure(duration time.Duration, attempts int)
OnEstablishStreamFailure provides a mock function with given fields: duration, attempts
func (*NetworkMetrics) OnFirstMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *NetworkMetrics) OnFirstMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnFirstMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*NetworkMetrics) OnGraftDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *NetworkMetrics) OnGraftDuplicateTopicIdsExceedThreshold()
OnGraftDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*NetworkMetrics) OnGraftInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *NetworkMetrics) OnGraftInvalidTopicIdsExceedThreshold()
OnGraftInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*NetworkMetrics) OnGraftMessageInspected ¶ added in v0.33.7
func (_m *NetworkMetrics) OnGraftMessageInspected(duplicateTopicIds int, invalidTopicIds int)
OnGraftMessageInspected provides a mock function with given fields: duplicateTopicIds, invalidTopicIds
func (*NetworkMetrics) OnIHaveControlMessageIdsTruncated ¶ added in v0.33.1
func (_m *NetworkMetrics) OnIHaveControlMessageIdsTruncated(diff int)
OnIHaveControlMessageIdsTruncated provides a mock function with given fields: diff
func (*NetworkMetrics) OnIHaveDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *NetworkMetrics) OnIHaveDuplicateMessageIdsExceedThreshold()
OnIHaveDuplicateMessageIdsExceedThreshold provides a mock function with given fields:
func (*NetworkMetrics) OnIHaveDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *NetworkMetrics) OnIHaveDuplicateTopicIdsExceedThreshold()
OnIHaveDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*NetworkMetrics) OnIHaveInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *NetworkMetrics) OnIHaveInvalidTopicIdsExceedThreshold()
OnIHaveInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*NetworkMetrics) OnIHaveMessageIDsReceived ¶ added in v0.33.1
func (_m *NetworkMetrics) OnIHaveMessageIDsReceived(channel string, msgIdCount int)
OnIHaveMessageIDsReceived provides a mock function with given fields: channel, msgIdCount
func (*NetworkMetrics) OnIHaveMessagesInspected ¶ added in v0.33.7
func (_m *NetworkMetrics) OnIHaveMessagesInspected(duplicateTopicIds int, duplicateMessageIds int, invalidTopicIds int)
OnIHaveMessagesInspected provides a mock function with given fields: duplicateTopicIds, duplicateMessageIds, invalidTopicIds
func (*NetworkMetrics) OnIPColocationFactorUpdated ¶ added in v0.30.0
func (_m *NetworkMetrics) OnIPColocationFactorUpdated(_a0 float64)
OnIPColocationFactorUpdated provides a mock function with given fields: _a0
func (*NetworkMetrics) OnIWantCacheMissMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *NetworkMetrics) OnIWantCacheMissMessageIdsExceedThreshold()
OnIWantCacheMissMessageIdsExceedThreshold provides a mock function with given fields:
func (*NetworkMetrics) OnIWantControlMessageIdsTruncated ¶ added in v0.33.1
func (_m *NetworkMetrics) OnIWantControlMessageIdsTruncated(diff int)
OnIWantControlMessageIdsTruncated provides a mock function with given fields: diff
func (*NetworkMetrics) OnIWantDuplicateMessageIdsExceedThreshold ¶ added in v0.33.7
func (_m *NetworkMetrics) OnIWantDuplicateMessageIdsExceedThreshold()
OnIWantDuplicateMessageIdsExceedThreshold provides a mock function with given fields:
func (*NetworkMetrics) OnIWantMessageIDsReceived ¶ added in v0.33.1
func (_m *NetworkMetrics) OnIWantMessageIDsReceived(msgIdCount int)
OnIWantMessageIDsReceived provides a mock function with given fields: msgIdCount
func (*NetworkMetrics) OnIWantMessagesInspected ¶ added in v0.33.7
func (_m *NetworkMetrics) OnIWantMessagesInspected(duplicateCount int, cacheMissCount int)
OnIWantMessagesInspected provides a mock function with given fields: duplicateCount, cacheMissCount
func (*NetworkMetrics) OnIncomingRpcReceived ¶ added in v0.33.1
func (_m *NetworkMetrics) OnIncomingRpcReceived(iHaveCount int, iWantCount int, graftCount int, pruneCount int, msgCount int)
OnIncomingRpcReceived provides a mock function with given fields: iHaveCount, iWantCount, graftCount, pruneCount, msgCount
func (*NetworkMetrics) OnInvalidControlMessageNotificationSent ¶ added in v0.33.7
func (_m *NetworkMetrics) OnInvalidControlMessageNotificationSent()
OnInvalidControlMessageNotificationSent provides a mock function with given fields:
func (*NetworkMetrics) OnInvalidMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *NetworkMetrics) OnInvalidMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnInvalidMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*NetworkMetrics) OnInvalidTopicIdDetectedForControlMessage ¶ added in v0.33.7
func (_m *NetworkMetrics) OnInvalidTopicIdDetectedForControlMessage(messageType p2pmsg.ControlMessageType)
OnInvalidTopicIdDetectedForControlMessage provides a mock function with given fields: messageType
func (*NetworkMetrics) OnLocalMeshSizeUpdated ¶ added in v0.30.0
func (_m *NetworkMetrics) OnLocalMeshSizeUpdated(topic string, size int)
OnLocalMeshSizeUpdated provides a mock function with given fields: topic, size
func (*NetworkMetrics) OnLocalPeerJoinedTopic ¶ added in v0.33.1
func (_m *NetworkMetrics) OnLocalPeerJoinedTopic()
OnLocalPeerJoinedTopic provides a mock function with given fields:
func (*NetworkMetrics) OnLocalPeerLeftTopic ¶ added in v0.33.1
func (_m *NetworkMetrics) OnLocalPeerLeftTopic()
OnLocalPeerLeftTopic provides a mock function with given fields:
func (*NetworkMetrics) OnMeshMessageDeliveredUpdated ¶ added in v0.30.0
func (_m *NetworkMetrics) OnMeshMessageDeliveredUpdated(_a0 channels.Topic, _a1 float64)
OnMeshMessageDeliveredUpdated provides a mock function with given fields: _a0, _a1
func (*NetworkMetrics) OnMessageDeliveredToAllSubscribers ¶ added in v0.33.1
func (_m *NetworkMetrics) OnMessageDeliveredToAllSubscribers(size int)
OnMessageDeliveredToAllSubscribers provides a mock function with given fields: size
func (*NetworkMetrics) OnMessageDuplicate ¶ added in v0.33.1
func (_m *NetworkMetrics) OnMessageDuplicate(size int)
OnMessageDuplicate provides a mock function with given fields: size
func (*NetworkMetrics) OnMessageEnteredValidation ¶ added in v0.33.1
func (_m *NetworkMetrics) OnMessageEnteredValidation(size int)
OnMessageEnteredValidation provides a mock function with given fields: size
func (*NetworkMetrics) OnMessageRejected ¶ added in v0.33.1
func (_m *NetworkMetrics) OnMessageRejected(size int, reason string)
OnMessageRejected provides a mock function with given fields: size, reason
func (*NetworkMetrics) OnMisbehaviorReported ¶ added in v0.31.0
func (_m *NetworkMetrics) OnMisbehaviorReported(channel string, misbehaviorType string)
OnMisbehaviorReported provides a mock function with given fields: channel, misbehaviorType
func (*NetworkMetrics) OnOutboundRpcDropped ¶ added in v0.33.1
func (_m *NetworkMetrics) OnOutboundRpcDropped()
OnOutboundRpcDropped provides a mock function with given fields:
func (*NetworkMetrics) OnOverallPeerScoreUpdated ¶ added in v0.30.0
func (_m *NetworkMetrics) OnOverallPeerScoreUpdated(_a0 float64)
OnOverallPeerScoreUpdated provides a mock function with given fields: _a0
func (*NetworkMetrics) OnPeerAddedToProtocol ¶ added in v0.33.1
func (_m *NetworkMetrics) OnPeerAddedToProtocol(_a0 string)
OnPeerAddedToProtocol provides a mock function with given fields: _a0
func (*NetworkMetrics) OnPeerDialFailure ¶ added in v0.30.0
func (_m *NetworkMetrics) OnPeerDialFailure(duration time.Duration, attempts int)
OnPeerDialFailure provides a mock function with given fields: duration, attempts
func (*NetworkMetrics) OnPeerDialed ¶ added in v0.30.0
func (_m *NetworkMetrics) OnPeerDialed(duration time.Duration, attempts int)
OnPeerDialed provides a mock function with given fields: duration, attempts
func (*NetworkMetrics) OnPeerGraftTopic ¶ added in v0.33.1
func (_m *NetworkMetrics) OnPeerGraftTopic(topic string)
OnPeerGraftTopic provides a mock function with given fields: topic
func (*NetworkMetrics) OnPeerPruneTopic ¶ added in v0.33.1
func (_m *NetworkMetrics) OnPeerPruneTopic(topic string)
OnPeerPruneTopic provides a mock function with given fields: topic
func (*NetworkMetrics) OnPeerRemovedFromProtocol ¶ added in v0.33.1
func (_m *NetworkMetrics) OnPeerRemovedFromProtocol()
OnPeerRemovedFromProtocol provides a mock function with given fields:
func (*NetworkMetrics) OnPeerThrottled ¶ added in v0.33.1
func (_m *NetworkMetrics) OnPeerThrottled()
OnPeerThrottled provides a mock function with given fields:
func (*NetworkMetrics) OnPruneDuplicateTopicIdsExceedThreshold ¶ added in v0.33.7
func (_m *NetworkMetrics) OnPruneDuplicateTopicIdsExceedThreshold()
OnPruneDuplicateTopicIdsExceedThreshold provides a mock function with given fields:
func (*NetworkMetrics) OnPruneInvalidTopicIdsExceedThreshold ¶ added in v0.33.30
func (_m *NetworkMetrics) OnPruneInvalidTopicIdsExceedThreshold()
OnPruneInvalidTopicIdsExceedThreshold provides a mock function with given fields:
func (*NetworkMetrics) OnPruneMessageInspected ¶ added in v0.33.7
func (_m *NetworkMetrics) OnPruneMessageInspected(duplicateTopicIds int, invalidTopicIds int)
OnPruneMessageInspected provides a mock function with given fields: duplicateTopicIds, invalidTopicIds
func (*NetworkMetrics) OnPublishMessageInspected ¶ added in v0.33.7
func (_m *NetworkMetrics) OnPublishMessageInspected(totalErrCount int, invalidTopicIdsCount int, invalidSubscriptionsCount int, invalidSendersCount int)
OnPublishMessageInspected provides a mock function with given fields: totalErrCount, invalidTopicIdsCount, invalidSubscriptionsCount, invalidSendersCount
func (*NetworkMetrics) OnPublishMessagesInspectionErrorExceedsThreshold ¶ added in v0.33.7
func (_m *NetworkMetrics) OnPublishMessagesInspectionErrorExceedsThreshold()
OnPublishMessagesInspectionErrorExceedsThreshold provides a mock function with given fields:
func (*NetworkMetrics) OnRateLimitedPeer ¶ added in v0.30.0
func (_m *NetworkMetrics) OnRateLimitedPeer(pid peer.ID, role string, msgType string, topic string, reason string)
OnRateLimitedPeer provides a mock function with given fields: pid, role, msgType, topic, reason
func (*NetworkMetrics) OnRpcReceived ¶ added in v0.33.1
func (_m *NetworkMetrics) OnRpcReceived(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
OnRpcReceived provides a mock function with given fields: msgCount, iHaveCount, iWantCount, graftCount, pruneCount
func (*NetworkMetrics) OnRpcRejectedFromUnknownSender ¶ added in v0.33.30
func (_m *NetworkMetrics) OnRpcRejectedFromUnknownSender()
OnRpcRejectedFromUnknownSender provides a mock function with given fields:
func (*NetworkMetrics) OnRpcSent ¶ added in v0.33.1
func (_m *NetworkMetrics) OnRpcSent(msgCount int, iHaveCount int, iWantCount int, graftCount int, pruneCount int)
OnRpcSent provides a mock function with given fields: msgCount, iHaveCount, iWantCount, graftCount, pruneCount
func (*NetworkMetrics) OnStreamCreated ¶ added in v0.30.0
func (_m *NetworkMetrics) OnStreamCreated(duration time.Duration, attempts int)
OnStreamCreated provides a mock function with given fields: duration, attempts
func (*NetworkMetrics) OnStreamCreationFailure ¶ added in v0.30.0
func (_m *NetworkMetrics) OnStreamCreationFailure(duration time.Duration, attempts int)
OnStreamCreationFailure provides a mock function with given fields: duration, attempts
func (*NetworkMetrics) OnStreamCreationRetryBudgetResetToDefault ¶ added in v0.32.2
func (_m *NetworkMetrics) OnStreamCreationRetryBudgetResetToDefault()
OnStreamCreationRetryBudgetResetToDefault provides a mock function with given fields:
func (*NetworkMetrics) OnStreamCreationRetryBudgetUpdated ¶ added in v0.32.2
func (_m *NetworkMetrics) OnStreamCreationRetryBudgetUpdated(budget uint64)
OnStreamCreationRetryBudgetUpdated provides a mock function with given fields: budget
func (*NetworkMetrics) OnStreamEstablished ¶ added in v0.30.0
func (_m *NetworkMetrics) OnStreamEstablished(duration time.Duration, attempts int)
OnStreamEstablished provides a mock function with given fields: duration, attempts
func (*NetworkMetrics) OnTimeInMeshUpdated ¶ added in v0.30.0
func (_m *NetworkMetrics) OnTimeInMeshUpdated(_a0 channels.Topic, _a1 time.Duration)
OnTimeInMeshUpdated provides a mock function with given fields: _a0, _a1
func (*NetworkMetrics) OnUnauthorizedMessage ¶ added in v0.28.0
func (_m *NetworkMetrics) OnUnauthorizedMessage(role string, msgType string, topic string, offense string)
OnUnauthorizedMessage provides a mock function with given fields: role, msgType, topic, offense
func (*NetworkMetrics) OnUndeliveredMessage ¶ added in v0.33.1
func (_m *NetworkMetrics) OnUndeliveredMessage()
OnUndeliveredMessage provides a mock function with given fields:
func (*NetworkMetrics) OnUnstakedPeerInspectionFailed ¶ added in v0.33.7
func (_m *NetworkMetrics) OnUnstakedPeerInspectionFailed()
OnUnstakedPeerInspectionFailed provides a mock function with given fields:
func (*NetworkMetrics) OnViolationReportSkipped ¶ added in v0.32.0
func (_m *NetworkMetrics) OnViolationReportSkipped()
OnViolationReportSkipped provides a mock function with given fields:
func (*NetworkMetrics) OutboundConnections ¶ added in v0.12.0
func (_m *NetworkMetrics) OutboundConnections(connectionCount uint)
OutboundConnections provides a mock function with given fields: connectionCount
func (*NetworkMetrics) OutboundMessageSent ¶ added in v0.29.1
func (_m *NetworkMetrics) OutboundMessageSent(sizeBytes int, topic string, _a2 string, messageType string)
OutboundMessageSent provides a mock function with given fields: sizeBytes, topic, _a2, messageType
func (*NetworkMetrics) QueueDuration ¶
func (_m *NetworkMetrics) QueueDuration(duration time.Duration, priority int)
QueueDuration provides a mock function with given fields: duration, priority
func (*NetworkMetrics) RoutingTablePeerAdded ¶ added in v0.26.16
func (_m *NetworkMetrics) RoutingTablePeerAdded()
RoutingTablePeerAdded provides a mock function with given fields:
func (*NetworkMetrics) RoutingTablePeerRemoved ¶ added in v0.26.16
func (_m *NetworkMetrics) RoutingTablePeerRemoved()
RoutingTablePeerRemoved provides a mock function with given fields:
func (*NetworkMetrics) SetWarningStateCount ¶ added in v0.30.0
func (_m *NetworkMetrics) SetWarningStateCount(_a0 uint)
SetWarningStateCount provides a mock function with given fields: _a0
func (*NetworkMetrics) UnicastMessageSendingCompleted ¶ added in v0.29.1
func (_m *NetworkMetrics) UnicastMessageSendingCompleted(topic string)
UnicastMessageSendingCompleted provides a mock function with given fields: topic
func (*NetworkMetrics) UnicastMessageSendingStarted ¶ added in v0.29.1
func (_m *NetworkMetrics) UnicastMessageSendingStarted(topic string)
UnicastMessageSendingStarted provides a mock function with given fields: topic
type NetworkSecurityMetrics ¶ added in v0.28.0
NetworkSecurityMetrics is an autogenerated mock type for the NetworkSecurityMetrics type
func NewNetworkSecurityMetrics ¶ added in v0.28.0
func NewNetworkSecurityMetrics(t interface { mock.TestingT Cleanup(func()) }) *NetworkSecurityMetrics
NewNetworkSecurityMetrics creates a new instance of NetworkSecurityMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*NetworkSecurityMetrics) OnRateLimitedPeer ¶ added in v0.30.0
func (_m *NetworkSecurityMetrics) OnRateLimitedPeer(pid peer.ID, role string, msgType string, topic string, reason string)
OnRateLimitedPeer provides a mock function with given fields: pid, role, msgType, topic, reason
func (*NetworkSecurityMetrics) OnUnauthorizedMessage ¶ added in v0.28.0
func (_m *NetworkSecurityMetrics) OnUnauthorizedMessage(role string, msgType string, topic string, offense string)
OnUnauthorizedMessage provides a mock function with given fields: role, msgType, topic, offense
func (*NetworkSecurityMetrics) OnViolationReportSkipped ¶ added in v0.32.0
func (_m *NetworkSecurityMetrics) OnViolationReportSkipped()
OnViolationReportSkipped provides a mock function with given fields:
type NewJobListener ¶ added in v0.15.0
NewJobListener is an autogenerated mock type for the NewJobListener type
func NewNewJobListener ¶ added in v0.26.1
func NewNewJobListener(t interface { mock.TestingT Cleanup(func()) }) *NewJobListener
NewNewJobListener creates a new instance of NewJobListener. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*NewJobListener) Check ¶ added in v0.15.0
func (_m *NewJobListener) Check()
Check provides a mock function with given fields:
type PendingBlockBuffer ¶
PendingBlockBuffer is an autogenerated mock type for the PendingBlockBuffer type
func NewPendingBlockBuffer ¶ added in v0.26.1
func NewPendingBlockBuffer(t interface { mock.TestingT Cleanup(func()) }) *PendingBlockBuffer
NewPendingBlockBuffer creates a new instance of PendingBlockBuffer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PendingBlockBuffer) ByID ¶
func (_m *PendingBlockBuffer) ByID(blockID flow.Identifier) (flow.Slashable[*flow.Block], bool)
ByID provides a mock function with given fields: blockID
func (*PendingBlockBuffer) ByParentID ¶
func (_m *PendingBlockBuffer) ByParentID(parentID flow.Identifier) ([]flow.Slashable[*flow.Block], bool)
ByParentID provides a mock function with given fields: parentID
func (*PendingBlockBuffer) DropForParent ¶
func (_m *PendingBlockBuffer) DropForParent(parentID flow.Identifier)
DropForParent provides a mock function with given fields: parentID
func (*PendingBlockBuffer) PruneByView ¶ added in v0.25.0
func (_m *PendingBlockBuffer) PruneByView(view uint64)
PruneByView provides a mock function with given fields: view
func (*PendingBlockBuffer) Size ¶
func (_m *PendingBlockBuffer) Size() uint
Size provides a mock function with given fields:
type PendingClusterBlockBuffer ¶
PendingClusterBlockBuffer is an autogenerated mock type for the PendingClusterBlockBuffer type
func NewPendingClusterBlockBuffer ¶ added in v0.26.1
func NewPendingClusterBlockBuffer(t interface { mock.TestingT Cleanup(func()) }) *PendingClusterBlockBuffer
NewPendingClusterBlockBuffer creates a new instance of PendingClusterBlockBuffer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PendingClusterBlockBuffer) ByID ¶
func (_m *PendingClusterBlockBuffer) ByID(blockID flow.Identifier) (flow.Slashable[*cluster.Block], bool)
ByID provides a mock function with given fields: blockID
func (*PendingClusterBlockBuffer) ByParentID ¶
func (_m *PendingClusterBlockBuffer) ByParentID(parentID flow.Identifier) ([]flow.Slashable[*cluster.Block], bool)
ByParentID provides a mock function with given fields: parentID
func (*PendingClusterBlockBuffer) DropForParent ¶
func (_m *PendingClusterBlockBuffer) DropForParent(parentID flow.Identifier)
DropForParent provides a mock function with given fields: parentID
func (*PendingClusterBlockBuffer) PruneByView ¶ added in v0.25.0
func (_m *PendingClusterBlockBuffer) PruneByView(view uint64)
PruneByView provides a mock function with given fields: view
func (*PendingClusterBlockBuffer) Size ¶
func (_m *PendingClusterBlockBuffer) Size() uint
Size provides a mock function with given fields:
type PingMetrics ¶
PingMetrics is an autogenerated mock type for the PingMetrics type
func NewPingMetrics ¶ added in v0.26.1
func NewPingMetrics(t interface { mock.TestingT Cleanup(func()) }) *PingMetrics
NewPingMetrics creates a new instance of PingMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PingMetrics) NodeInfo ¶ added in v0.17.6
func (_m *PingMetrics) NodeInfo(node *flow.Identity, nodeInfo string, version string, sealedHeight uint64, hotstuffCurView uint64)
NodeInfo provides a mock function with given fields: node, nodeInfo, version, sealedHeight, hotstuffCurView
func (*PingMetrics) NodeReachable ¶
NodeReachable provides a mock function with given fields: node, nodeInfo, rtt
type ProcessingNotifier ¶ added in v0.15.0
ProcessingNotifier is an autogenerated mock type for the ProcessingNotifier type
func NewProcessingNotifier ¶ added in v0.26.1
func NewProcessingNotifier(t interface { mock.TestingT Cleanup(func()) }) *ProcessingNotifier
NewProcessingNotifier creates a new instance of ProcessingNotifier. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ProcessingNotifier) Notify ¶ added in v0.15.0
func (_m *ProcessingNotifier) Notify(entityID flow.Identifier)
Notify provides a mock function with given fields: entityID
type ProviderMetrics ¶
ProviderMetrics is an autogenerated mock type for the ProviderMetrics type
func NewProviderMetrics ¶ added in v0.26.1
func NewProviderMetrics(t interface { mock.TestingT Cleanup(func()) }) *ProviderMetrics
NewProviderMetrics creates a new instance of ProviderMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ProviderMetrics) ChunkDataPackRequestProcessed ¶ added in v0.28.0
func (_m *ProviderMetrics) ChunkDataPackRequestProcessed()
ChunkDataPackRequestProcessed provides a mock function with given fields:
type PublicKey ¶ added in v0.23.9
PublicKey is an autogenerated mock type for the PublicKey type
func NewPublicKey ¶ added in v0.26.1
func NewPublicKey(t mockConstructorTestingTNewPublicKey) *PublicKey
NewPublicKey creates a new instance of PublicKey. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*PublicKey) Algorithm ¶ added in v0.23.9
func (_m *PublicKey) Algorithm() crypto.SigningAlgorithm
Algorithm provides a mock function with given fields:
func (*PublicKey) EncodeCompressed ¶ added in v0.23.9
EncodeCompressed provides a mock function with given fields:
type QCContractClient ¶
QCContractClient is an autogenerated mock type for the QCContractClient type
func NewQCContractClient ¶ added in v0.26.1
func NewQCContractClient(t interface { mock.TestingT Cleanup(func()) }) *QCContractClient
NewQCContractClient creates a new instance of QCContractClient. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*QCContractClient) SubmitVote ¶
SubmitVote provides a mock function with given fields: ctx, vote
type RandomBeaconKeyStore ¶ added in v0.23.9
RandomBeaconKeyStore is an autogenerated mock type for the RandomBeaconKeyStore type
func NewRandomBeaconKeyStore ¶ added in v0.26.1
func NewRandomBeaconKeyStore(t interface { mock.TestingT Cleanup(func()) }) *RandomBeaconKeyStore
NewRandomBeaconKeyStore creates a new instance of RandomBeaconKeyStore. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*RandomBeaconKeyStore) ByView ¶ added in v0.23.9
func (_m *RandomBeaconKeyStore) ByView(view uint64) (crypto.PrivateKey, error)
ByView provides a mock function with given fields: view
type RateLimitedBlockstoreMetrics ¶ added in v0.28.0
RateLimitedBlockstoreMetrics is an autogenerated mock type for the RateLimitedBlockstoreMetrics type
func NewRateLimitedBlockstoreMetrics ¶ added in v0.28.0
func NewRateLimitedBlockstoreMetrics(t interface { mock.TestingT Cleanup(func()) }) *RateLimitedBlockstoreMetrics
NewRateLimitedBlockstoreMetrics creates a new instance of RateLimitedBlockstoreMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*RateLimitedBlockstoreMetrics) BytesRead ¶ added in v0.28.0
func (_m *RateLimitedBlockstoreMetrics) BytesRead(_a0 int)
BytesRead provides a mock function with given fields: _a0
type ReadyDoneAware ¶
ReadyDoneAware is an autogenerated mock type for the ReadyDoneAware type
func NewReadyDoneAware ¶ added in v0.26.1
func NewReadyDoneAware(t interface { mock.TestingT Cleanup(func()) }) *ReadyDoneAware
NewReadyDoneAware creates a new instance of ReadyDoneAware. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ReadyDoneAware) Done ¶
func (_m *ReadyDoneAware) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*ReadyDoneAware) Ready ¶
func (_m *ReadyDoneAware) Ready() <-chan struct{}
Ready provides a mock function with given fields:
type ReceiptValidator ¶ added in v0.14.0
ReceiptValidator is an autogenerated mock type for the ReceiptValidator type
func NewReceiptValidator ¶ added in v0.26.1
func NewReceiptValidator(t interface { mock.TestingT Cleanup(func()) }) *ReceiptValidator
NewReceiptValidator creates a new instance of ReceiptValidator. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ReceiptValidator) Validate ¶ added in v0.14.0
func (_m *ReceiptValidator) Validate(receipt *flow.ExecutionReceipt) error
Validate provides a mock function with given fields: receipt
func (*ReceiptValidator) ValidatePayload ¶ added in v0.16.0
func (_m *ReceiptValidator) ValidatePayload(candidate *flow.Block) error
ValidatePayload provides a mock function with given fields: candidate
type Requester ¶
Requester is an autogenerated mock type for the Requester type
func NewRequester ¶ added in v0.26.1
NewRequester creates a new instance of Requester. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*Requester) EntityByID ¶
func (_m *Requester) EntityByID(entityID flow.Identifier, selector flow.IdentityFilter[flow.Identity])
EntityByID provides a mock function with given fields: entityID, selector
func (*Requester) Force ¶
func (_m *Requester) Force()
Force provides a mock function with given fields:
func (*Requester) Query ¶ added in v0.15.0
func (_m *Requester) Query(key flow.Identifier, selector flow.IdentityFilter[flow.Identity])
Query provides a mock function with given fields: key, selector
type ResolverMetrics ¶ added in v0.21.0
ResolverMetrics is an autogenerated mock type for the ResolverMetrics type
func NewResolverMetrics ¶ added in v0.26.1
func NewResolverMetrics(t interface { mock.TestingT Cleanup(func()) }) *ResolverMetrics
NewResolverMetrics creates a new instance of ResolverMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ResolverMetrics) DNSLookupDuration ¶ added in v0.21.0
func (_m *ResolverMetrics) DNSLookupDuration(duration time.Duration)
DNSLookupDuration provides a mock function with given fields: duration
func (*ResolverMetrics) OnDNSCacheHit ¶ added in v0.21.0
func (_m *ResolverMetrics) OnDNSCacheHit()
OnDNSCacheHit provides a mock function with given fields:
func (*ResolverMetrics) OnDNSCacheInvalidated ¶ added in v0.21.1
func (_m *ResolverMetrics) OnDNSCacheInvalidated()
OnDNSCacheInvalidated provides a mock function with given fields:
func (*ResolverMetrics) OnDNSCacheMiss ¶ added in v0.21.0
func (_m *ResolverMetrics) OnDNSCacheMiss()
OnDNSCacheMiss provides a mock function with given fields:
func (*ResolverMetrics) OnDNSLookupRequestDropped ¶ added in v0.23.9
func (_m *ResolverMetrics) OnDNSLookupRequestDropped()
OnDNSLookupRequestDropped provides a mock function with given fields:
type RestMetrics ¶ added in v0.31.0
RestMetrics is an autogenerated mock type for the RestMetrics type
func NewRestMetrics ¶ added in v0.31.0
func NewRestMetrics(t interface { mock.TestingT Cleanup(func()) }) *RestMetrics
NewRestMetrics creates a new instance of RestMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*RestMetrics) AddInflightRequests ¶ added in v0.31.0
func (_m *RestMetrics) AddInflightRequests(ctx context.Context, props metrics.HTTPProperties, quantity int)
AddInflightRequests provides a mock function with given fields: ctx, props, quantity
func (*RestMetrics) AddTotalRequests ¶ added in v0.31.0
func (_m *RestMetrics) AddTotalRequests(ctx context.Context, method string, routeName string)
AddTotalRequests provides a mock function with given fields: ctx, method, routeName
func (*RestMetrics) ObserveHTTPRequestDuration ¶ added in v0.31.0
func (_m *RestMetrics) ObserveHTTPRequestDuration(ctx context.Context, props metrics.HTTPReqProperties, duration time.Duration)
ObserveHTTPRequestDuration provides a mock function with given fields: ctx, props, duration
func (*RestMetrics) ObserveHTTPResponseSize ¶ added in v0.31.0
func (_m *RestMetrics) ObserveHTTPResponseSize(ctx context.Context, props metrics.HTTPReqProperties, sizeBytes int64)
ObserveHTTPResponseSize provides a mock function with given fields: ctx, props, sizeBytes
type RuntimeMetrics ¶
RuntimeMetrics is an autogenerated mock type for the RuntimeMetrics type
func NewRuntimeMetrics ¶ added in v0.26.1
func NewRuntimeMetrics(t interface { mock.TestingT Cleanup(func()) }) *RuntimeMetrics
NewRuntimeMetrics creates a new instance of RuntimeMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*RuntimeMetrics) RuntimeSetNumberOfAccounts ¶ added in v0.18.3
func (_m *RuntimeMetrics) RuntimeSetNumberOfAccounts(count uint64)
RuntimeSetNumberOfAccounts provides a mock function with given fields: count
func (*RuntimeMetrics) RuntimeTransactionChecked ¶ added in v0.18.3
func (_m *RuntimeMetrics) RuntimeTransactionChecked(dur time.Duration)
RuntimeTransactionChecked provides a mock function with given fields: dur
func (*RuntimeMetrics) RuntimeTransactionInterpreted ¶ added in v0.18.3
func (_m *RuntimeMetrics) RuntimeTransactionInterpreted(dur time.Duration)
RuntimeTransactionInterpreted provides a mock function with given fields: dur
func (*RuntimeMetrics) RuntimeTransactionParsed ¶ added in v0.18.3
func (_m *RuntimeMetrics) RuntimeTransactionParsed(dur time.Duration)
RuntimeTransactionParsed provides a mock function with given fields: dur
func (*RuntimeMetrics) RuntimeTransactionProgramsCacheHit ¶ added in v0.29.17
func (_m *RuntimeMetrics) RuntimeTransactionProgramsCacheHit()
RuntimeTransactionProgramsCacheHit provides a mock function with given fields:
func (*RuntimeMetrics) RuntimeTransactionProgramsCacheMiss ¶ added in v0.29.17
func (_m *RuntimeMetrics) RuntimeTransactionProgramsCacheMiss()
RuntimeTransactionProgramsCacheMiss provides a mock function with given fields:
type SDKClientWrapper ¶ added in v0.20.0
SDKClientWrapper is an autogenerated mock type for the SDKClientWrapper type
func NewSDKClientWrapper ¶ added in v0.26.1
func NewSDKClientWrapper(t interface { mock.TestingT Cleanup(func()) }) *SDKClientWrapper
NewSDKClientWrapper creates a new instance of SDKClientWrapper. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*SDKClientWrapper) ExecuteScriptAtBlockID ¶ added in v0.20.0
func (_m *SDKClientWrapper) ExecuteScriptAtBlockID(_a0 context.Context, _a1 flow.Identifier, _a2 []byte, _a3 []cadence.Value) (cadence.Value, error)
ExecuteScriptAtBlockID provides a mock function with given fields: _a0, _a1, _a2, _a3
func (*SDKClientWrapper) ExecuteScriptAtLatestBlock ¶ added in v0.20.0
func (_m *SDKClientWrapper) ExecuteScriptAtLatestBlock(_a0 context.Context, _a1 []byte, _a2 []cadence.Value) (cadence.Value, error)
ExecuteScriptAtLatestBlock provides a mock function with given fields: _a0, _a1, _a2
func (*SDKClientWrapper) GetAccount ¶ added in v0.20.0
func (_m *SDKClientWrapper) GetAccount(_a0 context.Context, _a1 flow.Address) (*flow.Account, error)
GetAccount provides a mock function with given fields: _a0, _a1
func (*SDKClientWrapper) GetAccountAtLatestBlock ¶ added in v0.20.0
func (_m *SDKClientWrapper) GetAccountAtLatestBlock(_a0 context.Context, _a1 flow.Address) (*flow.Account, error)
GetAccountAtLatestBlock provides a mock function with given fields: _a0, _a1
func (*SDKClientWrapper) GetLatestBlock ¶ added in v0.20.0
GetLatestBlock provides a mock function with given fields: _a0, _a1
func (*SDKClientWrapper) GetTransactionResult ¶ added in v0.20.0
func (_m *SDKClientWrapper) GetTransactionResult(_a0 context.Context, _a1 flow.Identifier) (*flow.TransactionResult, error)
GetTransactionResult provides a mock function with given fields: _a0, _a1
func (*SDKClientWrapper) SendTransaction ¶ added in v0.20.0
func (_m *SDKClientWrapper) SendTransaction(_a0 context.Context, _a1 flow.Transaction) error
SendTransaction provides a mock function with given fields: _a0, _a1
type SealValidator ¶ added in v0.14.0
SealValidator is an autogenerated mock type for the SealValidator type
func NewSealValidator ¶ added in v0.26.1
func NewSealValidator(t interface { mock.TestingT Cleanup(func()) }) *SealValidator
NewSealValidator creates a new instance of SealValidator. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
type SealingConfigsGetter ¶ added in v0.26.17
SealingConfigsGetter is an autogenerated mock type for the SealingConfigsGetter type
func NewSealingConfigsGetter ¶ added in v0.26.17
func NewSealingConfigsGetter(t interface { mock.TestingT Cleanup(func()) }) *SealingConfigsGetter
NewSealingConfigsGetter creates a new instance of SealingConfigsGetter. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*SealingConfigsGetter) ApprovalRequestsThresholdConst ¶ added in v0.26.17
func (_m *SealingConfigsGetter) ApprovalRequestsThresholdConst() uint64
ApprovalRequestsThresholdConst provides a mock function with given fields:
func (*SealingConfigsGetter) ChunkAlphaConst ¶ added in v0.26.17
func (_m *SealingConfigsGetter) ChunkAlphaConst() uint
ChunkAlphaConst provides a mock function with given fields:
func (*SealingConfigsGetter) EmergencySealingActiveConst ¶ added in v0.26.17
func (_m *SealingConfigsGetter) EmergencySealingActiveConst() bool
EmergencySealingActiveConst provides a mock function with given fields:
func (*SealingConfigsGetter) RequireApprovalsForSealConstructionDynamicValue ¶ added in v0.26.17
func (_m *SealingConfigsGetter) RequireApprovalsForSealConstructionDynamicValue() uint
RequireApprovalsForSealConstructionDynamicValue provides a mock function with given fields:
func (*SealingConfigsGetter) RequireApprovalsForSealVerificationConst ¶ added in v0.26.17
func (_m *SealingConfigsGetter) RequireApprovalsForSealVerificationConst() uint
RequireApprovalsForSealVerificationConst provides a mock function with given fields:
type SealingConfigsSetter ¶ added in v0.26.17
SealingConfigsSetter is an autogenerated mock type for the SealingConfigsSetter type
func NewSealingConfigsSetter ¶ added in v0.26.17
func NewSealingConfigsSetter(t interface { mock.TestingT Cleanup(func()) }) *SealingConfigsSetter
NewSealingConfigsSetter creates a new instance of SealingConfigsSetter. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*SealingConfigsSetter) ApprovalRequestsThresholdConst ¶ added in v0.26.17
func (_m *SealingConfigsSetter) ApprovalRequestsThresholdConst() uint64
ApprovalRequestsThresholdConst provides a mock function with given fields:
func (*SealingConfigsSetter) ChunkAlphaConst ¶ added in v0.26.17
func (_m *SealingConfigsSetter) ChunkAlphaConst() uint
ChunkAlphaConst provides a mock function with given fields:
func (*SealingConfigsSetter) EmergencySealingActiveConst ¶ added in v0.26.17
func (_m *SealingConfigsSetter) EmergencySealingActiveConst() bool
EmergencySealingActiveConst provides a mock function with given fields:
func (*SealingConfigsSetter) RequireApprovalsForSealConstructionDynamicValue ¶ added in v0.26.17
func (_m *SealingConfigsSetter) RequireApprovalsForSealConstructionDynamicValue() uint
RequireApprovalsForSealConstructionDynamicValue provides a mock function with given fields:
func (*SealingConfigsSetter) RequireApprovalsForSealVerificationConst ¶ added in v0.26.17
func (_m *SealingConfigsSetter) RequireApprovalsForSealVerificationConst() uint
RequireApprovalsForSealVerificationConst provides a mock function with given fields:
func (*SealingConfigsSetter) SetRequiredApprovalsForSealingConstruction ¶ added in v0.26.17
func (_m *SealingConfigsSetter) SetRequiredApprovalsForSealingConstruction(newVal uint) error
SetRequiredApprovalsForSealingConstruction provides a mock function with given fields: newVal
type Startable ¶ added in v0.22.4
Startable is an autogenerated mock type for the Startable type
func NewStartable ¶ added in v0.26.1
NewStartable creates a new instance of Startable. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*Startable) Start ¶ added in v0.22.4
func (_m *Startable) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
type SyncCore ¶
SyncCore is an autogenerated mock type for the SyncCore type
func NewSyncCore ¶ added in v0.26.1
NewSyncCore creates a new instance of SyncCore. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*SyncCore) BatchRequested ¶
BatchRequested provides a mock function with given fields: batch
func (*SyncCore) HandleBlock ¶
HandleBlock provides a mock function with given fields: header
func (*SyncCore) HandleHeight ¶
HandleHeight provides a mock function with given fields: final, height
func (*SyncCore) RangeRequested ¶
RangeRequested provides a mock function with given fields: ran
func (*SyncCore) ScanPending ¶
ScanPending provides a mock function with given fields: final
type Tracer ¶
Tracer is an autogenerated mock type for the Tracer type
func NewTracer ¶ added in v0.26.1
NewTracer creates a new instance of Tracer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*Tracer) BlockRootSpan ¶ added in v0.30.0
func (_m *Tracer) BlockRootSpan(blockID flow.Identifier) trace.Span
BlockRootSpan provides a mock function with given fields: blockID
func (*Tracer) Done ¶
func (_m *Tracer) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*Tracer) Ready ¶
func (_m *Tracer) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*Tracer) ShouldSample ¶ added in v0.30.0
func (_m *Tracer) ShouldSample(entityID flow.Identifier) bool
ShouldSample provides a mock function with given fields: entityID
func (*Tracer) StartBlockSpan ¶ added in v0.22.0
func (_m *Tracer) StartBlockSpan(ctx context.Context, blockID flow.Identifier, spanName moduletrace.SpanName, opts ...trace.SpanStartOption) (trace.Span, context.Context)
StartBlockSpan provides a mock function with given fields: ctx, blockID, spanName, opts
func (*Tracer) StartCollectionSpan ¶ added in v0.22.0
func (_m *Tracer) StartCollectionSpan(ctx context.Context, collectionID flow.Identifier, spanName moduletrace.SpanName, opts ...trace.SpanStartOption) (trace.Span, context.Context)
StartCollectionSpan provides a mock function with given fields: ctx, collectionID, spanName, opts
func (*Tracer) StartSampledSpanFromParent ¶ added in v0.30.0
func (_m *Tracer) StartSampledSpanFromParent(parentSpan trace.Span, entityID flow.Identifier, operationName moduletrace.SpanName, opts ...trace.SpanStartOption) trace.Span
StartSampledSpanFromParent provides a mock function with given fields: parentSpan, entityID, operationName, opts
func (*Tracer) StartSpanFromContext ¶
func (_m *Tracer) StartSpanFromContext(ctx context.Context, operationName moduletrace.SpanName, opts ...trace.SpanStartOption) (trace.Span, context.Context)
StartSpanFromContext provides a mock function with given fields: ctx, operationName, opts
func (*Tracer) StartSpanFromParent ¶
func (_m *Tracer) StartSpanFromParent(parentSpan trace.Span, operationName moduletrace.SpanName, opts ...trace.SpanStartOption) trace.Span
StartSpanFromParent provides a mock function with given fields: parentSpan, operationName, opts
func (*Tracer) WithSpanFromContext ¶ added in v0.15.0
func (_m *Tracer) WithSpanFromContext(ctx context.Context, operationName moduletrace.SpanName, f func(), opts ...trace.SpanStartOption)
WithSpanFromContext provides a mock function with given fields: ctx, operationName, f, opts
type TransactionMetrics ¶
TransactionMetrics is an autogenerated mock type for the TransactionMetrics type
func NewTransactionMetrics ¶ added in v0.26.1
func NewTransactionMetrics(t interface { mock.TestingT Cleanup(func()) }) *TransactionMetrics
NewTransactionMetrics creates a new instance of TransactionMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*TransactionMetrics) TransactionExecuted ¶
func (_m *TransactionMetrics) TransactionExecuted(txID flow.Identifier, when time.Time)
TransactionExecuted provides a mock function with given fields: txID, when
func (*TransactionMetrics) TransactionExpired ¶
func (_m *TransactionMetrics) TransactionExpired(txID flow.Identifier)
TransactionExpired provides a mock function with given fields: txID
func (*TransactionMetrics) TransactionFinalized ¶
func (_m *TransactionMetrics) TransactionFinalized(txID flow.Identifier, when time.Time)
TransactionFinalized provides a mock function with given fields: txID, when
func (*TransactionMetrics) TransactionReceived ¶
func (_m *TransactionMetrics) TransactionReceived(txID flow.Identifier, when time.Time)
TransactionReceived provides a mock function with given fields: txID, when
func (*TransactionMetrics) TransactionResultFetched ¶ added in v0.26.1
func (_m *TransactionMetrics) TransactionResultFetched(dur time.Duration, size int)
TransactionResultFetched provides a mock function with given fields: dur, size
func (*TransactionMetrics) TransactionSubmissionFailed ¶
func (_m *TransactionMetrics) TransactionSubmissionFailed()
TransactionSubmissionFailed provides a mock function with given fields:
type UnicastManagerMetrics ¶ added in v0.30.0
UnicastManagerMetrics is an autogenerated mock type for the UnicastManagerMetrics type
func NewUnicastManagerMetrics ¶ added in v0.30.0
func NewUnicastManagerMetrics(t interface { mock.TestingT Cleanup(func()) }) *UnicastManagerMetrics
NewUnicastManagerMetrics creates a new instance of UnicastManagerMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*UnicastManagerMetrics) OnDialRetryBudgetResetToDefault ¶ added in v0.32.2
func (_m *UnicastManagerMetrics) OnDialRetryBudgetResetToDefault()
OnDialRetryBudgetResetToDefault provides a mock function with given fields:
func (*UnicastManagerMetrics) OnDialRetryBudgetUpdated ¶ added in v0.32.2
func (_m *UnicastManagerMetrics) OnDialRetryBudgetUpdated(budget uint64)
OnDialRetryBudgetUpdated provides a mock function with given fields: budget
func (*UnicastManagerMetrics) OnEstablishStreamFailure ¶ added in v0.30.0
func (_m *UnicastManagerMetrics) OnEstablishStreamFailure(duration time.Duration, attempts int)
OnEstablishStreamFailure provides a mock function with given fields: duration, attempts
func (*UnicastManagerMetrics) OnPeerDialFailure ¶ added in v0.30.0
func (_m *UnicastManagerMetrics) OnPeerDialFailure(duration time.Duration, attempts int)
OnPeerDialFailure provides a mock function with given fields: duration, attempts
func (*UnicastManagerMetrics) OnPeerDialed ¶ added in v0.30.0
func (_m *UnicastManagerMetrics) OnPeerDialed(duration time.Duration, attempts int)
OnPeerDialed provides a mock function with given fields: duration, attempts
func (*UnicastManagerMetrics) OnStreamCreated ¶ added in v0.30.0
func (_m *UnicastManagerMetrics) OnStreamCreated(duration time.Duration, attempts int)
OnStreamCreated provides a mock function with given fields: duration, attempts
func (*UnicastManagerMetrics) OnStreamCreationFailure ¶ added in v0.30.0
func (_m *UnicastManagerMetrics) OnStreamCreationFailure(duration time.Duration, attempts int)
OnStreamCreationFailure provides a mock function with given fields: duration, attempts
func (*UnicastManagerMetrics) OnStreamCreationRetryBudgetResetToDefault ¶ added in v0.32.2
func (_m *UnicastManagerMetrics) OnStreamCreationRetryBudgetResetToDefault()
OnStreamCreationRetryBudgetResetToDefault provides a mock function with given fields:
func (*UnicastManagerMetrics) OnStreamCreationRetryBudgetUpdated ¶ added in v0.32.2
func (_m *UnicastManagerMetrics) OnStreamCreationRetryBudgetUpdated(budget uint64)
OnStreamCreationRetryBudgetUpdated provides a mock function with given fields: budget
func (*UnicastManagerMetrics) OnStreamEstablished ¶ added in v0.30.0
func (_m *UnicastManagerMetrics) OnStreamEstablished(duration time.Duration, attempts int)
OnStreamEstablished provides a mock function with given fields: duration, attempts
type VerificationMetrics ¶
VerificationMetrics is an autogenerated mock type for the VerificationMetrics type
func NewVerificationMetrics ¶ added in v0.26.1
func NewVerificationMetrics(t interface { mock.TestingT Cleanup(func()) }) *VerificationMetrics
NewVerificationMetrics creates a new instance of VerificationMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*VerificationMetrics) OnAssignedChunkProcessedAtAssigner ¶ added in v0.17.1
func (_m *VerificationMetrics) OnAssignedChunkProcessedAtAssigner()
OnAssignedChunkProcessedAtAssigner provides a mock function with given fields:
func (*VerificationMetrics) OnAssignedChunkReceivedAtFetcher ¶ added in v0.17.1
func (_m *VerificationMetrics) OnAssignedChunkReceivedAtFetcher()
OnAssignedChunkReceivedAtFetcher provides a mock function with given fields:
func (*VerificationMetrics) OnBlockConsumerJobDone ¶ added in v0.19.0
func (_m *VerificationMetrics) OnBlockConsumerJobDone(_a0 uint64)
OnBlockConsumerJobDone provides a mock function with given fields: _a0
func (*VerificationMetrics) OnChunkConsumerJobDone ¶ added in v0.19.0
func (_m *VerificationMetrics) OnChunkConsumerJobDone(_a0 uint64)
OnChunkConsumerJobDone provides a mock function with given fields: _a0
func (*VerificationMetrics) OnChunkDataPackArrivedAtFetcher ¶ added in v0.17.1
func (_m *VerificationMetrics) OnChunkDataPackArrivedAtFetcher()
OnChunkDataPackArrivedAtFetcher provides a mock function with given fields:
func (*VerificationMetrics) OnChunkDataPackRequestDispatchedInNetworkByRequester ¶ added in v0.19.0
func (_m *VerificationMetrics) OnChunkDataPackRequestDispatchedInNetworkByRequester()
OnChunkDataPackRequestDispatchedInNetworkByRequester provides a mock function with given fields:
func (*VerificationMetrics) OnChunkDataPackRequestReceivedByRequester ¶ added in v0.17.1
func (_m *VerificationMetrics) OnChunkDataPackRequestReceivedByRequester()
OnChunkDataPackRequestReceivedByRequester provides a mock function with given fields:
func (*VerificationMetrics) OnChunkDataPackRequestSentByFetcher ¶ added in v0.17.1
func (_m *VerificationMetrics) OnChunkDataPackRequestSentByFetcher()
OnChunkDataPackRequestSentByFetcher provides a mock function with given fields:
func (*VerificationMetrics) OnChunkDataPackResponseReceivedFromNetworkByRequester ¶ added in v0.19.0
func (_m *VerificationMetrics) OnChunkDataPackResponseReceivedFromNetworkByRequester()
OnChunkDataPackResponseReceivedFromNetworkByRequester provides a mock function with given fields:
func (*VerificationMetrics) OnChunkDataPackSentToFetcher ¶ added in v0.17.1
func (_m *VerificationMetrics) OnChunkDataPackSentToFetcher()
OnChunkDataPackSentToFetcher provides a mock function with given fields:
func (*VerificationMetrics) OnChunksAssignmentDoneAtAssigner ¶ added in v0.17.1
func (_m *VerificationMetrics) OnChunksAssignmentDoneAtAssigner(chunks int)
OnChunksAssignmentDoneAtAssigner provides a mock function with given fields: chunks
func (*VerificationMetrics) OnExecutionResultReceivedAtAssignerEngine ¶ added in v0.19.0
func (_m *VerificationMetrics) OnExecutionResultReceivedAtAssignerEngine()
OnExecutionResultReceivedAtAssignerEngine provides a mock function with given fields:
func (*VerificationMetrics) OnFinalizedBlockArrivedAtAssigner ¶ added in v0.17.1
func (_m *VerificationMetrics) OnFinalizedBlockArrivedAtAssigner(height uint64)
OnFinalizedBlockArrivedAtAssigner provides a mock function with given fields: height
func (*VerificationMetrics) OnResultApprovalDispatchedInNetworkByVerifier ¶ added in v0.19.0
func (_m *VerificationMetrics) OnResultApprovalDispatchedInNetworkByVerifier()
OnResultApprovalDispatchedInNetworkByVerifier provides a mock function with given fields:
func (*VerificationMetrics) OnVerifiableChunkReceivedAtVerifierEngine ¶ added in v0.17.1
func (_m *VerificationMetrics) OnVerifiableChunkReceivedAtVerifierEngine()
OnVerifiableChunkReceivedAtVerifierEngine provides a mock function with given fields:
func (*VerificationMetrics) OnVerifiableChunkSentToVerifier ¶ added in v0.17.1
func (_m *VerificationMetrics) OnVerifiableChunkSentToVerifier()
OnVerifiableChunkSentToVerifier provides a mock function with given fields:
func (*VerificationMetrics) SetMaxChunkDataPackAttemptsForNextUnsealedHeightAtRequester ¶ added in v0.22.0
func (_m *VerificationMetrics) SetMaxChunkDataPackAttemptsForNextUnsealedHeightAtRequester(attempts uint64)
SetMaxChunkDataPackAttemptsForNextUnsealedHeightAtRequester provides a mock function with given fields: attempts
type WALMetrics ¶ added in v0.15.4
WALMetrics is an autogenerated mock type for the WALMetrics type
func NewWALMetrics ¶ added in v0.26.1
func NewWALMetrics(t interface { mock.TestingT Cleanup(func()) }) *WALMetrics
NewWALMetrics creates a new instance of WALMetrics. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*WALMetrics) ExecutionCheckpointSize ¶ added in v0.33.10
func (_m *WALMetrics) ExecutionCheckpointSize(bytes uint64)
ExecutionCheckpointSize provides a mock function with given fields: bytes
Source Files ¶
- access_metrics.go
- alsp_metrics.go
- backend_scripts_metrics.go
- bitswap_metrics.go
- block_requester.go
- builder.go
- cache_metrics.go
- chain_sync_metrics.go
- chunk_assigner.go
- chunk_verifier.go
- cleaner_metrics.go
- cluster_root_qc_voter.go
- collection_executed_metric.go
- collection_metrics.go
- compliance_metrics.go
- consensus_metrics.go
- cruise_ctl_metrics.go
- dht_metrics.go
- dkg_broker.go
- dkg_contract_client.go
- dkg_controller.go
- dkg_controller_factory.go
- engine_metrics.go
- entries_func.go
- epoch_lookup.go
- evm_metrics.go
- execution_data_provider_metrics.go
- execution_data_pruner_metrics.go
- execution_data_requester_metrics.go
- execution_data_requester_v2_metrics.go
- execution_metrics.go
- execution_state_indexer_metrics.go
- finalized_header_cache.go
- finalizer.go
- gossip_sub_metrics.go
- gossip_sub_rpc_inspector_metrics.go
- gossip_sub_rpc_validation_inspector_metrics.go
- gossip_sub_scoring_metrics.go
- gossip_sub_scoring_registry_metrics.go
- grpc_connection_pool_metrics.go
- hero_cache_metrics.go
- hot_stuff.go
- hot_stuff_follower.go
- hotstuff_metrics.go
- identifier_provider.go
- identity_provider.go
- job.go
- job_consumer.go
- job_queue.go
- jobs.go
- ledger_metrics.go
- lib_p2_p_connection_metrics.go
- lib_p2_p_metrics.go
- local.go
- local_gossip_sub_router_metrics.go
- machine_account_metrics.go
- mempool_metrics.go
- network_core_metrics.go
- network_inbound_queue_metrics.go
- network_metrics.go
- network_security_metrics.go
- new_job_listener.go
- pending_block_buffer.go
- pending_cluster_block_buffer.go
- ping_metrics.go
- processing_notifier.go
- provider_metrics.go
- public_key.go
- qc_contract_client.go
- random_beacon_key_store.go
- rate_limited_blockstore_metrics.go
- ready_done_aware.go
- receipt_validator.go
- requester.go
- resolver_metrics.go
- rest_metrics.go
- runtime_metrics.go
- sdk_client_wrapper.go
- seal_validator.go
- sealing_configs_getter.go
- sealing_configs_setter.go
- startable.go
- sync_core.go
- tracer.go
- transaction_metrics.go
- unicast_manager_metrics.go
- verification_metrics.go
- wal_metrics.go