Documentation ¶
Index ¶
- type AggregatingSigner
- func (_m *AggregatingSigner) Aggregate(sigs []crypto.Signature) (crypto.Signature, error)
- func (_m *AggregatingSigner) Sign(msg []byte) (crypto.Signature, error)
- func (_m *AggregatingSigner) Verify(msg []byte, sig crypto.Signature, key crypto.PublicKey) (bool, error)
- func (_m *AggregatingSigner) VerifyMany(msg []byte, sig crypto.Signature, keys []crypto.PublicKey) (bool, error)
- type AggregatingVerifier
- type BackendScriptsMetrics
- type BlockRequester
- type Builder
- type CacheMetrics
- type ChunkAssigner
- type ChunkVerifier
- type CleanerMetrics
- type ClusterRootQCVoter
- type CollectionMetrics
- type ComplianceMetrics
- func (_m *ComplianceMetrics) BlockFinalized(_a0 *flow.Block)
- func (_m *ComplianceMetrics) BlockProposalDuration(duration time.Duration)
- func (_m *ComplianceMetrics) BlockSealed(_a0 *flow.Block)
- func (_m *ComplianceMetrics) CommittedEpochFinalView(view uint64)
- func (_m *ComplianceMetrics) CurrentDKGPhase1FinalView(view uint64)
- func (_m *ComplianceMetrics) CurrentDKGPhase2FinalView(view uint64)
- func (_m *ComplianceMetrics) CurrentDKGPhase3FinalView(view uint64)
- func (_m *ComplianceMetrics) CurrentEpochCounter(counter uint64)
- func (_m *ComplianceMetrics) CurrentEpochFinalView(view uint64)
- func (_m *ComplianceMetrics) CurrentEpochPhase(phase flow.EpochPhase)
- func (_m *ComplianceMetrics) EpochEmergencyFallbackTriggered()
- 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 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 EngineMetrics
- type EntriesFunc
- type EpochLookup
- 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 ExecutionDataServiceMetrics
- func (_m *ExecutionDataServiceMetrics) ExecutionDataAddFinished(duration time.Duration, success bool, blobTreeSize uint64)
- func (_m *ExecutionDataServiceMetrics) ExecutionDataAddStarted()
- func (_m *ExecutionDataServiceMetrics) ExecutionDataGetFinished(duration time.Duration, success bool, blobTreeSize uint64)
- func (_m *ExecutionDataServiceMetrics) ExecutionDataGetStarted()
- type ExecutionMetrics
- func (_m *ExecutionMetrics) ChunkDataPackRequested()
- func (_m *ExecutionMetrics) DiskSize(_a0 uint64)
- func (_m *ExecutionMetrics) ExecutionBlockDataUploadFinished(dur time.Duration)
- func (_m *ExecutionMetrics) ExecutionBlockDataUploadStarted()
- func (_m *ExecutionMetrics) ExecutionBlockExecuted(dur time.Duration, compUsed uint64, txCounts int, colCounts int)
- func (_m *ExecutionMetrics) ExecutionCollectionExecuted(dur time.Duration, compUsed uint64, txCounts int)
- func (_m *ExecutionMetrics) ExecutionCollectionRequestRetried()
- func (_m *ExecutionMetrics) ExecutionCollectionRequestSent()
- func (_m *ExecutionMetrics) ExecutionLastExecutedBlockHeight(height uint64)
- func (_m *ExecutionMetrics) ExecutionScriptExecuted(dur time.Duration, compUsed uint64, memoryUsed uint64, memoryEstimate uint64)
- func (_m *ExecutionMetrics) ExecutionStateReadsPerBlock(reads uint64)
- func (_m *ExecutionMetrics) ExecutionStorageStateCommitment(bytes int64)
- func (_m *ExecutionMetrics) ExecutionSync(syncing bool)
- func (_m *ExecutionMetrics) ExecutionTransactionExecuted(dur time.Duration, compUsed uint64, memoryUsed uint64, memoryEstimate uint64, ...)
- 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) StartBlockReceivedToExecuted(blockID flow.Identifier)
- 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 Finalizer
- 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) OnKeyPutFailure()
- func (_m *HeroCacheMetrics) OnKeyPutSuccess()
- type HotStuff
- type HotStuffFollower
- type HotstuffMetrics
- 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) SetTimeout(duration time.Duration)
- func (_m *HotstuffMetrics) SignerProcessingDuration(duration time.Duration)
- func (_m *HotstuffMetrics) ValidatorProcessingDuration(duration time.Duration)
- 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 Local
- type MempoolMetrics
- type Merger
- type NetworkMetrics
- func (_m *NetworkMetrics) DNSLookupDuration(duration time.Duration)
- func (_m *NetworkMetrics) DirectMessageFinished(topic string)
- func (_m *NetworkMetrics) DirectMessageStarted(topic string)
- func (_m *NetworkMetrics) InboundConnections(connectionCount uint)
- 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) NetworkDuplicateMessagesDropped(topic string, messageType string)
- func (_m *NetworkMetrics) NetworkMessageReceived(sizeBytes int, topic string, messageType string)
- func (_m *NetworkMetrics) NetworkMessageSent(sizeBytes int, topic string, messageType string)
- func (_m *NetworkMetrics) OnDNSCacheHit()
- func (_m *NetworkMetrics) OnDNSCacheInvalidated()
- func (_m *NetworkMetrics) OnDNSCacheMiss()
- func (_m *NetworkMetrics) OnDNSLookupRequestDropped()
- func (_m *NetworkMetrics) OutboundConnections(connectionCount uint)
- func (_m *NetworkMetrics) QueueDuration(duration time.Duration, priority int)
- type NewJobListener
- type PendingBlockBuffer
- func (_m *PendingBlockBuffer) Add(originID flow.Identifier, proposal *messages.BlockProposal) bool
- func (_m *PendingBlockBuffer) ByID(blockID flow.Identifier) (*flow.PendingBlock, bool)
- func (_m *PendingBlockBuffer) ByParentID(parentID flow.Identifier) ([]*flow.PendingBlock, 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(originID flow.Identifier, proposal *messages.ClusterBlockProposal) bool
- func (_m *PendingClusterBlockBuffer) ByID(blockID flow.Identifier) (*cluster.PendingBlock, bool)
- func (_m *PendingClusterBlockBuffer) ByParentID(parentID flow.Identifier) ([]*cluster.PendingBlock, 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 ReadyDoneAware
- type ReceiptValidator
- type Requester
- type ResolverMetrics
- type RuntimeMetrics
- 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, _a3 ...grpc.CallOption) (cadence.Value, error)
- func (_m *SDKClientWrapper) GetAccount(_a0 context.Context, _a1 flow.Address, _a2 ...grpc.CallOption) (*flow.Account, error)
- func (_m *SDKClientWrapper) GetAccountAtLatestBlock(_a0 context.Context, _a1 flow.Address, _a2 ...grpc.CallOption) (*flow.Account, error)
- func (_m *SDKClientWrapper) GetLatestBlock(_a0 context.Context, _a1 bool, _a2 ...grpc.CallOption) (*flow.Block, error)
- func (_m *SDKClientWrapper) GetTransactionResult(_a0 context.Context, _a1 flow.Identifier, _a2 ...grpc.CallOption) (*flow.TransactionResult, error)
- func (_m *SDKClientWrapper) SendTransaction(_a0 context.Context, _a1 flow.Transaction, _a2 ...grpc.CallOption) error
- type SealValidator
- type Signer
- type Startable
- type SyncCore
- func (_m *SyncCore) BatchRequested(batch flow.Batch)
- func (_m *SyncCore) HandleBlock(header *flow.Header) bool
- func (_m *SyncCore) HandleHeight(final *flow.Header, height uint64)
- func (_m *SyncCore) RangeRequested(ran flow.Range)
- func (_m *SyncCore) ScanPending(final *flow.Header) ([]flow.Range, []flow.Batch)
- func (_m *SyncCore) WithinTolerance(final *flow.Header, height uint64) bool
- type ThresholdSigner
- func (_m *ThresholdSigner) Reconstruct(size uint, shares []crypto.Signature, indices []uint) (crypto.Signature, error)
- func (_m *ThresholdSigner) Sign(msg []byte) (crypto.Signature, error)
- func (_m *ThresholdSigner) Verify(msg []byte, sig crypto.Signature, key crypto.PublicKey) (bool, error)
- func (_m *ThresholdSigner) VerifyThreshold(msg []byte, sig crypto.Signature, key crypto.PublicKey) (bool, error)
- type Tracer
- func (_m *Tracer) Done() <-chan struct{}
- func (_m *Tracer) Ready() <-chan struct{}
- func (_m *Tracer) RecordSpanFromParent(span opentracing.Span, operationName trace.SpanName, duration time.Duration, ...)
- func (_m *Tracer) StartBlockSpan(ctx context.Context, blockID flow.Identifier, spanName trace.SpanName, ...) (opentracing.Span, context.Context, bool)
- func (_m *Tracer) StartCollectionSpan(ctx context.Context, collectionID flow.Identifier, spanName trace.SpanName, ...) (opentracing.Span, context.Context, bool)
- func (_m *Tracer) StartSpanFromContext(ctx context.Context, operationName trace.SpanName, ...) (opentracing.Span, context.Context)
- func (_m *Tracer) StartSpanFromParent(span opentracing.Span, operationName trace.SpanName, ...) opentracing.Span
- func (_m *Tracer) StartTransactionSpan(ctx context.Context, transactionID flow.Identifier, spanName trace.SpanName, ...) (opentracing.Span, context.Context, bool)
- func (_m *Tracer) WithSpanFromContext(ctx context.Context, operationName trace.SpanName, f func(), ...)
- type TransactionMetrics
- func (_m *TransactionMetrics) ScriptExecuted(dur time.Duration, size int)
- 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 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 AggregatingSigner ¶
AggregatingSigner is an autogenerated mock type for the AggregatingSigner type
func (*AggregatingSigner) Sign ¶
func (_m *AggregatingSigner) Sign(msg []byte) (crypto.Signature, error)
Sign provides a mock function with given fields: msg
func (*AggregatingSigner) Verify ¶
func (_m *AggregatingSigner) Verify(msg []byte, sig crypto.Signature, key crypto.PublicKey) (bool, error)
Verify provides a mock function with given fields: msg, sig, key
func (*AggregatingSigner) VerifyMany ¶
func (_m *AggregatingSigner) VerifyMany(msg []byte, sig crypto.Signature, keys []crypto.PublicKey) (bool, error)
VerifyMany provides a mock function with given fields: msg, sig, keys
type AggregatingVerifier ¶
AggregatingVerifier is an autogenerated mock type for the AggregatingVerifier type
func (*AggregatingVerifier) Verify ¶
func (_m *AggregatingVerifier) Verify(msg []byte, sig crypto.Signature, key crypto.PublicKey) (bool, error)
Verify provides a mock function with given fields: msg, sig, key
func (*AggregatingVerifier) VerifyMany ¶
func (_m *AggregatingVerifier) VerifyMany(msg []byte, sig crypto.Signature, keys []crypto.PublicKey) (bool, error)
VerifyMany provides a mock function with given fields: msg, sig, keys
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 testing.TB) *BackendScriptsMetrics
NewBackendScriptsMetrics creates a new instance of BackendScriptsMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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
type BlockRequester ¶
BlockRequester is an autogenerated mock type for the BlockRequester type
func NewBlockRequester ¶ added in v0.26.1
func NewBlockRequester(t testing.TB) *BlockRequester
NewBlockRequester creates a new instance of BlockRequester. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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)
RequestBlock provides a mock function with given fields: blockID
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 the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
type CacheMetrics ¶
CacheMetrics is an autogenerated mock type for the CacheMetrics type
func NewCacheMetrics ¶ added in v0.26.1
func NewCacheMetrics(t testing.TB) *CacheMetrics
NewCacheMetrics creates a new instance of CacheMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 ChunkAssigner ¶
ChunkAssigner is an autogenerated mock type for the ChunkAssigner type
func NewChunkAssigner ¶ added in v0.26.1
func NewChunkAssigner(t testing.TB) *ChunkAssigner
NewChunkAssigner creates a new instance of ChunkAssigner. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *ChunkVerifier
NewChunkVerifier creates a new instance of ChunkVerifier. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*ChunkVerifier) SystemChunkVerify ¶
func (_m *ChunkVerifier) SystemChunkVerify(ch *verification.VerifiableChunkData) ([]byte, chunks.ChunkFault, error)
SystemChunkVerify provides a mock function with given fields: ch
func (*ChunkVerifier) Verify ¶
func (_m *ChunkVerifier) Verify(ch *verification.VerifiableChunkData) ([]byte, chunks.ChunkFault, 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 testing.TB) *CleanerMetrics
NewCleanerMetrics creates a new instance of CleanerMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *ClusterRootQCVoter
NewClusterRootQCVoter creates a new instance of ClusterRootQCVoter. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
type CollectionMetrics ¶
CollectionMetrics is an autogenerated mock type for the CollectionMetrics type
func NewCollectionMetrics ¶ added in v0.26.1
func NewCollectionMetrics(t testing.TB) *CollectionMetrics
NewCollectionMetrics creates a new instance of CollectionMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *ComplianceMetrics
NewComplianceMetrics creates a new instance of ComplianceMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*ComplianceMetrics) BlockFinalized ¶
func (_m *ComplianceMetrics) BlockFinalized(_a0 *flow.Block)
BlockFinalized provides a mock function with given fields: _a0
func (*ComplianceMetrics) BlockProposalDuration ¶ added in v0.15.0
func (_m *ComplianceMetrics) BlockProposalDuration(duration time.Duration)
BlockProposalDuration provides a mock function with given fields: duration
func (*ComplianceMetrics) BlockSealed ¶
func (_m *ComplianceMetrics) BlockSealed(_a0 *flow.Block)
BlockSealed provides a mock function with given fields: _a0
func (*ComplianceMetrics) CommittedEpochFinalView ¶ added in v0.18.3
func (_m *ComplianceMetrics) CommittedEpochFinalView(view uint64)
CommittedEpochFinalView provides a mock function with given fields: view
func (*ComplianceMetrics) CurrentDKGPhase1FinalView ¶ added in v0.21.0
func (_m *ComplianceMetrics) CurrentDKGPhase1FinalView(view uint64)
CurrentDKGPhase1FinalView provides a mock function with given fields: view
func (*ComplianceMetrics) CurrentDKGPhase2FinalView ¶ added in v0.21.0
func (_m *ComplianceMetrics) CurrentDKGPhase2FinalView(view uint64)
CurrentDKGPhase2FinalView provides a mock function with given fields: view
func (*ComplianceMetrics) CurrentDKGPhase3FinalView ¶ added in v0.21.0
func (_m *ComplianceMetrics) CurrentDKGPhase3FinalView(view uint64)
CurrentDKGPhase3FinalView provides a mock function with given fields: view
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) EpochEmergencyFallbackTriggered ¶ added in v0.23.2
func (_m *ComplianceMetrics) EpochEmergencyFallbackTriggered()
EpochEmergencyFallbackTriggered provides a mock function with given fields:
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 testing.TB) *ConsensusMetrics
NewConsensusMetrics creates a new instance of ConsensusMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 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 the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *DKGContractClient
NewDKGContractClient creates a new instance of DKGContractClient. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *DKGController
NewDKGController creates a new instance of DKGController. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *DKGControllerFactory
NewDKGControllerFactory creates a new instance of DKGControllerFactory. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*DKGControllerFactory) Create ¶ added in v0.20.0
func (_m *DKGControllerFactory) Create(dkgInstanceID string, participants flow.IdentityList, seed []byte) (module.DKGController, error)
Create provides a mock function with given fields: dkgInstanceID, participants, seed
type EngineMetrics ¶
EngineMetrics is an autogenerated mock type for the EngineMetrics type
func NewEngineMetrics ¶ added in v0.26.1
func NewEngineMetrics(t testing.TB) *EngineMetrics
NewEngineMetrics creates a new instance of EngineMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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
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 testing.TB) *EntriesFunc
NewEntriesFunc creates a new instance of EntriesFunc. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *EpochLookup
NewEpochLookup creates a new instance of EpochLookup. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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
func (*EpochLookup) EpochForViewWithFallback ¶ added in v0.21.1
func (_m *EpochLookup) EpochForViewWithFallback(view uint64) (uint64, error)
EpochForViewWithFallback provides a mock function with given fields: view
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 testing.TB) *ExecutionDataRequesterMetrics
NewExecutionDataRequesterMetrics creates a new instance of ExecutionDataRequesterMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 ExecutionDataServiceMetrics ¶ added in v0.23.5
ExecutionDataServiceMetrics is an autogenerated mock type for the ExecutionDataServiceMetrics type
func NewExecutionDataServiceMetrics ¶ added in v0.26.1
func NewExecutionDataServiceMetrics(t testing.TB) *ExecutionDataServiceMetrics
NewExecutionDataServiceMetrics creates a new instance of ExecutionDataServiceMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*ExecutionDataServiceMetrics) ExecutionDataAddFinished ¶ added in v0.23.5
func (_m *ExecutionDataServiceMetrics) ExecutionDataAddFinished(duration time.Duration, success bool, blobTreeSize uint64)
ExecutionDataAddFinished provides a mock function with given fields: duration, success, blobTreeSize
func (*ExecutionDataServiceMetrics) ExecutionDataAddStarted ¶ added in v0.23.5
func (_m *ExecutionDataServiceMetrics) ExecutionDataAddStarted()
ExecutionDataAddStarted provides a mock function with given fields:
func (*ExecutionDataServiceMetrics) ExecutionDataGetFinished ¶ added in v0.23.5
func (_m *ExecutionDataServiceMetrics) ExecutionDataGetFinished(duration time.Duration, success bool, blobTreeSize uint64)
ExecutionDataGetFinished provides a mock function with given fields: duration, success, blobTreeSize
func (*ExecutionDataServiceMetrics) ExecutionDataGetStarted ¶ added in v0.23.5
func (_m *ExecutionDataServiceMetrics) ExecutionDataGetStarted()
ExecutionDataGetStarted 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 testing.TB) *ExecutionMetrics
NewExecutionMetrics creates a new instance of ExecutionMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*ExecutionMetrics) ChunkDataPackRequested ¶
func (_m *ExecutionMetrics) ChunkDataPackRequested()
ChunkDataPackRequested provides a mock function with given fields:
func (*ExecutionMetrics) DiskSize ¶ added in v0.10.0
func (_m *ExecutionMetrics) DiskSize(_a0 uint64)
DiskSize provides a mock function with given fields: _a0
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, compUsed uint64, txCounts int, colCounts int)
ExecutionBlockExecuted provides a mock function with given fields: dur, compUsed, txCounts, colCounts
func (*ExecutionMetrics) ExecutionCollectionExecuted ¶ added in v0.18.3
func (_m *ExecutionMetrics) ExecutionCollectionExecuted(dur time.Duration, compUsed uint64, txCounts int)
ExecutionCollectionExecuted provides a mock function with given fields: dur, compUsed, txCounts
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) ExecutionLastExecutedBlockHeight ¶
func (_m *ExecutionMetrics) ExecutionLastExecutedBlockHeight(height uint64)
ExecutionLastExecutedBlockHeight 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) ExecutionStateReadsPerBlock ¶
func (_m *ExecutionMetrics) ExecutionStateReadsPerBlock(reads uint64)
ExecutionStateReadsPerBlock provides a mock function with given fields: reads
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, compUsed uint64, memoryUsed uint64, memoryEstimate uint64, eventCounts int, failed bool)
ExecutionTransactionExecuted provides a mock function with given fields: dur, compUsed, memoryUsed, memoryEstimate, eventCounts, failed
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) StartBlockReceivedToExecuted ¶
func (_m *ExecutionMetrics) StartBlockReceivedToExecuted(blockID flow.Identifier)
StartBlockReceivedToExecuted provides a mock function with given fields: blockID
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 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 the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *HeroCacheMetrics
NewHeroCacheMetrics creates a new instance of HeroCacheMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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) OnKeyPutFailure ¶ added in v0.24.11
func (_m *HeroCacheMetrics) OnKeyPutFailure()
OnKeyPutFailure provides a mock function with given fields:
func (*HeroCacheMetrics) OnKeyPutSuccess ¶ added in v0.24.11
func (_m *HeroCacheMetrics) OnKeyPutSuccess()
OnKeyPutSuccess provides a mock function with given fields:
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 the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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
type HotStuffFollower ¶
HotStuffFollower is an autogenerated mock type for the HotStuffFollower type
func NewHotStuffFollower ¶ added in v0.26.1
func NewHotStuffFollower(t testing.TB) *HotStuffFollower
NewHotStuffFollower creates a new instance of HotStuffFollower. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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) SubmitProposal ¶
func (_m *HotStuffFollower) SubmitProposal(proposal *flow.Header, parentView uint64)
SubmitProposal provides a mock function with given fields: proposal, parentView
type HotstuffMetrics ¶
HotstuffMetrics is an autogenerated mock type for the HotstuffMetrics type
func NewHotstuffMetrics ¶ added in v0.26.1
func NewHotstuffMetrics(t testing.TB) *HotstuffMetrics
NewHotstuffMetrics creates a new instance of HotstuffMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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) 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) ValidatorProcessingDuration ¶
func (_m *HotstuffMetrics) ValidatorProcessingDuration(duration time.Duration)
ValidatorProcessingDuration provides a mock function with given fields: duration
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 testing.TB) *JobConsumer
NewJobConsumer creates a new instance of JobConsumer. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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(defaultIndex uint64) error
Start provides a mock function with given fields: defaultIndex
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 the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
type LedgerMetrics ¶
LedgerMetrics is an autogenerated mock type for the LedgerMetrics type
func NewLedgerMetrics ¶ added in v0.26.1
func NewLedgerMetrics(t testing.TB) *LedgerMetrics
NewLedgerMetrics creates a new instance of LedgerMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 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 the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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
NotMeFilter provides a mock function with given fields:
type MempoolMetrics ¶
MempoolMetrics is an autogenerated mock type for the MempoolMetrics type
func NewMempoolMetrics ¶ added in v0.26.1
func NewMempoolMetrics(t testing.TB) *MempoolMetrics
NewMempoolMetrics creates a new instance of MempoolMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 Merger ¶
Merger is an autogenerated mock type for the Merger type
type NetworkMetrics ¶
NetworkMetrics is an autogenerated mock type for the NetworkMetrics type
func NewNetworkMetrics ¶ added in v0.26.1
func NewNetworkMetrics(t testing.TB) *NetworkMetrics
NewNetworkMetrics creates a new instance of NetworkMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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) DirectMessageFinished ¶ added in v0.24.7
func (_m *NetworkMetrics) DirectMessageFinished(topic string)
DirectMessageFinished provides a mock function with given fields: topic
func (*NetworkMetrics) DirectMessageStarted ¶ added in v0.24.7
func (_m *NetworkMetrics) DirectMessageStarted(topic string)
DirectMessageStarted provides a mock function with given fields: topic
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) 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) NetworkDuplicateMessagesDropped ¶
func (_m *NetworkMetrics) NetworkDuplicateMessagesDropped(topic string, messageType string)
NetworkDuplicateMessagesDropped provides a mock function with given fields: topic, messageType
func (*NetworkMetrics) NetworkMessageReceived ¶
func (_m *NetworkMetrics) NetworkMessageReceived(sizeBytes int, topic string, messageType string)
NetworkMessageReceived provides a mock function with given fields: sizeBytes, topic, messageType
func (*NetworkMetrics) NetworkMessageSent ¶
func (_m *NetworkMetrics) NetworkMessageSent(sizeBytes int, topic string, messageType string)
NetworkMessageSent provides a mock function with given fields: sizeBytes, topic, messageType
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) OutboundConnections ¶ added in v0.12.0
func (_m *NetworkMetrics) OutboundConnections(connectionCount uint)
OutboundConnections provides a mock function with given fields: connectionCount
func (*NetworkMetrics) QueueDuration ¶
func (_m *NetworkMetrics) QueueDuration(duration time.Duration, priority int)
QueueDuration provides a mock function with given fields: duration, priority
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 testing.TB) *NewJobListener
NewNewJobListener creates a new instance of NewJobListener. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *PendingBlockBuffer
NewPendingBlockBuffer creates a new instance of PendingBlockBuffer. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*PendingBlockBuffer) Add ¶
func (_m *PendingBlockBuffer) Add(originID flow.Identifier, proposal *messages.BlockProposal) bool
Add provides a mock function with given fields: originID, proposal
func (*PendingBlockBuffer) ByID ¶
func (_m *PendingBlockBuffer) ByID(blockID flow.Identifier) (*flow.PendingBlock, bool)
ByID provides a mock function with given fields: blockID
func (*PendingBlockBuffer) ByParentID ¶
func (_m *PendingBlockBuffer) ByParentID(parentID flow.Identifier) ([]*flow.PendingBlock, 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 testing.TB) *PendingClusterBlockBuffer
NewPendingClusterBlockBuffer creates a new instance of PendingClusterBlockBuffer. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*PendingClusterBlockBuffer) Add ¶
func (_m *PendingClusterBlockBuffer) Add(originID flow.Identifier, proposal *messages.ClusterBlockProposal) bool
Add provides a mock function with given fields: originID, proposal
func (*PendingClusterBlockBuffer) ByID ¶
func (_m *PendingClusterBlockBuffer) ByID(blockID flow.Identifier) (*cluster.PendingBlock, bool)
ByID provides a mock function with given fields: blockID
func (*PendingClusterBlockBuffer) ByParentID ¶
func (_m *PendingClusterBlockBuffer) ByParentID(parentID flow.Identifier) ([]*cluster.PendingBlock, 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 testing.TB) *PingMetrics
NewPingMetrics creates a new instance of PingMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *ProcessingNotifier
NewProcessingNotifier creates a new instance of ProcessingNotifier. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *ProviderMetrics
NewProviderMetrics creates a new instance of ProviderMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*ProviderMetrics) ChunkDataPackRequested ¶
func (_m *ProviderMetrics) ChunkDataPackRequested()
ChunkDataPackRequested 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
NewPublicKey creates a new instance of PublicKey. It also registers the testing.TB 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 testing.TB) *QCContractClient
NewQCContractClient creates a new instance of QCContractClient. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *RandomBeaconKeyStore
NewRandomBeaconKeyStore creates a new instance of RandomBeaconKeyStore. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 ReadyDoneAware ¶
ReadyDoneAware is an autogenerated mock type for the ReadyDoneAware type
func NewReadyDoneAware ¶ added in v0.26.1
func NewReadyDoneAware(t testing.TB) *ReadyDoneAware
NewReadyDoneAware creates a new instance of ReadyDoneAware. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *ReceiptValidator
NewReceiptValidator creates a new instance of ReceiptValidator. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*ReceiptValidator) Validate ¶ added in v0.14.0
func (_m *ReceiptValidator) Validate(receipts *flow.ExecutionReceipt) error
Validate provides a mock function with given fields: receipts
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 the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*Requester) EntityByID ¶
func (_m *Requester) EntityByID(entityID flow.Identifier, selector flow.IdentityFilter)
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)
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 testing.TB) *ResolverMetrics
NewResolverMetrics creates a new instance of ResolverMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 RuntimeMetrics ¶
RuntimeMetrics is an autogenerated mock type for the RuntimeMetrics type
func NewRuntimeMetrics ¶ added in v0.26.1
func NewRuntimeMetrics(t testing.TB) *RuntimeMetrics
NewRuntimeMetrics creates a new instance of RuntimeMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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
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 testing.TB) *SDKClientWrapper
NewSDKClientWrapper creates a new instance of SDKClientWrapper. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*SDKClientWrapper) ExecuteScriptAtBlockID ¶ added in v0.20.0
func (_m *SDKClientWrapper) ExecuteScriptAtBlockID(_a0 context.Context, _a1 flow.Identifier, _a2 []byte, _a3 []cadence.Value, _a4 ...grpc.CallOption) (cadence.Value, error)
ExecuteScriptAtBlockID provides a mock function with given fields: _a0, _a1, _a2, _a3, _a4
func (*SDKClientWrapper) ExecuteScriptAtLatestBlock ¶ added in v0.20.0
func (_m *SDKClientWrapper) ExecuteScriptAtLatestBlock(_a0 context.Context, _a1 []byte, _a2 []cadence.Value, _a3 ...grpc.CallOption) (cadence.Value, error)
ExecuteScriptAtLatestBlock provides a mock function with given fields: _a0, _a1, _a2, _a3
func (*SDKClientWrapper) GetAccount ¶ added in v0.20.0
func (_m *SDKClientWrapper) GetAccount(_a0 context.Context, _a1 flow.Address, _a2 ...grpc.CallOption) (*flow.Account, error)
GetAccount provides a mock function with given fields: _a0, _a1, _a2
func (*SDKClientWrapper) GetAccountAtLatestBlock ¶ added in v0.20.0
func (_m *SDKClientWrapper) GetAccountAtLatestBlock(_a0 context.Context, _a1 flow.Address, _a2 ...grpc.CallOption) (*flow.Account, error)
GetAccountAtLatestBlock provides a mock function with given fields: _a0, _a1, _a2
func (*SDKClientWrapper) GetLatestBlock ¶ added in v0.20.0
func (_m *SDKClientWrapper) GetLatestBlock(_a0 context.Context, _a1 bool, _a2 ...grpc.CallOption) (*flow.Block, error)
GetLatestBlock provides a mock function with given fields: _a0, _a1, _a2
func (*SDKClientWrapper) GetTransactionResult ¶ added in v0.20.0
func (_m *SDKClientWrapper) GetTransactionResult(_a0 context.Context, _a1 flow.Identifier, _a2 ...grpc.CallOption) (*flow.TransactionResult, error)
GetTransactionResult provides a mock function with given fields: _a0, _a1, _a2
func (*SDKClientWrapper) SendTransaction ¶ added in v0.20.0
func (_m *SDKClientWrapper) SendTransaction(_a0 context.Context, _a1 flow.Transaction, _a2 ...grpc.CallOption) error
SendTransaction provides a mock function with given fields: _a0, _a1, _a2
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 testing.TB) *SealValidator
NewSealValidator creates a new instance of SealValidator. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
type Signer ¶
Signer is an autogenerated mock type for the Signer type
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 the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 ThresholdSigner ¶
ThresholdSigner is an autogenerated mock type for the ThresholdSigner type
func (*ThresholdSigner) Reconstruct ¶ added in v0.15.4
func (_m *ThresholdSigner) Reconstruct(size uint, shares []crypto.Signature, indices []uint) (crypto.Signature, error)
Reconstruct provides a mock function with given fields: size, shares, indices
func (*ThresholdSigner) Sign ¶
func (_m *ThresholdSigner) Sign(msg []byte) (crypto.Signature, error)
Sign provides a mock function with given fields: msg
func (*ThresholdSigner) Verify ¶
func (_m *ThresholdSigner) Verify(msg []byte, sig crypto.Signature, key crypto.PublicKey) (bool, error)
Verify provides a mock function with given fields: msg, sig, key
func (*ThresholdSigner) VerifyThreshold ¶
func (_m *ThresholdSigner) VerifyThreshold(msg []byte, sig crypto.Signature, key crypto.PublicKey) (bool, error)
VerifyThreshold provides a mock function with given fields: msg, sig, key
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 the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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) RecordSpanFromParent ¶ added in v0.14.5
func (_m *Tracer) RecordSpanFromParent(span opentracing.Span, operationName trace.SpanName, duration time.Duration, logs []opentracing.LogRecord, opts ...opentracing.StartSpanOption)
RecordSpanFromParent provides a mock function with given fields: span, operationName, duration, logs, opts
func (*Tracer) StartBlockSpan ¶ added in v0.22.0
func (_m *Tracer) StartBlockSpan(ctx context.Context, blockID flow.Identifier, spanName trace.SpanName, opts ...opentracing.StartSpanOption) (opentracing.Span, context.Context, bool)
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 trace.SpanName, opts ...opentracing.StartSpanOption) (opentracing.Span, context.Context, bool)
StartCollectionSpan provides a mock function with given fields: ctx, collectionID, spanName, opts
func (*Tracer) StartSpanFromContext ¶
func (_m *Tracer) StartSpanFromContext(ctx context.Context, operationName trace.SpanName, opts ...opentracing.StartSpanOption) (opentracing.Span, context.Context)
StartSpanFromContext provides a mock function with given fields: ctx, operationName, opts
func (*Tracer) StartSpanFromParent ¶
func (_m *Tracer) StartSpanFromParent(span opentracing.Span, operationName trace.SpanName, opts ...opentracing.StartSpanOption) opentracing.Span
StartSpanFromParent provides a mock function with given fields: span, operationName, opts
func (*Tracer) StartTransactionSpan ¶ added in v0.22.0
func (_m *Tracer) StartTransactionSpan(ctx context.Context, transactionID flow.Identifier, spanName trace.SpanName, opts ...opentracing.StartSpanOption) (opentracing.Span, context.Context, bool)
StartTransactionSpan provides a mock function with given fields: ctx, transactionID, spanName, opts
func (*Tracer) WithSpanFromContext ¶ added in v0.15.0
func (_m *Tracer) WithSpanFromContext(ctx context.Context, operationName trace.SpanName, f func(), opts ...opentracing.StartSpanOption)
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 testing.TB) *TransactionMetrics
NewTransactionMetrics creates a new instance of TransactionMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*TransactionMetrics) ScriptExecuted ¶ added in v0.26.1
func (_m *TransactionMetrics) ScriptExecuted(dur time.Duration, size int)
ScriptExecuted provides a mock function with given fields: dur, size
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 VerificationMetrics ¶
VerificationMetrics is an autogenerated mock type for the VerificationMetrics type
func NewVerificationMetrics ¶ added in v0.26.1
func NewVerificationMetrics(t testing.TB) *VerificationMetrics
NewVerificationMetrics creates a new instance of VerificationMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
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 testing.TB) *WALMetrics
NewWALMetrics creates a new instance of WALMetrics. It also registers the testing.TB interface on the mock and a cleanup function to assert the mocks expectations.
func (*WALMetrics) DiskSize ¶ added in v0.15.4
func (_m *WALMetrics) DiskSize(_a0 uint64)
DiskSize provides a mock function with given fields: _a0
Source Files ¶
- aggregating_signer.go
- aggregating_verifier.go
- backend_scripts_metrics.go
- block_requester.go
- builder.go
- cache_metrics.go
- chunk_assigner.go
- chunk_verifier.go
- cleaner_metrics.go
- cluster_root_qc_voter.go
- collection_metrics.go
- compliance_metrics.go
- consensus_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
- execution_data_requester_metrics.go
- execution_data_service_metrics.go
- execution_metrics.go
- finalizer.go
- hero_cache_metrics.go
- hot_stuff.go
- hot_stuff_follower.go
- hotstuff_metrics.go
- job.go
- job_consumer.go
- job_queue.go
- jobs.go
- ledger_metrics.go
- local.go
- mempool_metrics.go
- merger.go
- network_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
- ready_done_aware.go
- receipt_validator.go
- requester.go
- resolver_metrics.go
- runtime_metrics.go
- sdk_client_wrapper.go
- seal_validator.go
- signer.go
- startable.go
- sync_core.go
- threshold_signer.go
- tracer.go
- transaction_metrics.go
- verification_metrics.go
- wal_metrics.go