Documentation ¶
Index ¶
- type AdjustFunction
- type BasicGossipSubRPCInspector
- type BasicRateLimiter
- type CollectionClusterChangesConsumer
- type ConnectionGater
- func (_m *ConnectionGater) InterceptAccept(_a0 network.ConnMultiaddrs) bool
- func (_m *ConnectionGater) InterceptAddrDial(_a0 peer.ID, _a1 multiaddr.Multiaddr) bool
- func (_m *ConnectionGater) InterceptPeerDial(p peer.ID) bool
- func (_m *ConnectionGater) InterceptSecured(_a0 network.Direction, _a1 peer.ID, _a2 network.ConnMultiaddrs) bool
- func (_m *ConnectionGater) InterceptUpgraded(_a0 network.Conn) (bool, control.DisconnectReason)
- func (_m *ConnectionGater) SetDisallowListOracle(oracle p2p.DisallowListOracle)
- type Connector
- type ConnectorFactory
- type ConnectorHost
- func (_m *ConnectorHost) ClosePeer(peerId peer.ID) error
- func (_m *ConnectorHost) Connections() []network.Conn
- func (_m *ConnectorHost) ID() peer.ID
- func (_m *ConnectorHost) IsConnectedTo(peerId peer.ID) bool
- func (_m *ConnectorHost) IsProtected(peerId peer.ID) bool
- func (_m *ConnectorHost) PeerInfo(peerId peer.ID) peer.AddrInfo
- type CoreP2P
- type CreateNodeFunc
- type DisallowListCache
- func (_m *DisallowListCache) AllowFor(peerID peer.ID, cause network.DisallowListedCause) []network.DisallowListedCause
- func (_m *DisallowListCache) DisallowFor(peerID peer.ID, cause network.DisallowListedCause) ([]network.DisallowListedCause, error)
- func (_m *DisallowListCache) IsDisallowListed(peerID peer.ID) ([]network.DisallowListedCause, bool)
- type DisallowListNotificationConsumer
- type DisallowListOracle
- type GetTimeNow
- type GossipSubAdapterConfigFunc
- type GossipSubAppSpecificRpcInspector
- type GossipSubApplicationSpecificScoreCache
- type GossipSubBuilder
- func (_m *GossipSubBuilder) Build(_a0 irrecoverable.SignalerContext) (p2p.PubSubAdapter, error)
- func (_m *GossipSubBuilder) EnableGossipSubScoringWithOverride(_a0 *p2p.PeerScoringConfigOverride)
- func (_m *GossipSubBuilder) OverrideDefaultRpcInspectorFactory(_a0 p2p.GossipSubRpcInspectorFactoryFunc)
- func (_m *GossipSubBuilder) SetGossipSubConfigFunc(_a0 p2p.GossipSubAdapterConfigFunc)
- func (_m *GossipSubBuilder) SetGossipSubFactory(_a0 p2p.GossipSubFactoryFunc)
- func (_m *GossipSubBuilder) SetHost(_a0 host.Host)
- func (_m *GossipSubBuilder) SetRoutingSystem(_a0 routing.Routing)
- func (_m *GossipSubBuilder) SetSubscriptionFilter(_a0 pubsub.SubscriptionFilter)
- type GossipSubDuplicateMessageTrackerCache
- type GossipSubFactoryFunc
- type GossipSubInvCtrlMsgNotifConsumer
- type GossipSubInvalidControlMessageNotificationConsumer
- type GossipSubRPCInspector
- func (_m *GossipSubRPCInspector) ActiveClustersChanged(_a0 flow.ChainIDList)
- func (_m *GossipSubRPCInspector) Done() <-chan struct{}
- func (_m *GossipSubRPCInspector) Inspect(_a0 peer.ID, _a1 *pubsub.RPC) error
- func (_m *GossipSubRPCInspector) Name() string
- func (_m *GossipSubRPCInspector) Ready() <-chan struct{}
- func (_m *GossipSubRPCInspector) Start(_a0 irrecoverable.SignalerContext)
- type GossipSubRpcInspectorFactoryFunc
- type GossipSubSpamRecordCache
- type IDTranslator
- type InspectorTopicOracle
- type LibP2PNode
- func (_m *LibP2PNode) ActiveClustersChanged(_a0 flow.ChainIDList)
- func (_m *LibP2PNode) ConnectToPeer(ctx context.Context, peerInfo peer.AddrInfo) error
- func (_m *LibP2PNode) Done() <-chan struct{}
- func (_m *LibP2PNode) GetIPPort() (string, string, error)
- func (_m *LibP2PNode) GetLocalMeshPeers(topic channels.Topic) []peer.ID
- func (_m *LibP2PNode) GetPeersForProtocol(pid protocol.ID) peer.IDSlice
- func (_m *LibP2PNode) HasSubscription(topic channels.Topic) bool
- func (_m *LibP2PNode) Host() host.Host
- func (_m *LibP2PNode) ID() peer.ID
- func (_m *LibP2PNode) IsConnected(peerID peer.ID) (bool, error)
- func (_m *LibP2PNode) IsDisallowListed(peerId peer.ID) ([]network.DisallowListedCause, bool)
- func (_m *LibP2PNode) ListPeers(topic string) []peer.ID
- func (_m *LibP2PNode) OnAllowListNotification(id peer.ID, cause network.DisallowListedCause)
- func (_m *LibP2PNode) OnDisallowListNotification(id peer.ID, cause network.DisallowListedCause)
- func (_m *LibP2PNode) OpenAndWriteOnStream(ctx context.Context, peerID peer.ID, protectionTag string, ...) error
- func (_m *LibP2PNode) PeerManagerComponent() component.Component
- func (_m *LibP2PNode) PeerScoreExposer() p2p.PeerScoreExposer
- func (_m *LibP2PNode) Publish(ctx context.Context, messageScope network.OutgoingMessageScope) error
- func (_m *LibP2PNode) Ready() <-chan struct{}
- func (_m *LibP2PNode) RemovePeer(peerID peer.ID) error
- func (_m *LibP2PNode) RequestPeerUpdate()
- func (_m *LibP2PNode) Routing() routing.Routing
- func (_m *LibP2PNode) RoutingTable() *kbucket.RoutingTable
- func (_m *LibP2PNode) SetComponentManager(cm *component.ComponentManager)
- func (_m *LibP2PNode) SetPubSub(ps p2p.PubSubAdapter)
- func (_m *LibP2PNode) SetRouting(r routing.Routing) error
- func (_m *LibP2PNode) SetUnicastManager(uniMgr p2p.UnicastManager)
- func (_m *LibP2PNode) Start(ctx irrecoverable.SignalerContext)
- func (_m *LibP2PNode) Stop() error
- func (_m *LibP2PNode) Subscribe(topic channels.Topic, topicValidator p2p.TopicValidatorFunc) (p2p.Subscription, error)
- func (_m *LibP2PNode) Unsubscribe(topic channels.Topic) error
- func (_m *LibP2PNode) WithDefaultUnicastProtocol(defaultHandler corenetwork.StreamHandler, preferred []protocols.ProtocolName) error
- func (_m *LibP2PNode) WithPeersProvider(peersProvider p2p.PeersProvider)
- type NetworkConfigOption
- type NetworkOptFunction
- type NetworkOption
- type NetworkParamOption
- type NodeBlockListConsumer
- type NodeBuilder
- func (_m *NodeBuilder) Build() (p2p.LibP2PNode, error)
- func (_m *NodeBuilder) OverrideDefaultRpcInspectorFactory(_a0 p2p.GossipSubRpcInspectorFactoryFunc) p2p.NodeBuilder
- func (_m *NodeBuilder) OverrideGossipSubFactory(_a0 p2p.GossipSubFactoryFunc, _a1 p2p.GossipSubAdapterConfigFunc) p2p.NodeBuilder
- func (_m *NodeBuilder) OverrideGossipSubScoringConfig(_a0 *p2p.PeerScoringConfigOverride) p2p.NodeBuilder
- func (_m *NodeBuilder) OverrideNodeConstructor(_a0 p2p.NodeConstructor) p2p.NodeBuilder
- func (_m *NodeBuilder) SetBasicResolver(_a0 madns.BasicResolver) p2p.NodeBuilder
- func (_m *NodeBuilder) SetConnectionGater(_a0 p2p.ConnectionGater) p2p.NodeBuilder
- func (_m *NodeBuilder) SetConnectionManager(_a0 connmgr.ConnManager) p2p.NodeBuilder
- func (_m *NodeBuilder) SetResourceManager(_a0 network.ResourceManager) p2p.NodeBuilder
- func (_m *NodeBuilder) SetRoutingSystem(_a0 func(context.Context, host.Host) (routing.Routing, error)) p2p.NodeBuilder
- func (_m *NodeBuilder) SetSubscriptionFilter(_a0 pubsub.SubscriptionFilter) p2p.NodeBuilder
- type NodeConstructor
- type PeerConnections
- type PeerFilter
- type PeerManagement
- func (_m *PeerManagement) ConnectToPeer(ctx context.Context, peerInfo peer.AddrInfo) error
- func (_m *PeerManagement) GetIPPort() (string, string, error)
- func (_m *PeerManagement) GetPeersForProtocol(pid protocol.ID) peer.IDSlice
- func (_m *PeerManagement) Host() host.Host
- func (_m *PeerManagement) ID() peer.ID
- func (_m *PeerManagement) ListPeers(topic string) []peer.ID
- func (_m *PeerManagement) PeerManagerComponent() component.Component
- func (_m *PeerManagement) Publish(ctx context.Context, messageScope network.OutgoingMessageScope) error
- func (_m *PeerManagement) RemovePeer(peerID peer.ID) error
- func (_m *PeerManagement) RequestPeerUpdate()
- func (_m *PeerManagement) RoutingTable() *kbucket.RoutingTable
- func (_m *PeerManagement) Subscribe(topic channels.Topic, topicValidator p2p.TopicValidatorFunc) (p2p.Subscription, error)
- func (_m *PeerManagement) Unsubscribe(topic channels.Topic) error
- func (_m *PeerManagement) WithDefaultUnicastProtocol(defaultHandler corenetwork.StreamHandler, preferred []protocols.ProtocolName) error
- func (_m *PeerManagement) WithPeersProvider(peersProvider p2p.PeersProvider)
- type PeerManager
- func (_m *PeerManager) Done() <-chan struct{}
- func (_m *PeerManager) ForceUpdatePeers(_a0 context.Context)
- func (_m *PeerManager) OnRateLimitedPeer(pid peer.ID, role string, msgType string, topic string, reason string)
- func (_m *PeerManager) Ready() <-chan struct{}
- func (_m *PeerManager) RequestPeerUpdate()
- func (_m *PeerManager) SetPeersProvider(_a0 p2p.PeersProvider)
- func (_m *PeerManager) Start(_a0 irrecoverable.SignalerContext)
- type PeerManagerFactoryFunc
- type PeerScore
- type PeerScoreExposer
- func (_m *PeerScoreExposer) GetAppScore(peerID peer.ID) (float64, bool)
- func (_m *PeerScoreExposer) GetBehaviourPenalty(peerID peer.ID) (float64, bool)
- func (_m *PeerScoreExposer) GetIPColocationFactor(peerID peer.ID) (float64, bool)
- func (_m *PeerScoreExposer) GetScore(peerID peer.ID) (float64, bool)
- func (_m *PeerScoreExposer) GetTopicScores(peerID peer.ID) (map[string]p2p.TopicScoreSnapshot, bool)
- type PeerScoreTracer
- func (_m *PeerScoreTracer) Done() <-chan struct{}
- func (_m *PeerScoreTracer) GetAppScore(peerID peer.ID) (float64, bool)
- func (_m *PeerScoreTracer) GetBehaviourPenalty(peerID peer.ID) (float64, bool)
- func (_m *PeerScoreTracer) GetIPColocationFactor(peerID peer.ID) (float64, bool)
- func (_m *PeerScoreTracer) GetScore(peerID peer.ID) (float64, bool)
- func (_m *PeerScoreTracer) GetTopicScores(peerID peer.ID) (map[string]p2p.TopicScoreSnapshot, bool)
- func (_m *PeerScoreTracer) Ready() <-chan struct{}
- func (_m *PeerScoreTracer) Start(_a0 irrecoverable.SignalerContext)
- func (_m *PeerScoreTracer) UpdateInterval() time.Duration
- func (_m *PeerScoreTracer) UpdatePeerScoreSnapshots(_a0 map[peer.ID]*p2p.PeerScoreSnapshot)
- type PeerScoringBuilder
- type PeerUpdater
- type PeersProvider
- type ProtocolPeerCache
- func (_m *ProtocolPeerCache) AddProtocols(peerID peer.ID, protocols []protocol.ID)
- func (_m *ProtocolPeerCache) GetPeers(pid protocol.ID) map[peer.ID]struct{}
- func (_m *ProtocolPeerCache) RemovePeer(peerID peer.ID)
- func (_m *ProtocolPeerCache) RemoveProtocols(peerID peer.ID, protocols []protocol.ID)
- type PubSub
- func (_m *PubSub) GetLocalMeshPeers(topic channels.Topic) []peer.ID
- func (_m *PubSub) Publish(ctx context.Context, messageScope network.OutgoingMessageScope) error
- func (_m *PubSub) SetPubSub(ps p2p.PubSubAdapter)
- func (_m *PubSub) Subscribe(topic channels.Topic, topicValidator p2p.TopicValidatorFunc) (p2p.Subscription, error)
- func (_m *PubSub) Unsubscribe(topic channels.Topic) error
- type PubSubAdapter
- func (_m *PubSubAdapter) ActiveClustersChanged(_a0 flow.ChainIDList)
- func (_m *PubSubAdapter) Done() <-chan struct{}
- func (_m *PubSubAdapter) GetLocalMeshPeers(topic channels.Topic) []peer.ID
- func (_m *PubSubAdapter) GetTopics() []string
- func (_m *PubSubAdapter) Join(topic string) (p2p.Topic, error)
- func (_m *PubSubAdapter) ListPeers(topic string) []peer.ID
- func (_m *PubSubAdapter) PeerScoreExposer() p2p.PeerScoreExposer
- func (_m *PubSubAdapter) Ready() <-chan struct{}
- func (_m *PubSubAdapter) RegisterTopicValidator(topic string, topicValidator p2p.TopicValidatorFunc) error
- func (_m *PubSubAdapter) Start(_a0 irrecoverable.SignalerContext)
- func (_m *PubSubAdapter) UnregisterTopicValidator(topic string) error
- type PubSubAdapterConfig
- func (_m *PubSubAdapterConfig) WithMessageIdFunction(f func([]byte) string)
- func (_m *PubSubAdapterConfig) WithRoutingDiscovery(_a0 routing.ContentRouting)
- func (_m *PubSubAdapterConfig) WithRpcInspector(_a0 p2p.GossipSubRPCInspector)
- func (_m *PubSubAdapterConfig) WithScoreOption(_a0 p2p.ScoreOptionBuilder)
- func (_m *PubSubAdapterConfig) WithScoreTracer(tracer p2p.PeerScoreTracer)
- func (_m *PubSubAdapterConfig) WithSubscriptionFilter(_a0 p2p.SubscriptionFilter)
- func (_m *PubSubAdapterConfig) WithTracer(t p2p.PubSubTracer)
- type PubSubTracer
- func (_m *PubSubTracer) AddPeer(p peer.ID, proto protocol.ID)
- func (_m *PubSubTracer) DeliverMessage(msg *pubsub.Message)
- func (_m *PubSubTracer) Done() <-chan struct{}
- func (_m *PubSubTracer) DropRPC(rpc *pubsub.RPC, p peer.ID)
- func (_m *PubSubTracer) DuplicateMessage(msg *pubsub.Message)
- func (_m *PubSubTracer) DuplicateMessageCount(_a0 peer.ID) float64
- func (_m *PubSubTracer) GetLocalMeshPeers(topic channels.Topic) []peer.ID
- func (_m *PubSubTracer) Graft(p peer.ID, topic string)
- func (_m *PubSubTracer) Join(topic string)
- func (_m *PubSubTracer) LastHighestIHaveRPCSize() int64
- func (_m *PubSubTracer) Leave(topic string)
- func (_m *PubSubTracer) Prune(p peer.ID, topic string)
- func (_m *PubSubTracer) Ready() <-chan struct{}
- func (_m *PubSubTracer) RecvRPC(rpc *pubsub.RPC)
- func (_m *PubSubTracer) RejectMessage(msg *pubsub.Message, reason string)
- func (_m *PubSubTracer) RemovePeer(p peer.ID)
- func (_m *PubSubTracer) SendRPC(rpc *pubsub.RPC, p peer.ID)
- func (_m *PubSubTracer) Start(_a0 irrecoverable.SignalerContext)
- func (_m *PubSubTracer) ThrottlePeer(p peer.ID)
- func (_m *PubSubTracer) UndeliverableMessage(msg *pubsub.Message)
- func (_m *PubSubTracer) ValidateMessage(msg *pubsub.Message)
- func (_m *PubSubTracer) WasIHaveRPCSent(messageID string) bool
- type RateLimiter
- type RateLimiterConsumer
- type RateLimiterOpt
- type Routable
- type RpcControlTracking
- type ScoreOption
- type ScoreOptionBuilder
- func (_m *ScoreOptionBuilder) BuildFlowPubSubScoreOption() (*pubsub.PeerScoreParams, *pubsub.PeerScoreThresholds)
- func (_m *ScoreOptionBuilder) Done() <-chan struct{}
- func (_m *ScoreOptionBuilder) Ready() <-chan struct{}
- func (_m *ScoreOptionBuilder) Start(_a0 irrecoverable.SignalerContext)
- func (_m *ScoreOptionBuilder) TopicScoreParams(_a0 *pubsub.Topic) *pubsub.TopicScoreParams
- type StreamFactory
- type Subscription
- type SubscriptionFilter
- type SubscriptionProvider
- type SubscriptionValidator
- type Subscriptions
- type Topic
- type TopicProvider
- type TopicValidatorFunc
- type UnicastManagement
- type UnicastManager
- type UnicastManagerFactoryFunc
- type UnicastRateLimiterDistributor
- type UpdateFunction
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
This section is empty.
Types ¶
type AdjustFunction ¶ added in v0.31.0
AdjustFunction is an autogenerated mock type for the AdjustFunction type
func NewAdjustFunction ¶ added in v0.31.0
func NewAdjustFunction(t mockConstructorTestingTNewAdjustFunction) *AdjustFunction
NewAdjustFunction creates a new instance of AdjustFunction. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*AdjustFunction) Execute ¶ added in v0.31.0
func (_m *AdjustFunction) Execute(record p2p.GossipSubSpamRecord) p2p.GossipSubSpamRecord
Execute provides a mock function with given fields: record
type BasicGossipSubRPCInspector ¶ added in v0.30.0
BasicGossipSubRPCInspector is an autogenerated mock type for the BasicGossipSubRPCInspector type
func NewBasicGossipSubRPCInspector ¶ added in v0.30.0
func NewBasicGossipSubRPCInspector(t mockConstructorTestingTNewBasicGossipSubRPCInspector) *BasicGossipSubRPCInspector
NewBasicGossipSubRPCInspector creates a new instance of BasicGossipSubRPCInspector. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
type BasicRateLimiter ¶ added in v0.30.0
BasicRateLimiter is an autogenerated mock type for the BasicRateLimiter type
func NewBasicRateLimiter ¶ added in v0.30.0
func NewBasicRateLimiter(t interface { mock.TestingT Cleanup(func()) }) *BasicRateLimiter
NewBasicRateLimiter creates a new instance of BasicRateLimiter. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*BasicRateLimiter) Allow ¶ added in v0.30.0
func (_m *BasicRateLimiter) Allow(peerID peer.ID, msgSize int) bool
Allow provides a mock function with given fields: peerID, msgSize
func (*BasicRateLimiter) Done ¶ added in v0.30.0
func (_m *BasicRateLimiter) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*BasicRateLimiter) Ready ¶ added in v0.30.0
func (_m *BasicRateLimiter) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*BasicRateLimiter) Start ¶ added in v0.30.0
func (_m *BasicRateLimiter) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
type CollectionClusterChangesConsumer ¶ added in v0.32.0
CollectionClusterChangesConsumer is an autogenerated mock type for the CollectionClusterChangesConsumer type
func NewCollectionClusterChangesConsumer ¶ added in v0.32.0
func NewCollectionClusterChangesConsumer(t interface { mock.TestingT Cleanup(func()) }) *CollectionClusterChangesConsumer
NewCollectionClusterChangesConsumer creates a new instance of CollectionClusterChangesConsumer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*CollectionClusterChangesConsumer) ActiveClustersChanged ¶ added in v0.32.0
func (_m *CollectionClusterChangesConsumer) ActiveClustersChanged(_a0 flow.ChainIDList)
ActiveClustersChanged provides a mock function with given fields: _a0
type ConnectionGater ¶ added in v0.29.0
ConnectionGater is an autogenerated mock type for the ConnectionGater type
func NewConnectionGater ¶ added in v0.29.0
func NewConnectionGater(t interface { mock.TestingT Cleanup(func()) }) *ConnectionGater
NewConnectionGater creates a new instance of ConnectionGater. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ConnectionGater) InterceptAccept ¶ added in v0.29.0
func (_m *ConnectionGater) InterceptAccept(_a0 network.ConnMultiaddrs) bool
InterceptAccept provides a mock function with given fields: _a0
func (*ConnectionGater) InterceptAddrDial ¶ added in v0.29.0
InterceptAddrDial provides a mock function with given fields: _a0, _a1
func (*ConnectionGater) InterceptPeerDial ¶ added in v0.29.0
func (_m *ConnectionGater) InterceptPeerDial(p peer.ID) bool
InterceptPeerDial provides a mock function with given fields: p
func (*ConnectionGater) InterceptSecured ¶ added in v0.29.0
func (_m *ConnectionGater) InterceptSecured(_a0 network.Direction, _a1 peer.ID, _a2 network.ConnMultiaddrs) bool
InterceptSecured provides a mock function with given fields: _a0, _a1, _a2
func (*ConnectionGater) InterceptUpgraded ¶ added in v0.29.0
func (_m *ConnectionGater) InterceptUpgraded(_a0 network.Conn) (bool, control.DisconnectReason)
InterceptUpgraded provides a mock function with given fields: _a0
func (*ConnectionGater) SetDisallowListOracle ¶ added in v0.32.0
func (_m *ConnectionGater) SetDisallowListOracle(oracle p2p.DisallowListOracle)
SetDisallowListOracle provides a mock function with given fields: oracle
type Connector ¶
Connector is an autogenerated mock type for the Connector type
func NewConnector ¶
NewConnector creates a new instance of Connector. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
type ConnectorFactory ¶ added in v0.32.0
ConnectorFactory is an autogenerated mock type for the ConnectorFactory type
func NewConnectorFactory ¶ added in v0.32.0
func NewConnectorFactory(t interface { mock.TestingT Cleanup(func()) }) *ConnectorFactory
NewConnectorFactory creates a new instance of ConnectorFactory. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
type ConnectorHost ¶ added in v0.31.0
ConnectorHost is an autogenerated mock type for the ConnectorHost type
func NewConnectorHost ¶ added in v0.31.0
func NewConnectorHost(t interface { mock.TestingT Cleanup(func()) }) *ConnectorHost
NewConnectorHost creates a new instance of ConnectorHost. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ConnectorHost) ClosePeer ¶ added in v0.31.0
func (_m *ConnectorHost) ClosePeer(peerId peer.ID) error
ClosePeer provides a mock function with given fields: peerId
func (*ConnectorHost) Connections ¶ added in v0.31.0
func (_m *ConnectorHost) Connections() []network.Conn
Connections provides a mock function with given fields:
func (*ConnectorHost) ID ¶ added in v0.31.0
func (_m *ConnectorHost) ID() peer.ID
ID provides a mock function with given fields:
func (*ConnectorHost) IsConnectedTo ¶ added in v0.32.0
func (_m *ConnectorHost) IsConnectedTo(peerId peer.ID) bool
IsConnectedTo provides a mock function with given fields: peerId
func (*ConnectorHost) IsProtected ¶ added in v0.31.0
func (_m *ConnectorHost) IsProtected(peerId peer.ID) bool
IsProtected provides a mock function with given fields: peerId
type CoreP2P ¶ added in v0.32.0
CoreP2P is an autogenerated mock type for the CoreP2P type
func NewCoreP2P ¶ added in v0.32.0
NewCoreP2P creates a new instance of CoreP2P. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*CoreP2P) SetComponentManager ¶ added in v0.32.0
func (_m *CoreP2P) SetComponentManager(cm *component.ComponentManager)
SetComponentManager provides a mock function with given fields: cm
func (*CoreP2P) Start ¶ added in v0.32.0
func (_m *CoreP2P) Start(ctx irrecoverable.SignalerContext)
Start provides a mock function with given fields: ctx
type CreateNodeFunc ¶ added in v0.30.0
CreateNodeFunc is an autogenerated mock type for the CreateNodeFunc type
func NewCreateNodeFunc ¶ added in v0.30.0
func NewCreateNodeFunc(t mockConstructorTestingTNewCreateNodeFunc) *CreateNodeFunc
NewCreateNodeFunc creates a new instance of CreateNodeFunc. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*CreateNodeFunc) Execute ¶ added in v0.30.0
func (_m *CreateNodeFunc) Execute(_a0 zerolog.Logger, _a1 host.Host, _a2 p2p.ProtocolPeerCache, _a3 p2p.PeerManager, _a4 *p2p.DisallowListCacheConfig) p2p.LibP2PNode
Execute provides a mock function with given fields: _a0, _a1, _a2, _a3, _a4
type DisallowListCache ¶ added in v0.32.0
DisallowListCache is an autogenerated mock type for the DisallowListCache type
func NewDisallowListCache ¶ added in v0.32.0
func NewDisallowListCache(t interface { mock.TestingT Cleanup(func()) }) *DisallowListCache
NewDisallowListCache creates a new instance of DisallowListCache. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*DisallowListCache) AllowFor ¶ added in v0.32.0
func (_m *DisallowListCache) AllowFor(peerID peer.ID, cause network.DisallowListedCause) []network.DisallowListedCause
AllowFor provides a mock function with given fields: peerID, cause
func (*DisallowListCache) DisallowFor ¶ added in v0.32.0
func (_m *DisallowListCache) DisallowFor(peerID peer.ID, cause network.DisallowListedCause) ([]network.DisallowListedCause, error)
DisallowFor provides a mock function with given fields: peerID, cause
func (*DisallowListCache) IsDisallowListed ¶ added in v0.32.0
func (_m *DisallowListCache) IsDisallowListed(peerID peer.ID) ([]network.DisallowListedCause, bool)
IsDisallowListed provides a mock function with given fields: peerID
type DisallowListNotificationConsumer ¶ added in v0.30.0
DisallowListNotificationConsumer is an autogenerated mock type for the DisallowListNotificationConsumer type
func NewDisallowListNotificationConsumer ¶ added in v0.30.0
func NewDisallowListNotificationConsumer(t interface { mock.TestingT Cleanup(func()) }) *DisallowListNotificationConsumer
NewDisallowListNotificationConsumer creates a new instance of DisallowListNotificationConsumer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*DisallowListNotificationConsumer) OnAllowListNotification ¶ added in v0.32.0
func (_m *DisallowListNotificationConsumer) OnAllowListNotification(id peer.ID, cause network.DisallowListedCause)
OnAllowListNotification provides a mock function with given fields: id, cause
func (*DisallowListNotificationConsumer) OnDisallowListNotification ¶ added in v0.30.0
func (_m *DisallowListNotificationConsumer) OnDisallowListNotification(id peer.ID, cause network.DisallowListedCause)
OnDisallowListNotification provides a mock function with given fields: id, cause
type DisallowListOracle ¶ added in v0.32.0
DisallowListOracle is an autogenerated mock type for the DisallowListOracle type
func NewDisallowListOracle ¶ added in v0.32.0
func NewDisallowListOracle(t interface { mock.TestingT Cleanup(func()) }) *DisallowListOracle
NewDisallowListOracle creates a new instance of DisallowListOracle. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*DisallowListOracle) IsDisallowListed ¶ added in v0.32.0
func (_m *DisallowListOracle) IsDisallowListed(peerId peer.ID) ([]network.DisallowListedCause, bool)
IsDisallowListed provides a mock function with given fields: peerId
type GetTimeNow ¶ added in v0.29.0
GetTimeNow is an autogenerated mock type for the GetTimeNow type
func NewGetTimeNow ¶ added in v0.29.0
func NewGetTimeNow(t mockConstructorTestingTNewGetTimeNow) *GetTimeNow
NewGetTimeNow creates a new instance of GetTimeNow. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*GetTimeNow) Execute ¶ added in v0.29.0
func (_m *GetTimeNow) Execute() time.Time
Execute provides a mock function with given fields:
type GossipSubAdapterConfigFunc ¶ added in v0.30.0
GossipSubAdapterConfigFunc is an autogenerated mock type for the GossipSubAdapterConfigFunc type
func NewGossipSubAdapterConfigFunc ¶ added in v0.30.0
func NewGossipSubAdapterConfigFunc(t interface { mock.TestingT Cleanup(func()) }) *GossipSubAdapterConfigFunc
NewGossipSubAdapterConfigFunc creates a new instance of GossipSubAdapterConfigFunc. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubAdapterConfigFunc) Execute ¶ added in v0.30.0
func (_m *GossipSubAdapterConfigFunc) Execute(_a0 *p2p.BasePubSubAdapterConfig) p2p.PubSubAdapterConfig
Execute provides a mock function with given fields: _a0
type GossipSubAppSpecificRpcInspector ¶ added in v0.30.0
GossipSubAppSpecificRpcInspector is an autogenerated mock type for the GossipSubAppSpecificRpcInspector type
func NewGossipSubAppSpecificRpcInspector ¶ added in v0.30.0
func NewGossipSubAppSpecificRpcInspector(t mockConstructorTestingTNewGossipSubAppSpecificRpcInspector) *GossipSubAppSpecificRpcInspector
NewGossipSubAppSpecificRpcInspector creates a new instance of GossipSubAppSpecificRpcInspector. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
type GossipSubApplicationSpecificScoreCache ¶ added in v0.33.1
GossipSubApplicationSpecificScoreCache is an autogenerated mock type for the GossipSubApplicationSpecificScoreCache type
func NewGossipSubApplicationSpecificScoreCache ¶ added in v0.33.1
func NewGossipSubApplicationSpecificScoreCache(t interface { mock.TestingT Cleanup(func()) }) *GossipSubApplicationSpecificScoreCache
NewGossipSubApplicationSpecificScoreCache creates a new instance of GossipSubApplicationSpecificScoreCache. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubApplicationSpecificScoreCache) AdjustWithInit ¶ added in v0.33.1
func (_m *GossipSubApplicationSpecificScoreCache) AdjustWithInit(peerID peer.ID, score float64, _a2 time.Time) error
AdjustWithInit provides a mock function with given fields: peerID, score, _a2
type GossipSubBuilder ¶ added in v0.30.0
GossipSubBuilder is an autogenerated mock type for the GossipSubBuilder type
func NewGossipSubBuilder ¶ added in v0.30.0
func NewGossipSubBuilder(t interface { mock.TestingT Cleanup(func()) }) *GossipSubBuilder
NewGossipSubBuilder creates a new instance of GossipSubBuilder. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubBuilder) Build ¶ added in v0.30.0
func (_m *GossipSubBuilder) Build(_a0 irrecoverable.SignalerContext) (p2p.PubSubAdapter, error)
Build provides a mock function with given fields: _a0
func (*GossipSubBuilder) EnableGossipSubScoringWithOverride ¶ added in v0.32.0
func (_m *GossipSubBuilder) EnableGossipSubScoringWithOverride(_a0 *p2p.PeerScoringConfigOverride)
EnableGossipSubScoringWithOverride provides a mock function with given fields: _a0
func (*GossipSubBuilder) OverrideDefaultRpcInspectorFactory ¶ added in v0.33.30
func (_m *GossipSubBuilder) OverrideDefaultRpcInspectorFactory(_a0 p2p.GossipSubRpcInspectorFactoryFunc)
OverrideDefaultRpcInspectorFactory provides a mock function with given fields: _a0
func (*GossipSubBuilder) SetGossipSubConfigFunc ¶ added in v0.30.0
func (_m *GossipSubBuilder) SetGossipSubConfigFunc(_a0 p2p.GossipSubAdapterConfigFunc)
SetGossipSubConfigFunc provides a mock function with given fields: _a0
func (*GossipSubBuilder) SetGossipSubFactory ¶ added in v0.30.0
func (_m *GossipSubBuilder) SetGossipSubFactory(_a0 p2p.GossipSubFactoryFunc)
SetGossipSubFactory provides a mock function with given fields: _a0
func (*GossipSubBuilder) SetHost ¶ added in v0.30.0
func (_m *GossipSubBuilder) SetHost(_a0 host.Host)
SetHost provides a mock function with given fields: _a0
func (*GossipSubBuilder) SetRoutingSystem ¶ added in v0.30.0
func (_m *GossipSubBuilder) SetRoutingSystem(_a0 routing.Routing)
SetRoutingSystem provides a mock function with given fields: _a0
func (*GossipSubBuilder) SetSubscriptionFilter ¶ added in v0.30.0
func (_m *GossipSubBuilder) SetSubscriptionFilter(_a0 pubsub.SubscriptionFilter)
SetSubscriptionFilter provides a mock function with given fields: _a0
type GossipSubDuplicateMessageTrackerCache ¶ added in v0.33.30
GossipSubDuplicateMessageTrackerCache is an autogenerated mock type for the GossipSubDuplicateMessageTrackerCache type
func NewGossipSubDuplicateMessageTrackerCache ¶ added in v0.33.30
func NewGossipSubDuplicateMessageTrackerCache(t mockConstructorTestingTNewGossipSubDuplicateMessageTrackerCache) *GossipSubDuplicateMessageTrackerCache
NewGossipSubDuplicateMessageTrackerCache creates a new instance of GossipSubDuplicateMessageTrackerCache. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
type GossipSubFactoryFunc ¶ added in v0.30.0
GossipSubFactoryFunc is an autogenerated mock type for the GossipSubFactoryFunc type
func NewGossipSubFactoryFunc ¶ added in v0.30.0
func NewGossipSubFactoryFunc(t interface { mock.TestingT Cleanup(func()) }) *GossipSubFactoryFunc
NewGossipSubFactoryFunc creates a new instance of GossipSubFactoryFunc. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubFactoryFunc) Execute ¶ added in v0.30.0
func (_m *GossipSubFactoryFunc) Execute(_a0 context.Context, _a1 zerolog.Logger, _a2 host.Host, _a3 p2p.PubSubAdapterConfig, _a4 p2p.CollectionClusterChangesConsumer) (p2p.PubSubAdapter, error)
Execute provides a mock function with given fields: _a0, _a1, _a2, _a3, _a4
type GossipSubInvCtrlMsgNotifConsumer ¶ added in v0.31.0
GossipSubInvCtrlMsgNotifConsumer is an autogenerated mock type for the GossipSubInvCtrlMsgNotifConsumer type
func NewGossipSubInvCtrlMsgNotifConsumer ¶ added in v0.31.0
func NewGossipSubInvCtrlMsgNotifConsumer(t interface { mock.TestingT Cleanup(func()) }) *GossipSubInvCtrlMsgNotifConsumer
NewGossipSubInvCtrlMsgNotifConsumer creates a new instance of GossipSubInvCtrlMsgNotifConsumer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubInvCtrlMsgNotifConsumer) OnInvalidControlMessageNotification ¶ added in v0.31.0
func (_m *GossipSubInvCtrlMsgNotifConsumer) OnInvalidControlMessageNotification(_a0 *p2p.InvCtrlMsgNotif)
OnInvalidControlMessageNotification provides a mock function with given fields: _a0
type GossipSubInvalidControlMessageNotificationConsumer ¶ added in v0.30.0
GossipSubInvalidControlMessageNotificationConsumer is an autogenerated mock type for the GossipSubInvalidControlMessageNotificationConsumer type
func NewGossipSubInvalidControlMessageNotificationConsumer ¶ added in v0.30.0
func NewGossipSubInvalidControlMessageNotificationConsumer(t mockConstructorTestingTNewGossipSubInvalidControlMessageNotificationConsumer) *GossipSubInvalidControlMessageNotificationConsumer
NewGossipSubInvalidControlMessageNotificationConsumer creates a new instance of GossipSubInvalidControlMessageNotificationConsumer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*GossipSubInvalidControlMessageNotificationConsumer) OnInvalidControlMessageNotification ¶ added in v0.30.0
func (_m *GossipSubInvalidControlMessageNotificationConsumer) OnInvalidControlMessageNotification(_a0 *p2p.InvCtrlMsgNotif)
OnInvalidControlMessageNotification provides a mock function with given fields: _a0
type GossipSubRPCInspector ¶ added in v0.30.0
GossipSubRPCInspector is an autogenerated mock type for the GossipSubRPCInspector type
func NewGossipSubRPCInspector ¶ added in v0.30.0
func NewGossipSubRPCInspector(t interface { mock.TestingT Cleanup(func()) }) *GossipSubRPCInspector
NewGossipSubRPCInspector creates a new instance of GossipSubRPCInspector. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubRPCInspector) ActiveClustersChanged ¶ added in v0.33.30
func (_m *GossipSubRPCInspector) ActiveClustersChanged(_a0 flow.ChainIDList)
ActiveClustersChanged provides a mock function with given fields: _a0
func (*GossipSubRPCInspector) Done ¶ added in v0.30.0
func (_m *GossipSubRPCInspector) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*GossipSubRPCInspector) Inspect ¶ added in v0.30.0
Inspect provides a mock function with given fields: _a0, _a1
func (*GossipSubRPCInspector) Name ¶ added in v0.30.0
func (_m *GossipSubRPCInspector) Name() string
Name provides a mock function with given fields:
func (*GossipSubRPCInspector) Ready ¶ added in v0.30.0
func (_m *GossipSubRPCInspector) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*GossipSubRPCInspector) Start ¶ added in v0.30.0
func (_m *GossipSubRPCInspector) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
type GossipSubRpcInspectorFactoryFunc ¶ added in v0.33.30
GossipSubRpcInspectorFactoryFunc is an autogenerated mock type for the GossipSubRpcInspectorFactoryFunc type
func NewGossipSubRpcInspectorFactoryFunc ¶ added in v0.33.30
func NewGossipSubRpcInspectorFactoryFunc(t interface { mock.TestingT Cleanup(func()) }) *GossipSubRpcInspectorFactoryFunc
NewGossipSubRpcInspectorFactoryFunc creates a new instance of GossipSubRpcInspectorFactoryFunc. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubRpcInspectorFactoryFunc) Execute ¶ added in v0.33.30
func (_m *GossipSubRpcInspectorFactoryFunc) Execute(_a0 zerolog.Logger, _a1 flow.Identifier, _a2 *p2pconfig.RpcInspectorParameters, _a3 module.GossipSubMetrics, _a4 metrics.HeroCacheMetricsFactory, _a5 network.NetworkingType, _a6 module.IdentityProvider, _a7 func() p2p.TopicProvider, _a8 p2p.GossipSubInvCtrlMsgNotifConsumer) (p2p.GossipSubRPCInspector, error)
Execute provides a mock function with given fields: _a0, _a1, _a2, _a3, _a4, _a5, _a6, _a7, _a8
type GossipSubSpamRecordCache ¶ added in v0.31.0
GossipSubSpamRecordCache is an autogenerated mock type for the GossipSubSpamRecordCache type
func NewGossipSubSpamRecordCache ¶ added in v0.31.0
func NewGossipSubSpamRecordCache(t interface { mock.TestingT Cleanup(func()) }) *GossipSubSpamRecordCache
NewGossipSubSpamRecordCache creates a new instance of GossipSubSpamRecordCache. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*GossipSubSpamRecordCache) Adjust ¶ added in v0.33.1
func (_m *GossipSubSpamRecordCache) Adjust(peerID peer.ID, updateFunc p2p.UpdateFunction) (*p2p.GossipSubSpamRecord, error)
Adjust provides a mock function with given fields: peerID, updateFunc
func (*GossipSubSpamRecordCache) Get ¶ added in v0.31.0
func (_m *GossipSubSpamRecordCache) Get(peerID peer.ID) (*p2p.GossipSubSpamRecord, error, bool)
Get provides a mock function with given fields: peerID
type IDTranslator ¶
IDTranslator is an autogenerated mock type for the IDTranslator type
func NewIDTranslator ¶
func NewIDTranslator(t interface { mock.TestingT Cleanup(func()) }) *IDTranslator
NewIDTranslator creates a new instance of IDTranslator. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*IDTranslator) GetFlowID ¶
func (_m *IDTranslator) GetFlowID(_a0 peer.ID) (flow.Identifier, error)
GetFlowID provides a mock function with given fields: _a0
func (*IDTranslator) GetPeerID ¶
func (_m *IDTranslator) GetPeerID(_a0 flow.Identifier) (peer.ID, error)
GetPeerID provides a mock function with given fields: _a0
type InspectorTopicOracle ¶ added in v0.33.1
InspectorTopicOracle is an autogenerated mock type for the InspectorTopicOracle type
func NewInspectorTopicOracle ¶ added in v0.33.1
func NewInspectorTopicOracle(t mockConstructorTestingTNewInspectorTopicOracle) *InspectorTopicOracle
NewInspectorTopicOracle creates a new instance of InspectorTopicOracle. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*InspectorTopicOracle) SetTopicOracle ¶ added in v0.33.1
func (_m *InspectorTopicOracle) SetTopicOracle(topicOracle func() []string) error
SetTopicOracle provides a mock function with given fields: topicOracle
type LibP2PNode ¶ added in v0.29.0
LibP2PNode is an autogenerated mock type for the LibP2PNode type
func NewLibP2PNode ¶ added in v0.29.0
func NewLibP2PNode(t interface { mock.TestingT Cleanup(func()) }) *LibP2PNode
NewLibP2PNode creates a new instance of LibP2PNode. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*LibP2PNode) ActiveClustersChanged ¶ added in v0.32.0
func (_m *LibP2PNode) ActiveClustersChanged(_a0 flow.ChainIDList)
ActiveClustersChanged provides a mock function with given fields: _a0
func (*LibP2PNode) ConnectToPeer ¶ added in v0.32.0
ConnectToPeer provides a mock function with given fields: ctx, peerInfo
func (*LibP2PNode) Done ¶ added in v0.29.0
func (_m *LibP2PNode) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*LibP2PNode) GetIPPort ¶ added in v0.29.0
func (_m *LibP2PNode) GetIPPort() (string, string, error)
GetIPPort provides a mock function with given fields:
func (*LibP2PNode) GetLocalMeshPeers ¶ added in v0.33.1
func (_m *LibP2PNode) GetLocalMeshPeers(topic channels.Topic) []peer.ID
GetLocalMeshPeers provides a mock function with given fields: topic
func (*LibP2PNode) GetPeersForProtocol ¶ added in v0.29.0
func (_m *LibP2PNode) GetPeersForProtocol(pid protocol.ID) peer.IDSlice
GetPeersForProtocol provides a mock function with given fields: pid
func (*LibP2PNode) HasSubscription ¶ added in v0.29.0
func (_m *LibP2PNode) HasSubscription(topic channels.Topic) bool
HasSubscription provides a mock function with given fields: topic
func (*LibP2PNode) Host ¶ added in v0.29.0
func (_m *LibP2PNode) Host() host.Host
Host provides a mock function with given fields:
func (*LibP2PNode) ID ¶ added in v0.32.0
func (_m *LibP2PNode) ID() peer.ID
ID provides a mock function with given fields:
func (*LibP2PNode) IsConnected ¶ added in v0.29.0
func (_m *LibP2PNode) IsConnected(peerID peer.ID) (bool, error)
IsConnected provides a mock function with given fields: peerID
func (*LibP2PNode) IsDisallowListed ¶ added in v0.32.0
func (_m *LibP2PNode) IsDisallowListed(peerId peer.ID) ([]network.DisallowListedCause, bool)
IsDisallowListed provides a mock function with given fields: peerId
func (*LibP2PNode) ListPeers ¶ added in v0.29.0
func (_m *LibP2PNode) ListPeers(topic string) []peer.ID
ListPeers provides a mock function with given fields: topic
func (*LibP2PNode) OnAllowListNotification ¶ added in v0.32.0
func (_m *LibP2PNode) OnAllowListNotification(id peer.ID, cause network.DisallowListedCause)
OnAllowListNotification provides a mock function with given fields: id, cause
func (*LibP2PNode) OnDisallowListNotification ¶ added in v0.32.0
func (_m *LibP2PNode) OnDisallowListNotification(id peer.ID, cause network.DisallowListedCause)
OnDisallowListNotification provides a mock function with given fields: id, cause
func (*LibP2PNode) OpenAndWriteOnStream ¶ added in v0.33.1
func (_m *LibP2PNode) OpenAndWriteOnStream(ctx context.Context, peerID peer.ID, protectionTag string, writingLogic func(corenetwork.Stream) error) error
OpenAndWriteOnStream provides a mock function with given fields: ctx, peerID, protectionTag, writingLogic
func (*LibP2PNode) PeerManagerComponent ¶ added in v0.29.0
func (_m *LibP2PNode) PeerManagerComponent() component.Component
PeerManagerComponent provides a mock function with given fields:
func (*LibP2PNode) PeerScoreExposer ¶ added in v0.30.0
func (_m *LibP2PNode) PeerScoreExposer() p2p.PeerScoreExposer
PeerScoreExposer provides a mock function with given fields:
func (*LibP2PNode) Publish ¶ added in v0.29.0
func (_m *LibP2PNode) Publish(ctx context.Context, messageScope network.OutgoingMessageScope) error
Publish provides a mock function with given fields: ctx, messageScope
func (*LibP2PNode) Ready ¶ added in v0.29.0
func (_m *LibP2PNode) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*LibP2PNode) RemovePeer ¶ added in v0.29.0
func (_m *LibP2PNode) RemovePeer(peerID peer.ID) error
RemovePeer provides a mock function with given fields: peerID
func (*LibP2PNode) RequestPeerUpdate ¶ added in v0.29.0
func (_m *LibP2PNode) RequestPeerUpdate()
RequestPeerUpdate provides a mock function with given fields:
func (*LibP2PNode) Routing ¶ added in v0.29.0
func (_m *LibP2PNode) Routing() routing.Routing
Routing provides a mock function with given fields:
func (*LibP2PNode) RoutingTable ¶ added in v0.29.0
func (_m *LibP2PNode) RoutingTable() *kbucket.RoutingTable
RoutingTable provides a mock function with given fields:
func (*LibP2PNode) SetComponentManager ¶ added in v0.29.0
func (_m *LibP2PNode) SetComponentManager(cm *component.ComponentManager)
SetComponentManager provides a mock function with given fields: cm
func (*LibP2PNode) SetPubSub ¶ added in v0.29.0
func (_m *LibP2PNode) SetPubSub(ps p2p.PubSubAdapter)
SetPubSub provides a mock function with given fields: ps
func (*LibP2PNode) SetRouting ¶ added in v0.29.0
func (_m *LibP2PNode) SetRouting(r routing.Routing) error
SetRouting provides a mock function with given fields: r
func (*LibP2PNode) SetUnicastManager ¶ added in v0.30.0
func (_m *LibP2PNode) SetUnicastManager(uniMgr p2p.UnicastManager)
SetUnicastManager provides a mock function with given fields: uniMgr
func (*LibP2PNode) Start ¶ added in v0.29.0
func (_m *LibP2PNode) Start(ctx irrecoverable.SignalerContext)
Start provides a mock function with given fields: ctx
func (*LibP2PNode) Stop ¶ added in v0.29.0
func (_m *LibP2PNode) Stop() error
Stop provides a mock function with given fields:
func (*LibP2PNode) Subscribe ¶ added in v0.29.0
func (_m *LibP2PNode) Subscribe(topic channels.Topic, topicValidator p2p.TopicValidatorFunc) (p2p.Subscription, error)
Subscribe provides a mock function with given fields: topic, topicValidator
func (*LibP2PNode) Unsubscribe ¶ added in v0.32.0
func (_m *LibP2PNode) Unsubscribe(topic channels.Topic) error
Unsubscribe provides a mock function with given fields: topic
func (*LibP2PNode) WithDefaultUnicastProtocol ¶ added in v0.29.0
func (_m *LibP2PNode) WithDefaultUnicastProtocol(defaultHandler corenetwork.StreamHandler, preferred []protocols.ProtocolName) error
WithDefaultUnicastProtocol provides a mock function with given fields: defaultHandler, preferred
func (*LibP2PNode) WithPeersProvider ¶ added in v0.29.0
func (_m *LibP2PNode) WithPeersProvider(peersProvider p2p.PeersProvider)
WithPeersProvider provides a mock function with given fields: peersProvider
type NetworkConfigOption ¶ added in v0.31.0
NetworkConfigOption is an autogenerated mock type for the NetworkConfigOption type
func NewNetworkConfigOption ¶ added in v0.31.0
func NewNetworkConfigOption(t mockConstructorTestingTNewNetworkConfigOption) *NetworkConfigOption
NewNetworkConfigOption creates a new instance of NetworkConfigOption. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*NetworkConfigOption) Execute ¶ added in v0.31.0
func (_m *NetworkConfigOption) Execute(_a0 *p2p.NetworkConfig)
Execute provides a mock function with given fields: _a0
type NetworkOptFunction ¶
NetworkOptFunction is an autogenerated mock type for the NetworkOptFunction type
func NewNetworkOptFunction ¶
func NewNetworkOptFunction(t mockConstructorTestingTNewNetworkOptFunction) *NetworkOptFunction
NewNetworkOptFunction creates a new instance of NetworkOptFunction. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*NetworkOptFunction) Execute ¶
func (_m *NetworkOptFunction) Execute(_a0 *p2p.Network)
Execute provides a mock function with given fields: _a0
type NetworkOption ¶ added in v0.31.0
NetworkOption is an autogenerated mock type for the NetworkOption type
func NewNetworkOption ¶ added in v0.31.0
func NewNetworkOption(t mockConstructorTestingTNewNetworkOption) *NetworkOption
NewNetworkOption creates a new instance of NetworkOption. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*NetworkOption) Execute ¶ added in v0.31.0
func (_m *NetworkOption) Execute(_a0 *p2p.Network)
Execute provides a mock function with given fields: _a0
type NetworkParamOption ¶ added in v0.31.0
NetworkParamOption is an autogenerated mock type for the NetworkParamOption type
func NewNetworkParamOption ¶ added in v0.31.0
func NewNetworkParamOption(t mockConstructorTestingTNewNetworkParamOption) *NetworkParamOption
NewNetworkParamOption creates a new instance of NetworkParamOption. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*NetworkParamOption) Execute ¶ added in v0.31.0
func (_m *NetworkParamOption) Execute(_a0 *p2p.NetworkConfig)
Execute provides a mock function with given fields: _a0
type NodeBlockListConsumer ¶ added in v0.30.0
NodeBlockListConsumer is an autogenerated mock type for the NodeBlockListConsumer type
func NewNodeBlockListConsumer ¶ added in v0.30.0
func NewNodeBlockListConsumer(t mockConstructorTestingTNewNodeBlockListConsumer) *NodeBlockListConsumer
NewNodeBlockListConsumer creates a new instance of NodeBlockListConsumer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*NodeBlockListConsumer) OnNodeDisallowListUpdate ¶ added in v0.30.0
func (_m *NodeBlockListConsumer) OnNodeDisallowListUpdate(list flow.IdentifierList)
OnNodeBlockListUpdate provides a mock function with given fields: list
type NodeBuilder ¶ added in v0.30.0
NodeBuilder is an autogenerated mock type for the NodeBuilder type
func NewNodeBuilder ¶ added in v0.30.0
func NewNodeBuilder(t interface { mock.TestingT Cleanup(func()) }) *NodeBuilder
NewNodeBuilder creates a new instance of NodeBuilder. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*NodeBuilder) Build ¶ added in v0.30.0
func (_m *NodeBuilder) Build() (p2p.LibP2PNode, error)
Build provides a mock function with given fields:
func (*NodeBuilder) OverrideDefaultRpcInspectorFactory ¶ added in v0.33.30
func (_m *NodeBuilder) OverrideDefaultRpcInspectorFactory(_a0 p2p.GossipSubRpcInspectorFactoryFunc) p2p.NodeBuilder
OverrideDefaultRpcInspectorFactory provides a mock function with given fields: _a0
func (*NodeBuilder) OverrideGossipSubFactory ¶ added in v0.33.30
func (_m *NodeBuilder) OverrideGossipSubFactory(_a0 p2p.GossipSubFactoryFunc, _a1 p2p.GossipSubAdapterConfigFunc) p2p.NodeBuilder
OverrideGossipSubFactory provides a mock function with given fields: _a0, _a1
func (*NodeBuilder) OverrideGossipSubScoringConfig ¶ added in v0.33.1
func (_m *NodeBuilder) OverrideGossipSubScoringConfig(_a0 *p2p.PeerScoringConfigOverride) p2p.NodeBuilder
OverrideGossipSubScoringConfig provides a mock function with given fields: _a0
func (*NodeBuilder) OverrideNodeConstructor ¶ added in v0.33.1
func (_m *NodeBuilder) OverrideNodeConstructor(_a0 p2p.NodeConstructor) p2p.NodeBuilder
OverrideNodeConstructor provides a mock function with given fields: _a0
func (*NodeBuilder) SetBasicResolver ¶ added in v0.30.0
func (_m *NodeBuilder) SetBasicResolver(_a0 madns.BasicResolver) p2p.NodeBuilder
SetBasicResolver provides a mock function with given fields: _a0
func (*NodeBuilder) SetConnectionGater ¶ added in v0.30.0
func (_m *NodeBuilder) SetConnectionGater(_a0 p2p.ConnectionGater) p2p.NodeBuilder
SetConnectionGater provides a mock function with given fields: _a0
func (*NodeBuilder) SetConnectionManager ¶ added in v0.30.0
func (_m *NodeBuilder) SetConnectionManager(_a0 connmgr.ConnManager) p2p.NodeBuilder
SetConnectionManager provides a mock function with given fields: _a0
func (*NodeBuilder) SetResourceManager ¶ added in v0.30.0
func (_m *NodeBuilder) SetResourceManager(_a0 network.ResourceManager) p2p.NodeBuilder
SetResourceManager provides a mock function with given fields: _a0
func (*NodeBuilder) SetRoutingSystem ¶ added in v0.30.0
func (_m *NodeBuilder) SetRoutingSystem(_a0 func(context.Context, host.Host) (routing.Routing, error)) p2p.NodeBuilder
SetRoutingSystem provides a mock function with given fields: _a0
func (*NodeBuilder) SetSubscriptionFilter ¶ added in v0.30.0
func (_m *NodeBuilder) SetSubscriptionFilter(_a0 pubsub.SubscriptionFilter) p2p.NodeBuilder
SetSubscriptionFilter provides a mock function with given fields: _a0
type NodeConstructor ¶ added in v0.33.1
NodeConstructor is an autogenerated mock type for the NodeConstructor type
func NewNodeConstructor ¶ added in v0.33.1
func NewNodeConstructor(t interface { mock.TestingT Cleanup(func()) }) *NodeConstructor
NewNodeConstructor creates a new instance of NodeConstructor. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*NodeConstructor) Execute ¶ added in v0.33.1
func (_m *NodeConstructor) Execute(config *p2p.NodeConfig) (p2p.LibP2PNode, error)
Execute provides a mock function with given fields: config
type PeerConnections ¶ added in v0.30.0
PeerConnections is an autogenerated mock type for the PeerConnections type
func NewPeerConnections ¶ added in v0.30.0
func NewPeerConnections(t interface { mock.TestingT Cleanup(func()) }) *PeerConnections
NewPeerConnections creates a new instance of PeerConnections. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PeerConnections) IsConnected ¶ added in v0.30.0
func (_m *PeerConnections) IsConnected(peerID peer.ID) (bool, error)
IsConnected provides a mock function with given fields: peerID
type PeerFilter ¶
PeerFilter is an autogenerated mock type for the PeerFilter type
func NewPeerFilter ¶
func NewPeerFilter(t interface { mock.TestingT Cleanup(func()) }) *PeerFilter
NewPeerFilter creates a new instance of PeerFilter. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
type PeerManagement ¶ added in v0.32.0
PeerManagement is an autogenerated mock type for the PeerManagement type
func NewPeerManagement ¶ added in v0.32.0
func NewPeerManagement(t interface { mock.TestingT Cleanup(func()) }) *PeerManagement
NewPeerManagement creates a new instance of PeerManagement. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PeerManagement) ConnectToPeer ¶ added in v0.32.0
ConnectToPeer provides a mock function with given fields: ctx, peerInfo
func (*PeerManagement) GetIPPort ¶ added in v0.32.0
func (_m *PeerManagement) GetIPPort() (string, string, error)
GetIPPort provides a mock function with given fields:
func (*PeerManagement) GetPeersForProtocol ¶ added in v0.32.0
func (_m *PeerManagement) GetPeersForProtocol(pid protocol.ID) peer.IDSlice
GetPeersForProtocol provides a mock function with given fields: pid
func (*PeerManagement) Host ¶ added in v0.32.0
func (_m *PeerManagement) Host() host.Host
Host provides a mock function with given fields:
func (*PeerManagement) ID ¶ added in v0.32.0
func (_m *PeerManagement) ID() peer.ID
ID provides a mock function with given fields:
func (*PeerManagement) ListPeers ¶ added in v0.32.0
func (_m *PeerManagement) ListPeers(topic string) []peer.ID
ListPeers provides a mock function with given fields: topic
func (*PeerManagement) PeerManagerComponent ¶ added in v0.32.0
func (_m *PeerManagement) PeerManagerComponent() component.Component
PeerManagerComponent provides a mock function with given fields:
func (*PeerManagement) Publish ¶ added in v0.32.0
func (_m *PeerManagement) Publish(ctx context.Context, messageScope network.OutgoingMessageScope) error
Publish provides a mock function with given fields: ctx, messageScope
func (*PeerManagement) RemovePeer ¶ added in v0.32.0
func (_m *PeerManagement) RemovePeer(peerID peer.ID) error
RemovePeer provides a mock function with given fields: peerID
func (*PeerManagement) RequestPeerUpdate ¶ added in v0.32.0
func (_m *PeerManagement) RequestPeerUpdate()
RequestPeerUpdate provides a mock function with given fields:
func (*PeerManagement) RoutingTable ¶ added in v0.32.0
func (_m *PeerManagement) RoutingTable() *kbucket.RoutingTable
RoutingTable provides a mock function with given fields:
func (*PeerManagement) Subscribe ¶ added in v0.32.0
func (_m *PeerManagement) Subscribe(topic channels.Topic, topicValidator p2p.TopicValidatorFunc) (p2p.Subscription, error)
Subscribe provides a mock function with given fields: topic, topicValidator
func (*PeerManagement) Unsubscribe ¶ added in v0.32.0
func (_m *PeerManagement) Unsubscribe(topic channels.Topic) error
Unsubscribe provides a mock function with given fields: topic
func (*PeerManagement) WithDefaultUnicastProtocol ¶ added in v0.32.0
func (_m *PeerManagement) WithDefaultUnicastProtocol(defaultHandler corenetwork.StreamHandler, preferred []protocols.ProtocolName) error
WithDefaultUnicastProtocol provides a mock function with given fields: defaultHandler, preferred
func (*PeerManagement) WithPeersProvider ¶ added in v0.32.0
func (_m *PeerManagement) WithPeersProvider(peersProvider p2p.PeersProvider)
WithPeersProvider provides a mock function with given fields: peersProvider
type PeerManager ¶
PeerManager is an autogenerated mock type for the PeerManager type
func NewPeerManager ¶
func NewPeerManager(t interface { mock.TestingT Cleanup(func()) }) *PeerManager
NewPeerManager creates a new instance of PeerManager. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PeerManager) Done ¶
func (_m *PeerManager) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*PeerManager) ForceUpdatePeers ¶
func (_m *PeerManager) ForceUpdatePeers(_a0 context.Context)
ForceUpdatePeers provides a mock function with given fields: _a0
func (*PeerManager) OnRateLimitedPeer ¶ added in v0.30.0
func (_m *PeerManager) OnRateLimitedPeer(pid peer.ID, role string, msgType string, topic string, reason string)
OnRateLimitedPeer provides a mock function with given fields: pid, role, msgType, topic, reason
func (*PeerManager) Ready ¶
func (_m *PeerManager) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*PeerManager) RequestPeerUpdate ¶
func (_m *PeerManager) RequestPeerUpdate()
RequestPeerUpdate provides a mock function with given fields:
func (*PeerManager) SetPeersProvider ¶
func (_m *PeerManager) SetPeersProvider(_a0 p2p.PeersProvider)
SetPeersProvider provides a mock function with given fields: _a0
func (*PeerManager) Start ¶
func (_m *PeerManager) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
type PeerManagerFactoryFunc ¶
PeerManagerFactoryFunc is an autogenerated mock type for the PeerManagerFactoryFunc type
func NewPeerManagerFactoryFunc ¶
func NewPeerManagerFactoryFunc(t interface { mock.TestingT Cleanup(func()) }) *PeerManagerFactoryFunc
NewPeerManagerFactoryFunc creates a new instance of PeerManagerFactoryFunc. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PeerManagerFactoryFunc) Execute ¶
func (_m *PeerManagerFactoryFunc) Execute(_a0 host.Host, peersProvider p2p.PeersProvider, logger zerolog.Logger) (p2p.PeerManager, error)
Execute provides a mock function with given fields: _a0, peersProvider, logger
type PeerScore ¶ added in v0.30.0
PeerScore is an autogenerated mock type for the PeerScore type
func NewPeerScore ¶ added in v0.30.0
NewPeerScore creates a new instance of PeerScore. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PeerScore) PeerScoreExposer ¶ added in v0.30.0
func (_m *PeerScore) PeerScoreExposer() p2p.PeerScoreExposer
PeerScoreExposer provides a mock function with given fields:
type PeerScoreExposer ¶ added in v0.30.0
PeerScoreExposer is an autogenerated mock type for the PeerScoreExposer type
func NewPeerScoreExposer ¶ added in v0.30.0
func NewPeerScoreExposer(t interface { mock.TestingT Cleanup(func()) }) *PeerScoreExposer
NewPeerScoreExposer creates a new instance of PeerScoreExposer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PeerScoreExposer) GetAppScore ¶ added in v0.30.0
func (_m *PeerScoreExposer) GetAppScore(peerID peer.ID) (float64, bool)
GetAppScore provides a mock function with given fields: peerID
func (*PeerScoreExposer) GetBehaviourPenalty ¶ added in v0.30.0
func (_m *PeerScoreExposer) GetBehaviourPenalty(peerID peer.ID) (float64, bool)
GetBehaviourPenalty provides a mock function with given fields: peerID
func (*PeerScoreExposer) GetIPColocationFactor ¶ added in v0.30.0
func (_m *PeerScoreExposer) GetIPColocationFactor(peerID peer.ID) (float64, bool)
GetIPColocationFactor provides a mock function with given fields: peerID
func (*PeerScoreExposer) GetScore ¶ added in v0.30.0
func (_m *PeerScoreExposer) GetScore(peerID peer.ID) (float64, bool)
GetScore provides a mock function with given fields: peerID
func (*PeerScoreExposer) GetTopicScores ¶ added in v0.30.0
func (_m *PeerScoreExposer) GetTopicScores(peerID peer.ID) (map[string]p2p.TopicScoreSnapshot, bool)
GetTopicScores provides a mock function with given fields: peerID
type PeerScoreTracer ¶ added in v0.30.0
PeerScoreTracer is an autogenerated mock type for the PeerScoreTracer type
func NewPeerScoreTracer ¶ added in v0.30.0
func NewPeerScoreTracer(t interface { mock.TestingT Cleanup(func()) }) *PeerScoreTracer
NewPeerScoreTracer creates a new instance of PeerScoreTracer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PeerScoreTracer) Done ¶ added in v0.30.0
func (_m *PeerScoreTracer) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*PeerScoreTracer) GetAppScore ¶ added in v0.30.0
func (_m *PeerScoreTracer) GetAppScore(peerID peer.ID) (float64, bool)
GetAppScore provides a mock function with given fields: peerID
func (*PeerScoreTracer) GetBehaviourPenalty ¶ added in v0.30.0
func (_m *PeerScoreTracer) GetBehaviourPenalty(peerID peer.ID) (float64, bool)
GetBehaviourPenalty provides a mock function with given fields: peerID
func (*PeerScoreTracer) GetIPColocationFactor ¶ added in v0.30.0
func (_m *PeerScoreTracer) GetIPColocationFactor(peerID peer.ID) (float64, bool)
GetIPColocationFactor provides a mock function with given fields: peerID
func (*PeerScoreTracer) GetScore ¶ added in v0.30.0
func (_m *PeerScoreTracer) GetScore(peerID peer.ID) (float64, bool)
GetScore provides a mock function with given fields: peerID
func (*PeerScoreTracer) GetTopicScores ¶ added in v0.30.0
func (_m *PeerScoreTracer) GetTopicScores(peerID peer.ID) (map[string]p2p.TopicScoreSnapshot, bool)
GetTopicScores provides a mock function with given fields: peerID
func (*PeerScoreTracer) Ready ¶ added in v0.30.0
func (_m *PeerScoreTracer) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*PeerScoreTracer) Start ¶ added in v0.30.0
func (_m *PeerScoreTracer) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
func (*PeerScoreTracer) UpdateInterval ¶ added in v0.30.0
func (_m *PeerScoreTracer) UpdateInterval() time.Duration
UpdateInterval provides a mock function with given fields:
func (*PeerScoreTracer) UpdatePeerScoreSnapshots ¶ added in v0.30.0
func (_m *PeerScoreTracer) UpdatePeerScoreSnapshots(_a0 map[peer.ID]*p2p.PeerScoreSnapshot)
UpdatePeerScoreSnapshots provides a mock function with given fields: _a0
type PeerScoringBuilder ¶ added in v0.30.0
PeerScoringBuilder is an autogenerated mock type for the PeerScoringBuilder type
func NewPeerScoringBuilder ¶ added in v0.30.0
func NewPeerScoringBuilder(t mockConstructorTestingTNewPeerScoringBuilder) *PeerScoringBuilder
NewPeerScoringBuilder creates a new instance of PeerScoringBuilder. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*PeerScoringBuilder) SetAppSpecificScoreParams ¶ added in v0.30.0
func (_m *PeerScoringBuilder) SetAppSpecificScoreParams(_a0 func(peer.ID) float64)
SetAppSpecificScoreParams provides a mock function with given fields: _a0
func (*PeerScoringBuilder) SetTopicScoreParams ¶ added in v0.30.0
func (_m *PeerScoringBuilder) SetTopicScoreParams(topic channels.Topic, topicScoreParams *pubsub.TopicScoreParams)
SetTopicScoreParams provides a mock function with given fields: topic, topicScoreParams
type PeerUpdater ¶ added in v0.32.0
PeerUpdater is an autogenerated mock type for the PeerUpdater type
func NewPeerUpdater ¶ added in v0.32.0
func NewPeerUpdater(t interface { mock.TestingT Cleanup(func()) }) *PeerUpdater
NewPeerUpdater creates a new instance of PeerUpdater. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PeerUpdater) UpdatePeers ¶ added in v0.32.0
func (_m *PeerUpdater) UpdatePeers(ctx context.Context, peerIDs peer.IDSlice)
UpdatePeers provides a mock function with given fields: ctx, peerIDs
type PeersProvider ¶
PeersProvider is an autogenerated mock type for the PeersProvider type
func NewPeersProvider ¶
func NewPeersProvider(t interface { mock.TestingT Cleanup(func()) }) *PeersProvider
NewPeersProvider creates a new instance of PeersProvider. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PeersProvider) Execute ¶
func (_m *PeersProvider) Execute() peer.IDSlice
Execute provides a mock function with given fields:
type ProtocolPeerCache ¶ added in v0.30.0
ProtocolPeerCache is an autogenerated mock type for the ProtocolPeerCache type
func NewProtocolPeerCache ¶ added in v0.30.0
func NewProtocolPeerCache(t interface { mock.TestingT Cleanup(func()) }) *ProtocolPeerCache
NewProtocolPeerCache creates a new instance of ProtocolPeerCache. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ProtocolPeerCache) AddProtocols ¶ added in v0.30.0
func (_m *ProtocolPeerCache) AddProtocols(peerID peer.ID, protocols []protocol.ID)
AddProtocols provides a mock function with given fields: peerID, protocols
func (*ProtocolPeerCache) GetPeers ¶ added in v0.30.0
func (_m *ProtocolPeerCache) GetPeers(pid protocol.ID) map[peer.ID]struct{}
GetPeers provides a mock function with given fields: pid
func (*ProtocolPeerCache) RemovePeer ¶ added in v0.30.0
func (_m *ProtocolPeerCache) RemovePeer(peerID peer.ID)
RemovePeer provides a mock function with given fields: peerID
func (*ProtocolPeerCache) RemoveProtocols ¶ added in v0.30.0
func (_m *ProtocolPeerCache) RemoveProtocols(peerID peer.ID, protocols []protocol.ID)
RemoveProtocols provides a mock function with given fields: peerID, protocols
type PubSub ¶ added in v0.32.0
PubSub is an autogenerated mock type for the PubSub type
func NewPubSub ¶ added in v0.32.0
NewPubSub creates a new instance of PubSub. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PubSub) GetLocalMeshPeers ¶ added in v0.33.1
GetLocalMeshPeers provides a mock function with given fields: topic
func (*PubSub) Publish ¶ added in v0.32.0
Publish provides a mock function with given fields: ctx, messageScope
func (*PubSub) SetPubSub ¶ added in v0.32.0
func (_m *PubSub) SetPubSub(ps p2p.PubSubAdapter)
SetPubSub provides a mock function with given fields: ps
func (*PubSub) Subscribe ¶ added in v0.32.0
func (_m *PubSub) Subscribe(topic channels.Topic, topicValidator p2p.TopicValidatorFunc) (p2p.Subscription, error)
Subscribe provides a mock function with given fields: topic, topicValidator
type PubSubAdapter ¶ added in v0.29.0
PubSubAdapter is an autogenerated mock type for the PubSubAdapter type
func NewPubSubAdapter ¶ added in v0.29.0
func NewPubSubAdapter(t interface { mock.TestingT Cleanup(func()) }) *PubSubAdapter
NewPubSubAdapter creates a new instance of PubSubAdapter. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PubSubAdapter) ActiveClustersChanged ¶ added in v0.32.0
func (_m *PubSubAdapter) ActiveClustersChanged(_a0 flow.ChainIDList)
ActiveClustersChanged provides a mock function with given fields: _a0
func (*PubSubAdapter) Done ¶ added in v0.30.0
func (_m *PubSubAdapter) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*PubSubAdapter) GetLocalMeshPeers ¶ added in v0.33.1
func (_m *PubSubAdapter) GetLocalMeshPeers(topic channels.Topic) []peer.ID
GetLocalMeshPeers provides a mock function with given fields: topic
func (*PubSubAdapter) GetTopics ¶ added in v0.29.0
func (_m *PubSubAdapter) GetTopics() []string
GetTopics provides a mock function with given fields:
func (*PubSubAdapter) Join ¶ added in v0.29.0
func (_m *PubSubAdapter) Join(topic string) (p2p.Topic, error)
Join provides a mock function with given fields: topic
func (*PubSubAdapter) ListPeers ¶ added in v0.29.0
func (_m *PubSubAdapter) ListPeers(topic string) []peer.ID
ListPeers provides a mock function with given fields: topic
func (*PubSubAdapter) PeerScoreExposer ¶ added in v0.32.0
func (_m *PubSubAdapter) PeerScoreExposer() p2p.PeerScoreExposer
PeerScoreExposer provides a mock function with given fields:
func (*PubSubAdapter) Ready ¶ added in v0.30.0
func (_m *PubSubAdapter) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*PubSubAdapter) RegisterTopicValidator ¶ added in v0.29.0
func (_m *PubSubAdapter) RegisterTopicValidator(topic string, topicValidator p2p.TopicValidatorFunc) error
RegisterTopicValidator provides a mock function with given fields: topic, topicValidator
func (*PubSubAdapter) Start ¶ added in v0.30.0
func (_m *PubSubAdapter) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
func (*PubSubAdapter) UnregisterTopicValidator ¶ added in v0.29.0
func (_m *PubSubAdapter) UnregisterTopicValidator(topic string) error
UnregisterTopicValidator provides a mock function with given fields: topic
type PubSubAdapterConfig ¶ added in v0.29.0
PubSubAdapterConfig is an autogenerated mock type for the PubSubAdapterConfig type
func NewPubSubAdapterConfig ¶ added in v0.29.0
func NewPubSubAdapterConfig(t interface { mock.TestingT Cleanup(func()) }) *PubSubAdapterConfig
NewPubSubAdapterConfig creates a new instance of PubSubAdapterConfig. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PubSubAdapterConfig) WithMessageIdFunction ¶ added in v0.29.0
func (_m *PubSubAdapterConfig) WithMessageIdFunction(f func([]byte) string)
WithMessageIdFunction provides a mock function with given fields: f
func (*PubSubAdapterConfig) WithRoutingDiscovery ¶ added in v0.29.0
func (_m *PubSubAdapterConfig) WithRoutingDiscovery(_a0 routing.ContentRouting)
WithRoutingDiscovery provides a mock function with given fields: _a0
func (*PubSubAdapterConfig) WithRpcInspector ¶ added in v0.33.30
func (_m *PubSubAdapterConfig) WithRpcInspector(_a0 p2p.GossipSubRPCInspector)
WithRpcInspector provides a mock function with given fields: _a0
func (*PubSubAdapterConfig) WithScoreOption ¶ added in v0.29.0
func (_m *PubSubAdapterConfig) WithScoreOption(_a0 p2p.ScoreOptionBuilder)
WithScoreOption provides a mock function with given fields: _a0
func (*PubSubAdapterConfig) WithScoreTracer ¶ added in v0.30.0
func (_m *PubSubAdapterConfig) WithScoreTracer(tracer p2p.PeerScoreTracer)
WithScoreTracer provides a mock function with given fields: tracer
func (*PubSubAdapterConfig) WithSubscriptionFilter ¶ added in v0.29.0
func (_m *PubSubAdapterConfig) WithSubscriptionFilter(_a0 p2p.SubscriptionFilter)
WithSubscriptionFilter provides a mock function with given fields: _a0
func (*PubSubAdapterConfig) WithTracer ¶ added in v0.30.0
func (_m *PubSubAdapterConfig) WithTracer(t p2p.PubSubTracer)
WithTracer provides a mock function with given fields: t
type PubSubTracer ¶ added in v0.30.0
PubSubTracer is an autogenerated mock type for the PubSubTracer type
func NewPubSubTracer ¶ added in v0.30.0
func NewPubSubTracer(t interface { mock.TestingT Cleanup(func()) }) *PubSubTracer
NewPubSubTracer creates a new instance of PubSubTracer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*PubSubTracer) AddPeer ¶ added in v0.30.0
func (_m *PubSubTracer) AddPeer(p peer.ID, proto protocol.ID)
AddPeer provides a mock function with given fields: p, proto
func (*PubSubTracer) DeliverMessage ¶ added in v0.30.0
func (_m *PubSubTracer) DeliverMessage(msg *pubsub.Message)
DeliverMessage provides a mock function with given fields: msg
func (*PubSubTracer) Done ¶ added in v0.30.0
func (_m *PubSubTracer) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*PubSubTracer) DropRPC ¶ added in v0.30.0
func (_m *PubSubTracer) DropRPC(rpc *pubsub.RPC, p peer.ID)
DropRPC provides a mock function with given fields: rpc, p
func (*PubSubTracer) DuplicateMessage ¶ added in v0.30.0
func (_m *PubSubTracer) DuplicateMessage(msg *pubsub.Message)
DuplicateMessage provides a mock function with given fields: msg
func (*PubSubTracer) DuplicateMessageCount ¶ added in v0.33.30
func (_m *PubSubTracer) DuplicateMessageCount(_a0 peer.ID) float64
DuplicateMessageCount provides a mock function with given fields: _a0
func (*PubSubTracer) GetLocalMeshPeers ¶ added in v0.33.1
func (_m *PubSubTracer) GetLocalMeshPeers(topic channels.Topic) []peer.ID
GetLocalMeshPeers provides a mock function with given fields: topic
func (*PubSubTracer) Graft ¶ added in v0.30.0
func (_m *PubSubTracer) Graft(p peer.ID, topic string)
Graft provides a mock function with given fields: p, topic
func (*PubSubTracer) Join ¶ added in v0.30.0
func (_m *PubSubTracer) Join(topic string)
Join provides a mock function with given fields: topic
func (*PubSubTracer) LastHighestIHaveRPCSize ¶ added in v0.32.0
func (_m *PubSubTracer) LastHighestIHaveRPCSize() int64
LastHighestIHaveRPCSize provides a mock function with given fields:
func (*PubSubTracer) Leave ¶ added in v0.30.0
func (_m *PubSubTracer) Leave(topic string)
Leave provides a mock function with given fields: topic
func (*PubSubTracer) Prune ¶ added in v0.30.0
func (_m *PubSubTracer) Prune(p peer.ID, topic string)
Prune provides a mock function with given fields: p, topic
func (*PubSubTracer) Ready ¶ added in v0.30.0
func (_m *PubSubTracer) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*PubSubTracer) RecvRPC ¶ added in v0.30.0
func (_m *PubSubTracer) RecvRPC(rpc *pubsub.RPC)
RecvRPC provides a mock function with given fields: rpc
func (*PubSubTracer) RejectMessage ¶ added in v0.30.0
func (_m *PubSubTracer) RejectMessage(msg *pubsub.Message, reason string)
RejectMessage provides a mock function with given fields: msg, reason
func (*PubSubTracer) RemovePeer ¶ added in v0.30.0
func (_m *PubSubTracer) RemovePeer(p peer.ID)
RemovePeer provides a mock function with given fields: p
func (*PubSubTracer) SendRPC ¶ added in v0.30.0
func (_m *PubSubTracer) SendRPC(rpc *pubsub.RPC, p peer.ID)
SendRPC provides a mock function with given fields: rpc, p
func (*PubSubTracer) Start ¶ added in v0.30.0
func (_m *PubSubTracer) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
func (*PubSubTracer) ThrottlePeer ¶ added in v0.30.0
func (_m *PubSubTracer) ThrottlePeer(p peer.ID)
ThrottlePeer provides a mock function with given fields: p
func (*PubSubTracer) UndeliverableMessage ¶ added in v0.30.0
func (_m *PubSubTracer) UndeliverableMessage(msg *pubsub.Message)
UndeliverableMessage provides a mock function with given fields: msg
func (*PubSubTracer) ValidateMessage ¶ added in v0.30.0
func (_m *PubSubTracer) ValidateMessage(msg *pubsub.Message)
ValidateMessage provides a mock function with given fields: msg
func (*PubSubTracer) WasIHaveRPCSent ¶ added in v0.32.0
func (_m *PubSubTracer) WasIHaveRPCSent(messageID string) bool
WasIHaveRPCSent provides a mock function with given fields: messageID
type RateLimiter ¶ added in v0.29.0
RateLimiter is an autogenerated mock type for the RateLimiter type
func NewRateLimiter ¶ added in v0.29.0
func NewRateLimiter(t interface { mock.TestingT Cleanup(func()) }) *RateLimiter
NewRateLimiter creates a new instance of RateLimiter. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*RateLimiter) Allow ¶ added in v0.29.0
func (_m *RateLimiter) Allow(peerID peer.ID, msgSize int) bool
Allow provides a mock function with given fields: peerID, msgSize
func (*RateLimiter) Done ¶ added in v0.30.0
func (_m *RateLimiter) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*RateLimiter) IsRateLimited ¶ added in v0.29.0
func (_m *RateLimiter) IsRateLimited(peerID peer.ID) bool
IsRateLimited provides a mock function with given fields: peerID
func (*RateLimiter) Ready ¶ added in v0.30.0
func (_m *RateLimiter) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*RateLimiter) Start ¶ added in v0.29.0
func (_m *RateLimiter) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
type RateLimiterConsumer ¶ added in v0.30.0
RateLimiterConsumer is an autogenerated mock type for the RateLimiterConsumer type
func NewRateLimiterConsumer ¶ added in v0.30.0
func NewRateLimiterConsumer(t interface { mock.TestingT Cleanup(func()) }) *RateLimiterConsumer
NewRateLimiterConsumer creates a new instance of RateLimiterConsumer. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*RateLimiterConsumer) OnRateLimitedPeer ¶ added in v0.30.0
func (_m *RateLimiterConsumer) OnRateLimitedPeer(pid peer.ID, role string, msgType string, topic string, reason string)
OnRateLimitedPeer provides a mock function with given fields: pid, role, msgType, topic, reason
type RateLimiterOpt ¶ added in v0.29.0
RateLimiterOpt is an autogenerated mock type for the RateLimiterOpt type
func NewRateLimiterOpt ¶ added in v0.29.0
func NewRateLimiterOpt(t interface { mock.TestingT Cleanup(func()) }) *RateLimiterOpt
NewRateLimiterOpt creates a new instance of RateLimiterOpt. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*RateLimiterOpt) Execute ¶ added in v0.29.0
func (_m *RateLimiterOpt) Execute(limiter p2p.RateLimiter)
Execute provides a mock function with given fields: limiter
type Routable ¶ added in v0.32.0
Routable is an autogenerated mock type for the Routable type
func NewRoutable ¶ added in v0.32.0
NewRoutable creates a new instance of Routable. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*Routable) RoutingTable ¶ added in v0.32.0
func (_m *Routable) RoutingTable() *kbucket.RoutingTable
RoutingTable provides a mock function with given fields:
type RpcControlTracking ¶ added in v0.32.0
RpcControlTracking is an autogenerated mock type for the RpcControlTracking type
func NewRpcControlTracking ¶ added in v0.32.0
func NewRpcControlTracking(t interface { mock.TestingT Cleanup(func()) }) *RpcControlTracking
NewRpcControlTracking creates a new instance of RpcControlTracking. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*RpcControlTracking) LastHighestIHaveRPCSize ¶ added in v0.32.0
func (_m *RpcControlTracking) LastHighestIHaveRPCSize() int64
LastHighestIHaveRPCSize provides a mock function with given fields:
func (*RpcControlTracking) WasIHaveRPCSent ¶ added in v0.32.0
func (_m *RpcControlTracking) WasIHaveRPCSent(messageID string) bool
WasIHaveRPCSent provides a mock function with given fields: messageID
type ScoreOption ¶ added in v0.29.0
ScoreOption is an autogenerated mock type for the ScoreOption type
func NewScoreOption ¶ added in v0.29.0
func NewScoreOption(t mockConstructorTestingTNewScoreOption) *ScoreOption
NewScoreOption creates a new instance of ScoreOption. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*ScoreOption) BuildFlowPubSubScoreOption ¶ added in v0.29.0
func (_m *ScoreOption) BuildFlowPubSubScoreOption() pubsub.Option
BuildFlowPubSubScoreOption provides a mock function with given fields:
type ScoreOptionBuilder ¶ added in v0.29.0
ScoreOptionBuilder is an autogenerated mock type for the ScoreOptionBuilder type
func NewScoreOptionBuilder ¶ added in v0.29.0
func NewScoreOptionBuilder(t interface { mock.TestingT Cleanup(func()) }) *ScoreOptionBuilder
NewScoreOptionBuilder creates a new instance of ScoreOptionBuilder. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*ScoreOptionBuilder) BuildFlowPubSubScoreOption ¶ added in v0.29.0
func (_m *ScoreOptionBuilder) BuildFlowPubSubScoreOption() (*pubsub.PeerScoreParams, *pubsub.PeerScoreThresholds)
BuildFlowPubSubScoreOption provides a mock function with given fields:
func (*ScoreOptionBuilder) Done ¶ added in v0.33.1
func (_m *ScoreOptionBuilder) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*ScoreOptionBuilder) Ready ¶ added in v0.33.1
func (_m *ScoreOptionBuilder) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*ScoreOptionBuilder) Start ¶ added in v0.33.1
func (_m *ScoreOptionBuilder) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
func (*ScoreOptionBuilder) TopicScoreParams ¶ added in v0.32.0
func (_m *ScoreOptionBuilder) TopicScoreParams(_a0 *pubsub.Topic) *pubsub.TopicScoreParams
TopicScoreParams provides a mock function with given fields: _a0
type StreamFactory ¶ added in v0.32.2
StreamFactory is an autogenerated mock type for the StreamFactory type
func NewStreamFactory ¶ added in v0.32.2
func NewStreamFactory(t interface { mock.TestingT Cleanup(func()) }) *StreamFactory
NewStreamFactory creates a new instance of StreamFactory. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*StreamFactory) NewStream ¶ added in v0.32.2
func (_m *StreamFactory) NewStream(_a0 context.Context, _a1 peer.ID, _a2 protocol.ID) (network.Stream, error)
NewStream provides a mock function with given fields: _a0, _a1, _a2
func (*StreamFactory) SetStreamHandler ¶ added in v0.32.2
func (_m *StreamFactory) SetStreamHandler(_a0 protocol.ID, _a1 network.StreamHandler)
SetStreamHandler provides a mock function with given fields: _a0, _a1
type Subscription ¶ added in v0.29.0
Subscription is an autogenerated mock type for the Subscription type
func NewSubscription ¶ added in v0.29.0
func NewSubscription(t interface { mock.TestingT Cleanup(func()) }) *Subscription
NewSubscription creates a new instance of Subscription. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*Subscription) Cancel ¶ added in v0.29.0
func (_m *Subscription) Cancel()
Cancel provides a mock function with given fields:
func (*Subscription) Topic ¶ added in v0.29.0
func (_m *Subscription) Topic() string
Topic provides a mock function with given fields:
type SubscriptionFilter ¶ added in v0.29.0
SubscriptionFilter is an autogenerated mock type for the SubscriptionFilter type
func NewSubscriptionFilter ¶ added in v0.29.0
func NewSubscriptionFilter(t interface { mock.TestingT Cleanup(func()) }) *SubscriptionFilter
NewSubscriptionFilter creates a new instance of SubscriptionFilter. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*SubscriptionFilter) CanSubscribe ¶ added in v0.29.0
func (_m *SubscriptionFilter) CanSubscribe(_a0 string) bool
CanSubscribe provides a mock function with given fields: _a0
func (*SubscriptionFilter) FilterIncomingSubscriptions ¶ added in v0.29.0
func (_m *SubscriptionFilter) FilterIncomingSubscriptions(_a0 peer.ID, _a1 []*pubsub_pb.RPC_SubOpts) ([]*pubsub_pb.RPC_SubOpts, error)
FilterIncomingSubscriptions provides a mock function with given fields: _a0, _a1
type SubscriptionProvider ¶
SubscriptionProvider is an autogenerated mock type for the SubscriptionProvider type
func NewSubscriptionProvider ¶
func NewSubscriptionProvider(t interface { mock.TestingT Cleanup(func()) }) *SubscriptionProvider
NewSubscriptionProvider creates a new instance of SubscriptionProvider. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*SubscriptionProvider) Done ¶ added in v0.33.1
func (_m *SubscriptionProvider) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*SubscriptionProvider) GetSubscribedTopics ¶
func (_m *SubscriptionProvider) GetSubscribedTopics(pid peer.ID) []string
GetSubscribedTopics provides a mock function with given fields: pid
func (*SubscriptionProvider) Ready ¶ added in v0.33.1
func (_m *SubscriptionProvider) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*SubscriptionProvider) Start ¶ added in v0.33.1
func (_m *SubscriptionProvider) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
type SubscriptionValidator ¶ added in v0.31.0
SubscriptionValidator is an autogenerated mock type for the SubscriptionValidator type
func NewSubscriptionValidator ¶ added in v0.31.0
func NewSubscriptionValidator(t interface { mock.TestingT Cleanup(func()) }) *SubscriptionValidator
NewSubscriptionValidator creates a new instance of SubscriptionValidator. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*SubscriptionValidator) CheckSubscribedToAllowedTopics ¶ added in v0.31.0
CheckSubscribedToAllowedTopics provides a mock function with given fields: pid, role
func (*SubscriptionValidator) Done ¶ added in v0.33.1
func (_m *SubscriptionValidator) Done() <-chan struct{}
Done provides a mock function with given fields:
func (*SubscriptionValidator) Ready ¶ added in v0.33.1
func (_m *SubscriptionValidator) Ready() <-chan struct{}
Ready provides a mock function with given fields:
func (*SubscriptionValidator) Start ¶ added in v0.33.1
func (_m *SubscriptionValidator) Start(_a0 irrecoverable.SignalerContext)
Start provides a mock function with given fields: _a0
type Subscriptions ¶ added in v0.30.0
Subscriptions is an autogenerated mock type for the Subscriptions type
func NewSubscriptions ¶ added in v0.30.0
func NewSubscriptions(t interface { mock.TestingT Cleanup(func()) }) *Subscriptions
NewSubscriptions creates a new instance of Subscriptions. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*Subscriptions) HasSubscription ¶ added in v0.30.0
func (_m *Subscriptions) HasSubscription(topic channels.Topic) bool
HasSubscription provides a mock function with given fields: topic
func (*Subscriptions) SetUnicastManager ¶ added in v0.30.0
func (_m *Subscriptions) SetUnicastManager(uniMgr p2p.UnicastManager)
SetUnicastManager provides a mock function with given fields: uniMgr
type Topic ¶ added in v0.29.0
Topic is an autogenerated mock type for the Topic type
func NewTopic ¶ added in v0.29.0
NewTopic creates a new instance of Topic. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*Topic) Publish ¶ added in v0.29.0
Publish provides a mock function with given fields: _a0, _a1
type TopicProvider ¶
TopicProvider is an autogenerated mock type for the TopicProvider type
func NewTopicProvider ¶
func NewTopicProvider(t interface { mock.TestingT Cleanup(func()) }) *TopicProvider
NewTopicProvider creates a new instance of TopicProvider. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*TopicProvider) GetTopics ¶
func (_m *TopicProvider) GetTopics() []string
GetTopics provides a mock function with given fields:
type TopicValidatorFunc ¶ added in v0.29.0
TopicValidatorFunc is an autogenerated mock type for the TopicValidatorFunc type
func NewTopicValidatorFunc ¶ added in v0.29.0
func NewTopicValidatorFunc(t interface { mock.TestingT Cleanup(func()) }) *TopicValidatorFunc
NewTopicValidatorFunc creates a new instance of TopicValidatorFunc. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
type UnicastManagement ¶ added in v0.32.0
UnicastManagement is an autogenerated mock type for the UnicastManagement type
func NewUnicastManagement ¶ added in v0.32.0
func NewUnicastManagement(t interface { mock.TestingT Cleanup(func()) }) *UnicastManagement
NewUnicastManagement creates a new instance of UnicastManagement. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*UnicastManagement) OpenAndWriteOnStream ¶ added in v0.33.1
func (_m *UnicastManagement) OpenAndWriteOnStream(ctx context.Context, peerID peer.ID, protectionTag string, writingLogic func(network.Stream) error) error
OpenAndWriteOnStream provides a mock function with given fields: ctx, peerID, protectionTag, writingLogic
func (*UnicastManagement) WithDefaultUnicastProtocol ¶ added in v0.32.0
func (_m *UnicastManagement) WithDefaultUnicastProtocol(defaultHandler network.StreamHandler, preferred []protocols.ProtocolName) error
WithDefaultUnicastProtocol provides a mock function with given fields: defaultHandler, preferred
type UnicastManager ¶ added in v0.30.0
UnicastManager is an autogenerated mock type for the UnicastManager type
func NewUnicastManager ¶ added in v0.30.0
func NewUnicastManager(t interface { mock.TestingT Cleanup(func()) }) *UnicastManager
NewUnicastManager creates a new instance of UnicastManager. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*UnicastManager) CreateStream ¶ added in v0.30.0
CreateStream provides a mock function with given fields: ctx, peerID
func (*UnicastManager) Register ¶ added in v0.30.0
func (_m *UnicastManager) Register(unicast protocols.ProtocolName) error
Register provides a mock function with given fields: unicast
func (*UnicastManager) SetDefaultHandler ¶ added in v0.32.0
func (_m *UnicastManager) SetDefaultHandler(defaultHandler network.StreamHandler)
SetDefaultHandler provides a mock function with given fields: defaultHandler
type UnicastManagerFactoryFunc ¶ added in v0.30.0
UnicastManagerFactoryFunc is an autogenerated mock type for the UnicastManagerFactoryFunc type
func NewUnicastManagerFactoryFunc ¶ added in v0.30.0
func NewUnicastManagerFactoryFunc(t mockConstructorTestingTNewUnicastManagerFactoryFunc) *UnicastManagerFactoryFunc
NewUnicastManagerFactoryFunc creates a new instance of UnicastManagerFactoryFunc. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations.
func (*UnicastManagerFactoryFunc) Execute ¶ added in v0.30.0
func (_m *UnicastManagerFactoryFunc) Execute(logger zerolog.Logger, streamFactory p2p.StreamFactory, sporkId flow.Identifier, createStreamRetryDelay time.Duration, connStatus p2p.PeerConnections, metrics module.UnicastManagerMetrics) p2p.UnicastManager
Execute provides a mock function with given fields: logger, streamFactory, sporkId, createStreamRetryDelay, connStatus, metrics
type UnicastRateLimiterDistributor ¶ added in v0.30.0
UnicastRateLimiterDistributor is an autogenerated mock type for the UnicastRateLimiterDistributor type
func NewUnicastRateLimiterDistributor ¶ added in v0.30.0
func NewUnicastRateLimiterDistributor(t interface { mock.TestingT Cleanup(func()) }) *UnicastRateLimiterDistributor
NewUnicastRateLimiterDistributor creates a new instance of UnicastRateLimiterDistributor. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*UnicastRateLimiterDistributor) AddConsumer ¶ added in v0.30.0
func (_m *UnicastRateLimiterDistributor) AddConsumer(consumer p2p.RateLimiterConsumer)
AddConsumer provides a mock function with given fields: consumer
func (*UnicastRateLimiterDistributor) OnRateLimitedPeer ¶ added in v0.30.0
func (_m *UnicastRateLimiterDistributor) OnRateLimitedPeer(pid peer.ID, role string, msgType string, topic string, reason string)
OnRateLimitedPeer provides a mock function with given fields: pid, role, msgType, topic, reason
type UpdateFunction ¶ added in v0.31.0
UpdateFunction is an autogenerated mock type for the UpdateFunction type
func NewUpdateFunction ¶ added in v0.31.0
func NewUpdateFunction(t interface { mock.TestingT Cleanup(func()) }) *UpdateFunction
NewUpdateFunction creates a new instance of UpdateFunction. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*UpdateFunction) Execute ¶ added in v0.31.0
func (_m *UpdateFunction) Execute(record p2p.GossipSubSpamRecord) p2p.GossipSubSpamRecord
Execute provides a mock function with given fields: record
Source Files ¶
- adjust_function.go
- basic_gossip_sub_rpc_inspector.go
- basic_rate_limiter.go
- collection_cluster_changes_consumer.go
- connection_gater.go
- connector.go
- connector_factory.go
- connector_host.go
- core_p2_p.go
- create_node_func.go
- disallow_list_cache.go
- disallow_list_notification_consumer.go
- disallow_list_oracle.go
- get_time_now.go
- gossip_sub_adapter_config_func.go
- gossip_sub_app_specific_rpc_inspector.go
- gossip_sub_application_specific_score_cache.go
- gossip_sub_builder.go
- gossip_sub_duplicate_message_tracker_cache.go
- gossip_sub_factory_func.go
- gossip_sub_inv_ctrl_msg_notif_consumer.go
- gossip_sub_invalid_control_message_notification_consumer.go
- gossip_sub_rpc_inspector.go
- gossip_sub_rpc_inspector_factory_func.go
- gossip_sub_spam_record_cache.go
- id_translator.go
- inspector_topic_oracle.go
- lib_p2_p_node.go
- network_config_option.go
- network_opt_function.go
- network_option.go
- network_param_option.go
- node_block_list_consumer.go
- node_builder.go
- node_constructor.go
- peer_connections.go
- peer_filter.go
- peer_management.go
- peer_manager.go
- peer_manager_factory_func.go
- peer_score.go
- peer_score_exposer.go
- peer_score_tracer.go
- peer_scoring_builder.go
- peer_updater.go
- peers_provider.go
- protocol_peer_cache.go
- pub_sub.go
- pub_sub_adapter.go
- pub_sub_adapter_config.go
- pub_sub_tracer.go
- rate_limiter.go
- rate_limiter_consumer.go
- rate_limiter_opt.go
- routable.go
- rpc_control_tracking.go
- score_option.go
- score_option_builder.go
- stream_factory.go
- subscription.go
- subscription_filter.go
- subscription_provider.go
- subscription_validator.go
- subscriptions.go
- topic.go
- topic_provider.go
- topic_validator_func.go
- unicast_management.go
- unicast_manager.go
- unicast_manager_factory_func.go
- unicast_rate_limiter_distributor.go
- update_function.go