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 BadgerMetrics
- func (_m *BadgerMetrics) BadgerLSMSize(sizeBytes int64)
- func (_m *BadgerMetrics) BadgerNumBlockedPuts(n int64)
- func (_m *BadgerMetrics) BadgerNumBytesRead(n int64)
- func (_m *BadgerMetrics) BadgerNumBytesWritten(n int64)
- func (_m *BadgerMetrics) BadgerNumGets(n int64)
- func (_m *BadgerMetrics) BadgerNumMemtableGets(n int64)
- func (_m *BadgerMetrics) BadgerNumPuts(n int64)
- func (_m *BadgerMetrics) BadgerNumReads(n int64)
- func (_m *BadgerMetrics) BadgerNumWrites(n int64)
- func (_m *BadgerMetrics) BadgerVLogSize(sizeBytes int64)
- type BlockRequester
- type Builder
- type CacheMetrics
- type ChunkAssigner
- type ChunkVerifier
- type CleanerMetrics
- type ClusterRootQCVoter
- type ColdStuff
- func (_m *ColdStuff) Done() <-chan struct{}
- func (_m *ColdStuff) Ready() <-chan struct{}
- func (_m *ColdStuff) SubmitCommit(commit *coldstuff.Commit)
- func (_m *ColdStuff) SubmitProposal(proposal *flow.Header, parentView uint64)
- func (_m *ColdStuff) SubmitVote(originID flow.Identifier, blockID flow.Identifier, view uint64, sigData []byte)
- type CollectionMetrics
- type ComplianceMetrics
- type ConsensusMetrics
- func (_m *ConsensusMetrics) FinishBlockToSeal(blockID flow.Identifier)
- func (_m *ConsensusMetrics) FinishCollectionToFinalized(collectionID flow.Identifier)
- func (_m *ConsensusMetrics) StartBlockToSeal(blockID flow.Identifier)
- func (_m *ConsensusMetrics) StartCollectionToFinalized(collectionID flow.Identifier)
- type Engine
- func (_m *Engine) Done() <-chan struct{}
- func (_m *Engine) Process(originID flow.Identifier, event interface{}) error
- func (_m *Engine) ProcessLocal(event interface{}) error
- func (_m *Engine) Ready() <-chan struct{}
- func (_m *Engine) Submit(originID flow.Identifier, event interface{})
- func (_m *Engine) SubmitLocal(event interface{})
- type EngineMetrics
- type ExecutionMetrics
- func (_m *ExecutionMetrics) ChunkDataPackRequested()
- func (_m *ExecutionMetrics) DiskSize(_a0 uint64)
- func (_m *ExecutionMetrics) ExecutionCollectionRequestRetried()
- func (_m *ExecutionMetrics) ExecutionCollectionRequestSent()
- func (_m *ExecutionMetrics) ExecutionGasUsedPerBlock(gas uint64)
- func (_m *ExecutionMetrics) ExecutionLastExecutedBlockHeight(height uint64)
- func (_m *ExecutionMetrics) ExecutionStateReadsPerBlock(reads uint64)
- func (_m *ExecutionMetrics) ExecutionStorageStateCommitment(bytes int64)
- func (_m *ExecutionMetrics) ExecutionSync(syncing bool)
- func (_m *ExecutionMetrics) ExecutionTotalExecutedTransactions(numExecuted int)
- func (_m *ExecutionMetrics) FinishBlockReceivedToExecuted(blockID flow.Identifier)
- func (_m *ExecutionMetrics) ForestApproxMemorySize(bytes uint64)
- func (_m *ExecutionMetrics) ForestNumberOfTrees(number uint64)
- func (_m *ExecutionMetrics) LatestTrieMaxDepth(number uint64)
- func (_m *ExecutionMetrics) LatestTrieMaxDepthDiff(number uint64)
- func (_m *ExecutionMetrics) LatestTrieRegCount(number uint64)
- func (_m *ExecutionMetrics) LatestTrieRegCountDiff(number uint64)
- 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) StartBlockReceivedToExecuted(blockID flow.Identifier)
- func (_m *ExecutionMetrics) TransactionChecked(dur time.Duration)
- func (_m *ExecutionMetrics) TransactionInterpreted(dur time.Duration)
- func (_m *ExecutionMetrics) TransactionParsed(dur time.Duration)
- 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 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 LedgerMetrics
- func (_m *LedgerMetrics) DiskSize(_a0 uint64)
- func (_m *LedgerMetrics) ForestApproxMemorySize(bytes uint64)
- func (_m *LedgerMetrics) ForestNumberOfTrees(number uint64)
- func (_m *LedgerMetrics) LatestTrieMaxDepth(number uint64)
- func (_m *LedgerMetrics) LatestTrieMaxDepthDiff(number uint64)
- func (_m *LedgerMetrics) LatestTrieRegCount(number uint64)
- func (_m *LedgerMetrics) LatestTrieRegCountDiff(number uint64)
- 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 Network
- type NetworkMetrics
- func (_m *NetworkMetrics) MessageAdded(priority int)
- 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) QueueDuration(duration time.Duration, priority int)
- 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) PruneByHeight(height 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) PruneByHeight(height uint64)
- func (_m *PendingClusterBlockBuffer) Size() uint
- type PingMetrics
- type ProviderMetrics
- type QCContractClient
- type ReadyDoneAware
- type Requester
- type RuntimeMetrics
- type Signer
- type StateMetrics
- 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 Synchronization
- type ThresholdSigner
- func (_m *ThresholdSigner) Combine(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 ThresholdVerifier
- type Tracer
- func (_m *Tracer) Done() <-chan struct{}
- func (_m *Tracer) FinishSpan(entity flow.Identifier, spanName trace.SpanName)
- func (_m *Tracer) GetSpan(entity flow.Identifier, spanName trace.SpanName) (opentracing.Span, bool)
- func (_m *Tracer) Ready() <-chan struct{}
- func (_m *Tracer) StartSpan(entity flow.Identifier, spanName trace.SpanName, ...) opentracing.Span
- 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
- 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) TransactionSubmissionFailed()
- type TransactionValidator
- type VerificationMetrics
- func (_m *VerificationMetrics) LogVerifiableChunkSize(size float64)
- func (_m *VerificationMetrics) OnChunkDataPackReceived()
- func (_m *VerificationMetrics) OnChunkDataPackRequested()
- func (_m *VerificationMetrics) OnExecutionReceiptReceived()
- func (_m *VerificationMetrics) OnExecutionResultReceived()
- func (_m *VerificationMetrics) OnExecutionResultSent()
- func (_m *VerificationMetrics) OnResultApproval()
- func (_m *VerificationMetrics) OnVerifiableChunkReceived()
- func (_m *VerificationMetrics) OnVerifiableChunkSent()
- type Verifier
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 BadgerMetrics ¶
BadgerMetrics is an autogenerated mock type for the BadgerMetrics type
func (*BadgerMetrics) BadgerLSMSize ¶
func (_m *BadgerMetrics) BadgerLSMSize(sizeBytes int64)
BadgerLSMSize provides a mock function with given fields: sizeBytes
func (*BadgerMetrics) BadgerNumBlockedPuts ¶
func (_m *BadgerMetrics) BadgerNumBlockedPuts(n int64)
BadgerNumBlockedPuts provides a mock function with given fields: n
func (*BadgerMetrics) BadgerNumBytesRead ¶
func (_m *BadgerMetrics) BadgerNumBytesRead(n int64)
BadgerNumBytesRead provides a mock function with given fields: n
func (*BadgerMetrics) BadgerNumBytesWritten ¶
func (_m *BadgerMetrics) BadgerNumBytesWritten(n int64)
BadgerNumBytesWritten provides a mock function with given fields: n
func (*BadgerMetrics) BadgerNumGets ¶
func (_m *BadgerMetrics) BadgerNumGets(n int64)
BadgerNumGets provides a mock function with given fields: n
func (*BadgerMetrics) BadgerNumMemtableGets ¶
func (_m *BadgerMetrics) BadgerNumMemtableGets(n int64)
BadgerNumMemtableGets provides a mock function with given fields: n
func (*BadgerMetrics) BadgerNumPuts ¶
func (_m *BadgerMetrics) BadgerNumPuts(n int64)
BadgerNumPuts provides a mock function with given fields: n
func (*BadgerMetrics) BadgerNumReads ¶
func (_m *BadgerMetrics) BadgerNumReads(n int64)
BadgerNumReads provides a mock function with given fields: n
func (*BadgerMetrics) BadgerNumWrites ¶
func (_m *BadgerMetrics) BadgerNumWrites(n int64)
BadgerNumWrites provides a mock function with given fields: n
func (*BadgerMetrics) BadgerVLogSize ¶
func (_m *BadgerMetrics) BadgerVLogSize(sizeBytes int64)
BadgerVLogSize provides a mock function with given fields: sizeBytes
type BlockRequester ¶
BlockRequester is an autogenerated mock type for the BlockRequester type
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 CacheMetrics ¶
CacheMetrics is an autogenerated mock type for the CacheMetrics type
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
type ChunkAssigner ¶
ChunkAssigner is an autogenerated mock type for the ChunkAssigner type
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 (*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 (*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
type ColdStuff ¶
ColdStuff is an autogenerated mock type for the ColdStuff type
func (*ColdStuff) Done ¶
func (_m *ColdStuff) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*ColdStuff) Ready ¶
func (_m *ColdStuff) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*ColdStuff) SubmitCommit ¶
SubmitCommit provides a mock function with given fields: commit
func (*ColdStuff) SubmitProposal ¶
SubmitProposal provides a mock function with given fields: proposal, parentView
func (*ColdStuff) SubmitVote ¶
func (_m *ColdStuff) SubmitVote(originID flow.Identifier, blockID flow.Identifier, view uint64, sigData []byte)
SubmitVote provides a mock function with given fields: originID, blockID, view, sigData
type CollectionMetrics ¶
CollectionMetrics is an autogenerated mock type for the CollectionMetrics type
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 (*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) 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 (*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) 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 Engine ¶
Engine is an autogenerated mock type for the Engine type
func (*Engine) Done ¶
func (_m *Engine) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*Engine) Process ¶
func (_m *Engine) Process(originID flow.Identifier, event interface{}) error
Process provides a mock function with given fields: originID, event
func (*Engine) ProcessLocal ¶
ProcessLocal provides a mock function with given fields: event
func (*Engine) Ready ¶
func (_m *Engine) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*Engine) Submit ¶
func (_m *Engine) Submit(originID flow.Identifier, event interface{})
Submit provides a mock function with given fields: originID, event
func (*Engine) SubmitLocal ¶
func (_m *Engine) SubmitLocal(event interface{})
SubmitLocal provides a mock function with given fields: event
type EngineMetrics ¶
EngineMetrics is an autogenerated mock type for the EngineMetrics type
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 ExecutionMetrics ¶
ExecutionMetrics is an autogenerated mock type for the ExecutionMetrics type
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) 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) ExecutionGasUsedPerBlock ¶
func (_m *ExecutionMetrics) ExecutionGasUsedPerBlock(gas uint64)
ExecutionGasUsedPerBlock provides a mock function with given fields: gas
func (*ExecutionMetrics) ExecutionLastExecutedBlockHeight ¶
func (_m *ExecutionMetrics) ExecutionLastExecutedBlockHeight(height uint64)
ExecutionLastExecutedBlockHeight provides a mock function with given fields: height
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) ExecutionTotalExecutedTransactions ¶
func (_m *ExecutionMetrics) ExecutionTotalExecutedTransactions(numExecuted int)
ExecutionTotalExecutedTransactions provides a mock function with given fields: numExecuted
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) LatestTrieMaxDepth ¶
func (_m *ExecutionMetrics) LatestTrieMaxDepth(number uint64)
LatestTrieMaxDepth provides a mock function with given fields: number
func (*ExecutionMetrics) LatestTrieMaxDepthDiff ¶
func (_m *ExecutionMetrics) LatestTrieMaxDepthDiff(number uint64)
LatestTrieMaxDepthDiff provides a mock function with given fields: number
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 uint64)
LatestTrieRegCountDiff provides a mock function with given fields: number
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) StartBlockReceivedToExecuted ¶
func (_m *ExecutionMetrics) StartBlockReceivedToExecuted(blockID flow.Identifier)
StartBlockReceivedToExecuted provides a mock function with given fields: blockID
func (*ExecutionMetrics) TransactionChecked ¶
func (_m *ExecutionMetrics) TransactionChecked(dur time.Duration)
TransactionChecked provides a mock function with given fields: dur
func (*ExecutionMetrics) TransactionInterpreted ¶
func (_m *ExecutionMetrics) TransactionInterpreted(dur time.Duration)
TransactionInterpreted provides a mock function with given fields: dur
func (*ExecutionMetrics) TransactionParsed ¶
func (_m *ExecutionMetrics) TransactionParsed(dur time.Duration)
TransactionParsed provides a mock function with given fields: dur
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
type HotStuff ¶
HotStuff is an autogenerated mock type for the HotStuff type
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) SubmitProposal ¶
SubmitProposal provides a mock function with given fields: proposal, parentView
func (*HotStuff) SubmitVote ¶
func (_m *HotStuff) SubmitVote(originID flow.Identifier, blockID flow.Identifier, view uint64, sigData []byte)
SubmitVote provides a mock function with given fields: originID, blockID, view, sigData
type HotStuffFollower ¶
HotStuffFollower is an autogenerated mock type for the HotStuffFollower type
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 (*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 LedgerMetrics ¶
LedgerMetrics is an autogenerated mock type for the LedgerMetrics type
func (*LedgerMetrics) DiskSize ¶ added in v0.10.0
func (_m *LedgerMetrics) DiskSize(_a0 uint64)
DiskSize provides a mock function with given fields: _a0
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) LatestTrieMaxDepth ¶
func (_m *LedgerMetrics) LatestTrieMaxDepth(number uint64)
LatestTrieMaxDepth provides a mock function with given fields: number
func (*LedgerMetrics) LatestTrieMaxDepthDiff ¶
func (_m *LedgerMetrics) LatestTrieMaxDepthDiff(number uint64)
LatestTrieMaxDepthDiff provides a mock function with given fields: number
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 uint64)
LatestTrieRegCountDiff provides a mock function with given fields: number
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 (*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 (*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 metrics.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 (*NetworkMetrics) MessageAdded ¶
func (_m *NetworkMetrics) MessageAdded(priority int)
MessageAdded provides a mock function with given fields: priority
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) QueueDuration ¶
func (_m *NetworkMetrics) QueueDuration(duration time.Duration, priority int)
QueueDuration provides a mock function with given fields: duration, priority
type PendingBlockBuffer ¶
PendingBlockBuffer is an autogenerated mock type for the PendingBlockBuffer type
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) PruneByHeight ¶
func (_m *PendingBlockBuffer) PruneByHeight(height uint64)
PruneByHeight provides a mock function with given fields: height
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 (*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) PruneByHeight ¶
func (_m *PendingClusterBlockBuffer) PruneByHeight(height uint64)
PruneByHeight provides a mock function with given fields: height
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 (*PingMetrics) NodeReachable ¶
func (_m *PingMetrics) NodeReachable(node *flow.Identity, reachable bool)
NodeReachable provides a mock function with given fields: node, reachable
type ProviderMetrics ¶
ProviderMetrics is an autogenerated mock type for the ProviderMetrics type
func (*ProviderMetrics) ChunkDataPackRequested ¶
func (_m *ProviderMetrics) ChunkDataPackRequested()
ChunkDataPackRequested provides a mock function with given fields:
type QCContractClient ¶
QCContractClient is an autogenerated mock type for the QCContractClient type
func (*QCContractClient) SubmitVote ¶
SubmitVote provides a mock function with given fields: ctx, vote
type ReadyDoneAware ¶
ReadyDoneAware is an autogenerated mock type for the ReadyDoneAware type
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 Requester ¶
Requester is an autogenerated mock type for the Requester type
func (*Requester) EntityByID ¶
func (_m *Requester) EntityByID(entityID flow.Identifier, selector flow.IdentityFilter)
EntityByID provides a mock function with given fields: entityID, selector
type RuntimeMetrics ¶
RuntimeMetrics is an autogenerated mock type for the RuntimeMetrics type
func (*RuntimeMetrics) TransactionChecked ¶
func (_m *RuntimeMetrics) TransactionChecked(dur time.Duration)
TransactionChecked provides a mock function with given fields: dur
func (*RuntimeMetrics) TransactionInterpreted ¶
func (_m *RuntimeMetrics) TransactionInterpreted(dur time.Duration)
TransactionInterpreted provides a mock function with given fields: dur
func (*RuntimeMetrics) TransactionParsed ¶
func (_m *RuntimeMetrics) TransactionParsed(dur time.Duration)
TransactionParsed provides a mock function with given fields: dur
type Signer ¶
Signer is an autogenerated mock type for the Signer type
type StateMetrics ¶
StateMetrics is an autogenerated mock type for the StateMetrics type
func (*StateMetrics) BlockFinalized ¶
func (_m *StateMetrics) BlockFinalized(_a0 *flow.Block)
BlockFinalized provides a mock function with given fields: _a0
func (*StateMetrics) BlockProposed ¶
func (_m *StateMetrics) BlockProposed(_a0 *flow.Block)
BlockProposed provides a mock function with given fields: _a0
func (*StateMetrics) BlockSealed ¶
func (_m *StateMetrics) BlockSealed(_a0 *flow.Block)
BlockSealed provides a mock function with given fields: _a0
type SyncCore ¶
SyncCore is an autogenerated mock type for the SyncCore type
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 Synchronization ¶
Synchronization is an autogenerated mock type for the Synchronization type
func (*Synchronization) Done ¶
func (_m *Synchronization) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*Synchronization) Ready ¶
func (_m *Synchronization) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*Synchronization) RequestBlock ¶
func (_m *Synchronization) RequestBlock(blockID flow.Identifier)
RequestBlock provides a mock function with given fields: blockID
type ThresholdSigner ¶
ThresholdSigner is an autogenerated mock type for the ThresholdSigner type
func (*ThresholdSigner) Combine ¶
func (_m *ThresholdSigner) Combine(size uint, shares []crypto.Signature, indices []uint) (crypto.Signature, error)
Combine 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 ThresholdVerifier ¶
ThresholdVerifier is an autogenerated mock type for the ThresholdVerifier type
func (*ThresholdVerifier) Verify ¶
func (_m *ThresholdVerifier) Verify(msg []byte, sig crypto.Signature, key crypto.PublicKey) (bool, error)
Verify provides a mock function with given fields: msg, sig, key
func (*ThresholdVerifier) VerifyThreshold ¶
func (_m *ThresholdVerifier) 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 (*Tracer) Done ¶
func (_m *Tracer) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*Tracer) FinishSpan ¶
func (_m *Tracer) FinishSpan(entity flow.Identifier, spanName trace.SpanName)
FinishSpan provides a mock function with given fields: entity, spanName
func (*Tracer) GetSpan ¶
func (_m *Tracer) GetSpan(entity flow.Identifier, spanName trace.SpanName) (opentracing.Span, bool)
GetSpan provides a mock function with given fields: entity, spanName
func (*Tracer) Ready ¶
func (_m *Tracer) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*Tracer) StartSpan ¶
func (_m *Tracer) StartSpan(entity flow.Identifier, spanName trace.SpanName, opts ...opentracing.StartSpanOption) opentracing.Span
StartSpan provides a mock function with given fields: entity, 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
type TransactionMetrics ¶
TransactionMetrics is an autogenerated mock type for the TransactionMetrics type
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) TransactionSubmissionFailed ¶
func (_m *TransactionMetrics) TransactionSubmissionFailed()
TransactionSubmissionFailed provides a mock function with given fields:
type TransactionValidator ¶
TransactionValidator is an autogenerated mock type for the TransactionValidator type
func (*TransactionValidator) ValidateTransaction ¶
func (_m *TransactionValidator) ValidateTransaction(tx *flow.TransactionBody) error
ValidateTransaction provides a mock function with given fields: tx
type VerificationMetrics ¶
VerificationMetrics is an autogenerated mock type for the VerificationMetrics type
func (*VerificationMetrics) LogVerifiableChunkSize ¶
func (_m *VerificationMetrics) LogVerifiableChunkSize(size float64)
LogVerifiableChunkSize provides a mock function with given fields: size
func (*VerificationMetrics) OnChunkDataPackReceived ¶
func (_m *VerificationMetrics) OnChunkDataPackReceived()
OnChunkDataPackReceived provides a mock function with given fields:
func (*VerificationMetrics) OnChunkDataPackRequested ¶
func (_m *VerificationMetrics) OnChunkDataPackRequested()
OnChunkDataPackRequested provides a mock function with given fields:
func (*VerificationMetrics) OnExecutionReceiptReceived ¶
func (_m *VerificationMetrics) OnExecutionReceiptReceived()
OnExecutionReceiptReceived provides a mock function with given fields:
func (*VerificationMetrics) OnExecutionResultReceived ¶
func (_m *VerificationMetrics) OnExecutionResultReceived()
OnExecutionResultReceived provides a mock function with given fields:
func (*VerificationMetrics) OnExecutionResultSent ¶
func (_m *VerificationMetrics) OnExecutionResultSent()
OnExecutionResultSent provides a mock function with given fields:
func (*VerificationMetrics) OnResultApproval ¶
func (_m *VerificationMetrics) OnResultApproval()
OnResultApproval provides a mock function with given fields:
func (*VerificationMetrics) OnVerifiableChunkReceived ¶
func (_m *VerificationMetrics) OnVerifiableChunkReceived()
OnVerifiableChunkReceived provides a mock function with given fields:
func (*VerificationMetrics) OnVerifiableChunkSent ¶
func (_m *VerificationMetrics) OnVerifiableChunkSent()
OnVerifiableChunkSent provides a mock function with given fields:
Source Files ¶
- aggregating_signer.go
- aggregating_verifier.go
- badger_metrics.go
- block_requester.go
- builder.go
- cache_metrics.go
- chunk_assigner.go
- chunk_verifier.go
- cleaner_metrics.go
- cluster_root_qc_voter.go
- cold_stuff.go
- collection_metrics.go
- compliance_metrics.go
- consensus_metrics.go
- engine.go
- engine_metrics.go
- execution_metrics.go
- finalizer.go
- hot_stuff.go
- hot_stuff_follower.go
- hotstuff_metrics.go
- ledger_metrics.go
- local.go
- mempool_metrics.go
- merger.go
- network.go
- network_metrics.go
- pending_block_buffer.go
- pending_cluster_block_buffer.go
- ping_metrics.go
- provider_metrics.go
- qc_contract_client.go
- ready_done_aware.go
- requester.go
- runtime_metrics.go
- signer.go
- state_metrics.go
- sync_core.go
- synchronization.go
- threshold_signer.go
- threshold_verifier.go
- tracer.go
- transaction_metrics.go
- transaction_validator.go
- verification_metrics.go
- verifier.go