Documentation ¶
Index ¶
- func NewStreamMock() *streamMock
- type AppStatusHandlerMock
- func (ashm *AppStatusHandlerMock) AddUint64(key string, val uint64)
- func (ashm *AppStatusHandlerMock) Close()
- func (ashm *AppStatusHandlerMock) Decrement(key string)
- func (ashm *AppStatusHandlerMock) GetUint64(key string) uint64
- func (ashm *AppStatusHandlerMock) Increment(key string)
- func (ashm *AppStatusHandlerMock) IsInterfaceNil() bool
- func (ashm *AppStatusHandlerMock) SetInt64Value(key string, value int64)
- func (ashm *AppStatusHandlerMock) SetStringValue(key string, value string)
- func (ashm *AppStatusHandlerMock) SetUInt64Value(key string, value uint64)
- type ChannelLoadBalancerStub
- func (clbs *ChannelLoadBalancerStub) AddChannel(pipe string) error
- func (clbs *ChannelLoadBalancerStub) Close() error
- func (clbs *ChannelLoadBalancerStub) CollectOneElementFromChannels() *p2p.SendableData
- func (clbs *ChannelLoadBalancerStub) GetChannelOrDefault(pipe string) chan *p2p.SendableData
- func (clbs *ChannelLoadBalancerStub) IsInterfaceNil() bool
- func (clbs *ChannelLoadBalancerStub) RemoveChannel(pipe string) error
- type CommonSharder
- type ConnManagerNotifieeStub
- func (cmns *ConnManagerNotifieeStub) Close() error
- func (cmns *ConnManagerNotifieeStub) ClosedStream(netw network.Network, stream network.Stream)
- func (cmns *ConnManagerNotifieeStub) Connected(netw network.Network, conn network.Conn)
- func (cmns *ConnManagerNotifieeStub) Disconnected(netw network.Network, conn network.Conn)
- func (cmns *ConnManagerNotifieeStub) GetTagInfo(p peer.ID) *connmgr.TagInfo
- func (cmns *ConnManagerNotifieeStub) Listen(netw network.Network, ma multiaddr.Multiaddr)
- func (cmns *ConnManagerNotifieeStub) ListenClose(netw network.Network, ma multiaddr.Multiaddr)
- func (cmns *ConnManagerNotifieeStub) Notifee() network.Notifiee
- func (cmns *ConnManagerNotifieeStub) OpenedStream(netw network.Network, stream network.Stream)
- func (cmns *ConnManagerNotifieeStub) Protect(id peer.ID, tag string)
- func (cmns *ConnManagerNotifieeStub) TagPeer(p peer.ID, tag string, val int)
- func (cmns *ConnManagerNotifieeStub) TrimOpenConns(ctx context.Context)
- func (cmns *ConnManagerNotifieeStub) Unprotect(id peer.ID, tag string) (protected bool)
- func (cmns *ConnManagerNotifieeStub) UntagPeer(p peer.ID, tag string)
- func (cmns *ConnManagerNotifieeStub) UpsertTag(p peer.ID, tag string, upsert func(int) int)
- type ConnStub
- func (cs *ConnStub) Close() error
- func (cs *ConnStub) GetStreams() []network.Stream
- func (cs *ConnStub) ID() string
- func (cs *ConnStub) LocalMultiaddr() multiaddr.Multiaddr
- func (cs *ConnStub) LocalPeer() peer.ID
- func (cs *ConnStub) LocalPrivateKey() libp2pCrypto.PrivKey
- func (cs *ConnStub) NewStream(ctx context.Context) (network.Stream, error)
- func (cs *ConnStub) RemoteMultiaddr() multiaddr.Multiaddr
- func (cs *ConnStub) RemotePeer() peer.ID
- func (cs *ConnStub) RemotePublicKey() libp2pCrypto.PubKey
- func (cs *ConnStub) Stat() network.Stat
- type ConnectableHostStub
- func (hs *ConnectableHostStub) Addrs() []multiaddr.Multiaddr
- func (hs *ConnectableHostStub) Close() error
- func (hs *ConnectableHostStub) ConnManager() connmgr.ConnManager
- func (hs *ConnectableHostStub) Connect(ctx context.Context, pi peer.AddrInfo) error
- func (hs *ConnectableHostStub) ConnectToPeer(ctx context.Context, address string) error
- func (hs *ConnectableHostStub) EventBus() event.Bus
- func (hs *ConnectableHostStub) ID() peer.ID
- func (hs *ConnectableHostStub) IsInterfaceNil() bool
- func (hs *ConnectableHostStub) Mux() protocol.Switch
- func (hs *ConnectableHostStub) Network() network.Network
- func (hs *ConnectableHostStub) NewStream(ctx context.Context, p peer.ID, pids ...protocol.ID) (network.Stream, error)
- func (hs *ConnectableHostStub) Peerstore() peerstore.Peerstore
- func (hs *ConnectableHostStub) RemoveStreamHandler(pid protocol.ID)
- func (hs *ConnectableHostStub) SetStreamHandler(pid protocol.ID, handler network.StreamHandler)
- func (hs *ConnectableHostStub) SetStreamHandlerMatch(pid protocol.ID, handler func(string) bool, ...)
- type ConnectionMonitorStub
- func (cms *ConnectionMonitorStub) ClosedStream(netw network.Network, stream network.Stream)
- func (cms *ConnectionMonitorStub) Connected(netw network.Network, conn network.Conn)
- func (cms *ConnectionMonitorStub) Disconnected(netw network.Network, conn network.Conn)
- func (cms *ConnectionMonitorStub) IsConnectedToTheNetwork(netw network.Network) bool
- func (cms *ConnectionMonitorStub) IsInterfaceNil() bool
- func (cms *ConnectionMonitorStub) Listen(netw network.Network, ma multiaddr.Multiaddr)
- func (cms *ConnectionMonitorStub) ListenClose(netw network.Network, ma multiaddr.Multiaddr)
- func (cms *ConnectionMonitorStub) OpenedStream(netw network.Network, stream network.Stream)
- func (cms *ConnectionMonitorStub) SetThresholdMinConnectedPeers(thresholdMinConnectedPeers int, netw network.Network)
- func (cms *ConnectionMonitorStub) ThresholdMinConnectedPeers() int
- type ContextProviderMock
- type EventBusStub
- type EventSubscriptionStub
- type MarshalizerStub
- type MessageProcessorStub
- type MultiaddrStub
- func (mas *MultiaddrStub) Bytes() []byte
- func (mas *MultiaddrStub) Decapsulate(multiaddr multiaddr.Multiaddr) multiaddr.Multiaddr
- func (mas *MultiaddrStub) Encapsulate(multiaddr multiaddr.Multiaddr) multiaddr.Multiaddr
- func (mas *MultiaddrStub) Equal(multiaddr multiaddr.Multiaddr) bool
- func (mas *MultiaddrStub) MarshalBinary() (data []byte, err error)
- func (mas *MultiaddrStub) MarshalJSON() ([]byte, error)
- func (mas *MultiaddrStub) MarshalText() (text []byte, err error)
- func (mas *MultiaddrStub) Protocols() []multiaddr.Protocol
- func (mas *MultiaddrStub) String() string
- func (mas *MultiaddrStub) UnmarshalBinary(data []byte) error
- func (mas *MultiaddrStub) UnmarshalJSON(bytes []byte) error
- func (mas *MultiaddrStub) UnmarshalText(text []byte) error
- func (mas *MultiaddrStub) ValueForProtocol(code int) (string, error)
- type NetworkShardingCollectorStub
- type NetworkStub
- func (ns *NetworkStub) Close() error
- func (ns *NetworkStub) ClosePeer(pid peer.ID) error
- func (ns *NetworkStub) Connectedness(pid peer.ID) network.Connectedness
- func (ns *NetworkStub) Conns() []network.Conn
- func (ns *NetworkStub) ConnsToPeer(p peer.ID) []network.Conn
- func (ns *NetworkStub) DialPeer(_ context.Context, _ peer.ID) (network.Conn, error)
- func (ns *NetworkStub) InterfaceListenAddresses() ([]multiaddr.Multiaddr, error)
- func (ns *NetworkStub) Listen(...multiaddr.Multiaddr) error
- func (ns *NetworkStub) ListenAddresses() []multiaddr.Multiaddr
- func (ns *NetworkStub) LocalPeer() peer.ID
- func (ns *NetworkStub) NewStream(context.Context, peer.ID) (network.Stream, error)
- func (ns *NetworkStub) Notify(notifee network.Notifiee)
- func (ns *NetworkStub) Peers() []peer.ID
- func (ns *NetworkStub) Peerstore() peerstore.Peerstore
- func (ns *NetworkStub) Process() goprocess.Process
- func (ns *NetworkStub) SetConnHandler(network.ConnHandler)
- func (ns *NetworkStub) SetStreamHandler(network.StreamHandler)
- func (ns *NetworkStub) StopNotify(notifee network.Notifiee)
- type P2PMessageMock
- func (msg *P2PMessageMock) Data() []byte
- func (msg *P2PMessageMock) From() []byte
- func (msg *P2PMessageMock) IsInterfaceNil() bool
- func (msg *P2PMessageMock) Key() []byte
- func (msg *P2PMessageMock) Payload() []byte
- func (msg *P2PMessageMock) Peer() core.PeerID
- func (msg *P2PMessageMock) SeqNo() []byte
- func (msg *P2PMessageMock) Signature() []byte
- func (msg *P2PMessageMock) Timestamp() int64
- func (msg *P2PMessageMock) Topic() string
- type PeerDenialEvaluatorStub
- type PeerDiscovererStub
- type PeerShardResolverStub
- type PeerstoreStub
- func (ps *PeerstoreStub) AddAddr(p peer.ID, addr multiaddr.Multiaddr, ttl time.Duration)
- func (ps *PeerstoreStub) AddAddrs(p peer.ID, addrs []multiaddr.Multiaddr, ttl time.Duration)
- func (ps *PeerstoreStub) AddPrivKey(id peer.ID, key libp2pCrypto.PrivKey) error
- func (ps *PeerstoreStub) AddProtocols(id peer.ID, s ...string) error
- func (ps *PeerstoreStub) AddPubKey(id peer.ID, key libp2pCrypto.PubKey) error
- func (ps *PeerstoreStub) AddrStream(ctx context.Context, id peer.ID) <-chan multiaddr.Multiaddr
- func (ps *PeerstoreStub) Addrs(p peer.ID) []multiaddr.Multiaddr
- func (ps *PeerstoreStub) ClearAddrs(p peer.ID)
- func (ps *PeerstoreStub) Close() error
- func (ps *PeerstoreStub) FirstSupportedProtocol(id peer.ID, s ...string) (string, error)
- func (ps *PeerstoreStub) Get(p peer.ID, key string) (interface{}, error)
- func (ps *PeerstoreStub) GetProtocols(id peer.ID) ([]string, error)
- func (ps *PeerstoreStub) LatencyEWMA(id peer.ID) time.Duration
- func (ps *PeerstoreStub) PeerInfo(id peer.ID) peer.AddrInfo
- func (ps *PeerstoreStub) Peers() peer.IDSlice
- func (ps *PeerstoreStub) PeersWithAddrs() peer.IDSlice
- func (ps *PeerstoreStub) PeersWithKeys() peer.IDSlice
- func (ps *PeerstoreStub) PrivKey(id peer.ID) libp2pCrypto.PrivKey
- func (ps *PeerstoreStub) PubKey(id peer.ID) libp2pCrypto.PubKey
- func (ps *PeerstoreStub) Put(p peer.ID, key string, val interface{}) error
- func (ps *PeerstoreStub) RecordLatency(id peer.ID, duration time.Duration)
- func (ps *PeerstoreStub) RemoveProtocols(id peer.ID, s ...string) error
- func (ps *PeerstoreStub) SetAddr(p peer.ID, addr multiaddr.Multiaddr, ttl time.Duration)
- func (ps *PeerstoreStub) SetAddrs(p peer.ID, addrs []multiaddr.Multiaddr, ttl time.Duration)
- func (ps *PeerstoreStub) SetProtocols(id peer.ID, s ...string) error
- func (ps *PeerstoreStub) SupportsProtocols(id peer.ID, s ...string) ([]string, error)
- func (ps *PeerstoreStub) UpdateAddrs(p peer.ID, oldTTL time.Duration, newTTL time.Duration)
- type ReconnecterStub
- type SharderStub
- type SignerVerifierStub
- type SyncTimerStub
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
Types ¶
type AppStatusHandlerMock ¶
type AppStatusHandlerMock struct {
// contains filtered or unexported fields
}
AppStatusHandlerMock -
func NewAppStatusHandlerMock ¶
func NewAppStatusHandlerMock() *AppStatusHandlerMock
NewAppStatusHandlerMock -
func (*AppStatusHandlerMock) AddUint64 ¶
func (ashm *AppStatusHandlerMock) AddUint64(key string, val uint64)
AddUint64 -
func (*AppStatusHandlerMock) Decrement ¶
func (ashm *AppStatusHandlerMock) Decrement(key string)
Decrement -
func (*AppStatusHandlerMock) GetUint64 ¶
func (ashm *AppStatusHandlerMock) GetUint64(key string) uint64
GetUint64 -
func (*AppStatusHandlerMock) Increment ¶
func (ashm *AppStatusHandlerMock) Increment(key string)
Increment -
func (*AppStatusHandlerMock) IsInterfaceNil ¶
func (ashm *AppStatusHandlerMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*AppStatusHandlerMock) SetInt64Value ¶
func (ashm *AppStatusHandlerMock) SetInt64Value(key string, value int64)
SetInt64Value -
func (*AppStatusHandlerMock) SetStringValue ¶
func (ashm *AppStatusHandlerMock) SetStringValue(key string, value string)
SetStringValue -
func (*AppStatusHandlerMock) SetUInt64Value ¶
func (ashm *AppStatusHandlerMock) SetUInt64Value(key string, value uint64)
SetUInt64Value -
type ChannelLoadBalancerStub ¶
type ChannelLoadBalancerStub struct { AddChannelCalled func(pipe string) error RemoveChannelCalled func(pipe string) error GetChannelOrDefaultCalled func(pipe string) chan *p2p.SendableData CollectOneElementFromChannelsCalled func() *p2p.SendableData CloseCalled func() error }
ChannelLoadBalancerStub -
func (*ChannelLoadBalancerStub) AddChannel ¶
func (clbs *ChannelLoadBalancerStub) AddChannel(pipe string) error
AddChannel -
func (*ChannelLoadBalancerStub) Close ¶ added in v1.0.115
func (clbs *ChannelLoadBalancerStub) Close() error
Close -
func (*ChannelLoadBalancerStub) CollectOneElementFromChannels ¶
func (clbs *ChannelLoadBalancerStub) CollectOneElementFromChannels() *p2p.SendableData
CollectOneElementFromChannels -
func (*ChannelLoadBalancerStub) GetChannelOrDefault ¶
func (clbs *ChannelLoadBalancerStub) GetChannelOrDefault(pipe string) chan *p2p.SendableData
GetChannelOrDefault -
func (*ChannelLoadBalancerStub) IsInterfaceNil ¶
func (clbs *ChannelLoadBalancerStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ChannelLoadBalancerStub) RemoveChannel ¶
func (clbs *ChannelLoadBalancerStub) RemoveChannel(pipe string) error
RemoveChannel -
type CommonSharder ¶
type CommonSharder struct {
SetPeerShardResolverCalled func(psp p2p.PeerShardResolver) error
}
CommonSharder -
func (*CommonSharder) IsInterfaceNil ¶
func (cs *CommonSharder) IsInterfaceNil() bool
IsInterfaceNil -
func (*CommonSharder) SetPeerShardResolver ¶
func (cs *CommonSharder) SetPeerShardResolver(psp p2p.PeerShardResolver) error
SetPeerShardResolver -
type ConnManagerNotifieeStub ¶
type ConnManagerNotifieeStub struct { UpsertTagCalled func(p peer.ID, tag string, upsert func(int) int) ProtectCalled func(id peer.ID, tag string) UnprotectCalled func(id peer.ID, tag string) (protected bool) CloseCalled func() error TagPeerCalled func(p peer.ID, tag string, val int) UntagPeerCalled func(p peer.ID, tag string) GetTagInfoCalled func(p peer.ID) *connmgr.TagInfo TrimOpenConnsCalled func(ctx context.Context) ListenCalled func(netw network.Network, ma multiaddr.Multiaddr) ListenCloseCalled func(netw network.Network, ma multiaddr.Multiaddr) ConnectedCalled func(netw network.Network, conn network.Conn) DisconnectedCalled func(netw network.Network, conn network.Conn) OpenedStreamCalled func(netw network.Network, stream network.Stream) ClosedStreamCalled func(netw network.Network, stream network.Stream) }
ConnManagerNotifieeStub -
func (*ConnManagerNotifieeStub) ClosedStream ¶
func (cmns *ConnManagerNotifieeStub) ClosedStream(netw network.Network, stream network.Stream)
ClosedStream -
func (*ConnManagerNotifieeStub) Connected ¶
func (cmns *ConnManagerNotifieeStub) Connected(netw network.Network, conn network.Conn)
Connected -
func (*ConnManagerNotifieeStub) Disconnected ¶
func (cmns *ConnManagerNotifieeStub) Disconnected(netw network.Network, conn network.Conn)
Disconnected -
func (*ConnManagerNotifieeStub) GetTagInfo ¶
func (cmns *ConnManagerNotifieeStub) GetTagInfo(p peer.ID) *connmgr.TagInfo
GetTagInfo -
func (*ConnManagerNotifieeStub) Listen ¶
func (cmns *ConnManagerNotifieeStub) Listen(netw network.Network, ma multiaddr.Multiaddr)
Listen -
func (*ConnManagerNotifieeStub) ListenClose ¶
func (cmns *ConnManagerNotifieeStub) ListenClose(netw network.Network, ma multiaddr.Multiaddr)
ListenClose -
func (*ConnManagerNotifieeStub) Notifee ¶
func (cmns *ConnManagerNotifieeStub) Notifee() network.Notifiee
Notifee -
func (*ConnManagerNotifieeStub) OpenedStream ¶
func (cmns *ConnManagerNotifieeStub) OpenedStream(netw network.Network, stream network.Stream)
OpenedStream -
func (*ConnManagerNotifieeStub) Protect ¶
func (cmns *ConnManagerNotifieeStub) Protect(id peer.ID, tag string)
Protect -
func (*ConnManagerNotifieeStub) TagPeer ¶
func (cmns *ConnManagerNotifieeStub) TagPeer(p peer.ID, tag string, val int)
TagPeer -
func (*ConnManagerNotifieeStub) TrimOpenConns ¶
func (cmns *ConnManagerNotifieeStub) TrimOpenConns(ctx context.Context)
TrimOpenConns -
func (*ConnManagerNotifieeStub) Unprotect ¶
func (cmns *ConnManagerNotifieeStub) Unprotect(id peer.ID, tag string) (protected bool)
Unprotect -
type ConnStub ¶
type ConnStub struct { IDCalled func() string CloseCalled func() error LocalPeerCalled func() peer.ID LocalPrivateKeyCalled func() libp2pCrypto.PrivKey RemotePeerCalled func() peer.ID RemotePublicKeyCalled func() libp2pCrypto.PubKey LocalMultiaddrCalled func() multiaddr.Multiaddr RemoteMultiaddrCalled func() multiaddr.Multiaddr NewStreamCalled func(ctx context.Context) (network.Stream, error) GetStreamsCalled func() []network.Stream StatCalled func() network.Stat }
ConnStub -
func (*ConnStub) LocalMultiaddr ¶
func (cs *ConnStub) LocalMultiaddr() multiaddr.Multiaddr
LocalMultiaddr -
func (*ConnStub) LocalPrivateKey ¶
func (cs *ConnStub) LocalPrivateKey() libp2pCrypto.PrivKey
LocalPrivateKey -
func (*ConnStub) RemoteMultiaddr ¶
func (cs *ConnStub) RemoteMultiaddr() multiaddr.Multiaddr
RemoteMultiaddr -
func (*ConnStub) RemotePublicKey ¶
func (cs *ConnStub) RemotePublicKey() libp2pCrypto.PubKey
RemotePublicKey -
type ConnectableHostStub ¶
type ConnectableHostStub struct { EventBusCalled func() event.Bus IDCalled func() peer.ID PeerstoreCalled func() peerstore.Peerstore AddrsCalled func() []multiaddr.Multiaddr NetworkCalled func() network.Network MuxCalled func() protocol.Switch ConnectCalled func(ctx context.Context, pi peer.AddrInfo) error SetStreamHandlerCalled func(pid protocol.ID, handler network.StreamHandler) SetStreamHandlerMatchCalled func(protocol.ID, func(string) bool, network.StreamHandler) RemoveStreamHandlerCalled func(pid protocol.ID) NewStreamCalled func(ctx context.Context, p peer.ID, pids ...protocol.ID) (network.Stream, error) CloseCalled func() error ConnManagerCalled func() connmgr.ConnManager ConnectToPeerCalled func(ctx context.Context, address string) error }
ConnectableHostStub -
func (*ConnectableHostStub) Addrs ¶
func (hs *ConnectableHostStub) Addrs() []multiaddr.Multiaddr
Addrs -
func (*ConnectableHostStub) ConnManager ¶
func (hs *ConnectableHostStub) ConnManager() connmgr.ConnManager
ConnManager -
func (*ConnectableHostStub) ConnectToPeer ¶
func (hs *ConnectableHostStub) ConnectToPeer(ctx context.Context, address string) error
ConnectToPeer -
func (*ConnectableHostStub) EventBus ¶
func (hs *ConnectableHostStub) EventBus() event.Bus
EventBus -
func (*ConnectableHostStub) IsInterfaceNil ¶
func (hs *ConnectableHostStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ConnectableHostStub) Network ¶
func (hs *ConnectableHostStub) Network() network.Network
Network -
func (*ConnectableHostStub) NewStream ¶
func (hs *ConnectableHostStub) NewStream(ctx context.Context, p peer.ID, pids ...protocol.ID) (network.Stream, error)
NewStream -
func (*ConnectableHostStub) Peerstore ¶
func (hs *ConnectableHostStub) Peerstore() peerstore.Peerstore
Peerstore -
func (*ConnectableHostStub) RemoveStreamHandler ¶
func (hs *ConnectableHostStub) RemoveStreamHandler(pid protocol.ID)
RemoveStreamHandler -
func (*ConnectableHostStub) SetStreamHandler ¶
func (hs *ConnectableHostStub) SetStreamHandler(pid protocol.ID, handler network.StreamHandler)
SetStreamHandler -
func (*ConnectableHostStub) SetStreamHandlerMatch ¶
func (hs *ConnectableHostStub) SetStreamHandlerMatch(pid protocol.ID, handler func(string) bool, streamHandler network.StreamHandler)
SetStreamHandlerMatch -
type ConnectionMonitorStub ¶
type ConnectionMonitorStub struct { ListenCalled func(netw network.Network, ma multiaddr.Multiaddr) ListenCloseCalled func(netw network.Network, ma multiaddr.Multiaddr) ConnectedCalled func(netw network.Network, conn network.Conn) DisconnectedCalled func(netw network.Network, conn network.Conn) OpenedStreamCalled func(netw network.Network, stream network.Stream) ClosedStreamCalled func(netw network.Network, stream network.Stream) IsConnectedToTheNetworkCalled func(netw network.Network) bool SetThresholdMinConnectedPeersCalled func(thresholdMinConnectedPeers int, netw network.Network) ThresholdMinConnectedPeersCalled func() int }
ConnectionMonitorStub -
func (*ConnectionMonitorStub) ClosedStream ¶
func (cms *ConnectionMonitorStub) ClosedStream(netw network.Network, stream network.Stream)
ClosedStream -
func (*ConnectionMonitorStub) Connected ¶
func (cms *ConnectionMonitorStub) Connected(netw network.Network, conn network.Conn)
Connected -
func (*ConnectionMonitorStub) Disconnected ¶
func (cms *ConnectionMonitorStub) Disconnected(netw network.Network, conn network.Conn)
Disconnected -
func (*ConnectionMonitorStub) IsConnectedToTheNetwork ¶
func (cms *ConnectionMonitorStub) IsConnectedToTheNetwork(netw network.Network) bool
IsConnectedToTheNetwork -
func (*ConnectionMonitorStub) IsInterfaceNil ¶
func (cms *ConnectionMonitorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*ConnectionMonitorStub) Listen ¶
func (cms *ConnectionMonitorStub) Listen(netw network.Network, ma multiaddr.Multiaddr)
Listen -
func (*ConnectionMonitorStub) ListenClose ¶
func (cms *ConnectionMonitorStub) ListenClose(netw network.Network, ma multiaddr.Multiaddr)
ListenClose -
func (*ConnectionMonitorStub) OpenedStream ¶
func (cms *ConnectionMonitorStub) OpenedStream(netw network.Network, stream network.Stream)
OpenedStream -
func (*ConnectionMonitorStub) SetThresholdMinConnectedPeers ¶
func (cms *ConnectionMonitorStub) SetThresholdMinConnectedPeers(thresholdMinConnectedPeers int, netw network.Network)
SetThresholdMinConnectedPeers -
func (*ConnectionMonitorStub) ThresholdMinConnectedPeers ¶
func (cms *ConnectionMonitorStub) ThresholdMinConnectedPeers() int
ThresholdMinConnectedPeers -
type ContextProviderMock ¶
type ContextProviderMock struct { }
ContextProviderMock -
func (*ContextProviderMock) Context ¶
func (*ContextProviderMock) Context() context.Context
Context -
func (*ContextProviderMock) IsInterfaceNil ¶
func (c *ContextProviderMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type EventBusStub ¶ added in v1.0.114
type EventBusStub struct { SubscribeCalled func(eventType interface{}, opts ...event.SubscriptionOpt) (event.Subscription, error) EmitterCalled func(eventType interface{}, opts ...event.EmitterOpt) (event.Emitter, error) GetAllEventTypesCalled func() []reflect.Type }
EventBusStub -
func (*EventBusStub) Emitter ¶ added in v1.0.114
func (ebs *EventBusStub) Emitter(eventType interface{}, opts ...event.EmitterOpt) (event.Emitter, error)
Emitter -
func (*EventBusStub) GetAllEventTypes ¶ added in v1.0.132
func (ebs *EventBusStub) GetAllEventTypes() []reflect.Type
GetAllEventTypes -
func (*EventBusStub) Subscribe ¶ added in v1.0.114
func (ebs *EventBusStub) Subscribe(eventType interface{}, opts ...event.SubscriptionOpt) (event.Subscription, error)
Subscribe -
type EventSubscriptionStub ¶ added in v1.0.114
type EventSubscriptionStub struct { CloseCalled func() error OutCalled func() <-chan interface{} }
EventSubscriptionStub -
func (*EventSubscriptionStub) Close ¶ added in v1.0.114
func (ess *EventSubscriptionStub) Close() error
Close -
func (*EventSubscriptionStub) Out ¶ added in v1.0.114
func (ess *EventSubscriptionStub) Out() <-chan interface{}
Out -
type MarshalizerStub ¶
type MarshalizerStub struct { MarshalCalled func(obj interface{}) ([]byte, error) UnmarshalCalled func(obj interface{}, buff []byte) error }
MarshalizerStub -
func (*MarshalizerStub) IsInterfaceNil ¶
func (ms *MarshalizerStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*MarshalizerStub) Marshal ¶
func (ms *MarshalizerStub) Marshal(obj interface{}) ([]byte, error)
Marshal -
func (*MarshalizerStub) Unmarshal ¶
func (ms *MarshalizerStub) Unmarshal(obj interface{}, buff []byte) error
Unmarshal -
type MessageProcessorStub ¶
type MessageProcessorStub struct {
ProcessMessageCalled func(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error
}
MessageProcessorStub -
func (*MessageProcessorStub) IsInterfaceNil ¶
func (mps *MessageProcessorStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*MessageProcessorStub) ProcessReceivedMessage ¶
func (mps *MessageProcessorStub) ProcessReceivedMessage(message p2p.MessageP2P, fromConnectedPeer core.PeerID) error
ProcessReceivedMessage -
type MultiaddrStub ¶ added in v1.1.28
type MultiaddrStub struct { MarshalJSONCalled func() ([]byte, error) UnmarshalJSONCalled func(bytes []byte) error MarshalTextCalled func() (text []byte, err error) UnmarshalTextCalled func(text []byte) error MarshalBinaryCalled func() (data []byte, err error) UnmarshalBinaryCalled func(data []byte) error EqualCalled func(multiaddr multiaddr.Multiaddr) bool BytesCalled func() []byte StringCalled func() string ProtocolsCalled func() []multiaddr.Protocol EncapsulateCalled func(multiaddr multiaddr.Multiaddr) multiaddr.Multiaddr DecapsulateCalled func(multiaddr multiaddr.Multiaddr) multiaddr.Multiaddr ValueForProtocolCalled func(code int) (string, error) }
MultiaddrStub -
func (*MultiaddrStub) Decapsulate ¶ added in v1.1.28
func (mas *MultiaddrStub) Decapsulate(multiaddr multiaddr.Multiaddr) multiaddr.Multiaddr
Decapsulate -
func (*MultiaddrStub) Encapsulate ¶ added in v1.1.28
func (mas *MultiaddrStub) Encapsulate(multiaddr multiaddr.Multiaddr) multiaddr.Multiaddr
Encapsulate -
func (*MultiaddrStub) Equal ¶ added in v1.1.28
func (mas *MultiaddrStub) Equal(multiaddr multiaddr.Multiaddr) bool
Equal -
func (*MultiaddrStub) MarshalBinary ¶ added in v1.1.28
func (mas *MultiaddrStub) MarshalBinary() (data []byte, err error)
MarshalBinary -
func (*MultiaddrStub) MarshalJSON ¶ added in v1.1.28
func (mas *MultiaddrStub) MarshalJSON() ([]byte, error)
MarshalJSON -
func (*MultiaddrStub) MarshalText ¶ added in v1.1.28
func (mas *MultiaddrStub) MarshalText() (text []byte, err error)
MarshalText -
func (*MultiaddrStub) Protocols ¶ added in v1.1.28
func (mas *MultiaddrStub) Protocols() []multiaddr.Protocol
Protocols -
func (*MultiaddrStub) UnmarshalBinary ¶ added in v1.1.28
func (mas *MultiaddrStub) UnmarshalBinary(data []byte) error
UnmarshalBinary -
func (*MultiaddrStub) UnmarshalJSON ¶ added in v1.1.28
func (mas *MultiaddrStub) UnmarshalJSON(bytes []byte) error
UnmarshalJSON -
func (*MultiaddrStub) UnmarshalText ¶ added in v1.1.28
func (mas *MultiaddrStub) UnmarshalText(text []byte) error
UnmarshalText -
func (*MultiaddrStub) ValueForProtocol ¶ added in v1.1.28
func (mas *MultiaddrStub) ValueForProtocol(code int) (string, error)
ValueForProtocol -
type NetworkShardingCollectorStub ¶
type NetworkShardingCollectorStub struct {
UpdatePeerIdPublicKeyCalled func(pid core.PeerID, pk []byte)
}
NetworkShardingCollectorStub -
func (*NetworkShardingCollectorStub) IsInterfaceNil ¶
func (nscs *NetworkShardingCollectorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*NetworkShardingCollectorStub) UpdatePeerIdPublicKey ¶
func (nscs *NetworkShardingCollectorStub) UpdatePeerIdPublicKey(pid core.PeerID, pk []byte)
UpdatePeerIdPublicKey -
type NetworkStub ¶
type NetworkStub struct { ConnsToPeerCalled func(p peer.ID) []network.Conn ConnsCalled func() []network.Conn ConnectednessCalled func(peer.ID) network.Connectedness NotifyCalled func(network.Notifiee) StopNotifyCalled func(network.Notifiee) PeersCall func() []peer.ID ClosePeerCall func(peer.ID) error }
NetworkStub -
func (*NetworkStub) Connectedness ¶
func (ns *NetworkStub) Connectedness(pid peer.ID) network.Connectedness
Connectedness -
func (*NetworkStub) ConnsToPeer ¶
func (ns *NetworkStub) ConnsToPeer(p peer.ID) []network.Conn
ConnsToPeer -
func (*NetworkStub) InterfaceListenAddresses ¶
func (ns *NetworkStub) InterfaceListenAddresses() ([]multiaddr.Multiaddr, error)
InterfaceListenAddresses -
func (*NetworkStub) ListenAddresses ¶
func (ns *NetworkStub) ListenAddresses() []multiaddr.Multiaddr
ListenAddresses -
func (*NetworkStub) SetConnHandler ¶
func (ns *NetworkStub) SetConnHandler(network.ConnHandler)
SetConnHandler -
func (*NetworkStub) SetStreamHandler ¶
func (ns *NetworkStub) SetStreamHandler(network.StreamHandler)
SetStreamHandler -
func (*NetworkStub) StopNotify ¶
func (ns *NetworkStub) StopNotify(notifee network.Notifiee)
StopNotify -
type P2PMessageMock ¶
type P2PMessageMock struct { FromField []byte DataField []byte SeqNoField []byte TopicField string SignatureField []byte KeyField []byte PeerField core.PeerID PayloadField []byte TimestampField int64 }
P2PMessageMock -
func (*P2PMessageMock) IsInterfaceNil ¶
func (msg *P2PMessageMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*P2PMessageMock) Payload ¶ added in v1.0.133
func (msg *P2PMessageMock) Payload() []byte
Payload -
func (*P2PMessageMock) Timestamp ¶ added in v1.0.133
func (msg *P2PMessageMock) Timestamp() int64
Timestamp -
type PeerDenialEvaluatorStub ¶ added in v1.0.133
type PeerDenialEvaluatorStub struct { UpsertPeerIDCalled func(pid core.PeerID, duration time.Duration) error IsDeniedCalled func(pid core.PeerID) bool }
PeerDenialEvaluatorStub -
func (*PeerDenialEvaluatorStub) IsDenied ¶ added in v1.0.133
func (pdes *PeerDenialEvaluatorStub) IsDenied(pid core.PeerID) bool
IsDenied -
func (*PeerDenialEvaluatorStub) IsInterfaceNil ¶ added in v1.0.133
func (pdes *PeerDenialEvaluatorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*PeerDenialEvaluatorStub) UpsertPeerID ¶ added in v1.0.133
UpsertPeerID -
type PeerDiscovererStub ¶
PeerDiscovererStub -
func (*PeerDiscovererStub) IsInterfaceNil ¶
func (pds *PeerDiscovererStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type PeerShardResolverStub ¶
type PeerShardResolverStub struct {
GetPeerInfoCalled func(pid core.PeerID) core.P2PPeerInfo
}
PeerShardResolverStub -
func (*PeerShardResolverStub) GetPeerInfo ¶
func (psrs *PeerShardResolverStub) GetPeerInfo(pid core.PeerID) core.P2PPeerInfo
GetPeerInfo -
func (*PeerShardResolverStub) IsInterfaceNil ¶
func (psrs *PeerShardResolverStub) IsInterfaceNil() bool
IsInterfaceNil -
type PeerstoreStub ¶ added in v1.1.28
type PeerstoreStub struct { CloseCalled func() error AddAddrCalled func(p peer.ID, addr multiaddr.Multiaddr, ttl time.Duration) AddAddrsCalled func(p peer.ID, addrs []multiaddr.Multiaddr, ttl time.Duration) SetAddrCalled func(p peer.ID, addr multiaddr.Multiaddr, ttl time.Duration) SetAddrsCalled func(p peer.ID, addrs []multiaddr.Multiaddr, ttl time.Duration) UpdateAddrsCalled func(p peer.ID, oldTTL time.Duration, newTTL time.Duration) AddrsCalled func(p peer.ID) []multiaddr.Multiaddr AddrStreamCalled func(ctx context.Context, id peer.ID) <-chan multiaddr.Multiaddr ClearAddrsCalled func(p peer.ID) PeersWithAddrsCalled func() peer.IDSlice PubKeyCalled func(id peer.ID) libp2pCrypto.PubKey AddPubKeyCalled func(id peer.ID, key libp2pCrypto.PubKey) error PrivKeyCalled func(id peer.ID) libp2pCrypto.PrivKey AddPrivKeyCalled func(id peer.ID, key libp2pCrypto.PrivKey) error PeersWithKeysCalled func() peer.IDSlice GetCalled func(p peer.ID, key string) (interface{}, error) PutCalled func(p peer.ID, key string, val interface{}) error RecordLatencyCalled func(id peer.ID, duration time.Duration) LatencyEWMACalled func(id peer.ID) time.Duration GetProtocolsCalled func(id peer.ID) ([]string, error) AddProtocolsCalled func(id peer.ID, s ...string) error SetProtocolsCalled func(id peer.ID, s ...string) error RemoveProtocolsCalled func(id peer.ID, s ...string) error SupportsProtocolsCalled func(id peer.ID, s ...string) ([]string, error) FirstSupportedProtocolCalled func(id peer.ID, s ...string) (string, error) PeerInfoCalled func(id peer.ID) peer.AddrInfo PeersCalled func() peer.IDSlice }
PeerstoreStub -
func (*PeerstoreStub) AddAddr ¶ added in v1.1.28
func (ps *PeerstoreStub) AddAddr(p peer.ID, addr multiaddr.Multiaddr, ttl time.Duration)
AddAddr -
func (*PeerstoreStub) AddAddrs ¶ added in v1.1.28
func (ps *PeerstoreStub) AddAddrs(p peer.ID, addrs []multiaddr.Multiaddr, ttl time.Duration)
AddAddrs -
func (*PeerstoreStub) AddPrivKey ¶ added in v1.1.28
func (ps *PeerstoreStub) AddPrivKey(id peer.ID, key libp2pCrypto.PrivKey) error
AddPrivKey -
func (*PeerstoreStub) AddProtocols ¶ added in v1.1.28
func (ps *PeerstoreStub) AddProtocols(id peer.ID, s ...string) error
AddProtocols -
func (*PeerstoreStub) AddPubKey ¶ added in v1.1.28
func (ps *PeerstoreStub) AddPubKey(id peer.ID, key libp2pCrypto.PubKey) error
AddPubKey -
func (*PeerstoreStub) AddrStream ¶ added in v1.1.28
func (ps *PeerstoreStub) AddrStream(ctx context.Context, id peer.ID) <-chan multiaddr.Multiaddr
AddrStream -
func (*PeerstoreStub) Addrs ¶ added in v1.1.28
func (ps *PeerstoreStub) Addrs(p peer.ID) []multiaddr.Multiaddr
Addrs -
func (*PeerstoreStub) ClearAddrs ¶ added in v1.1.28
func (ps *PeerstoreStub) ClearAddrs(p peer.ID)
ClearAddrs -
func (*PeerstoreStub) FirstSupportedProtocol ¶ added in v1.1.28
FirstSupportedProtocol -
func (*PeerstoreStub) Get ¶ added in v1.1.28
func (ps *PeerstoreStub) Get(p peer.ID, key string) (interface{}, error)
Get -
func (*PeerstoreStub) GetProtocols ¶ added in v1.1.28
func (ps *PeerstoreStub) GetProtocols(id peer.ID) ([]string, error)
GetProtocols -
func (*PeerstoreStub) LatencyEWMA ¶ added in v1.1.28
func (ps *PeerstoreStub) LatencyEWMA(id peer.ID) time.Duration
LatencyEWMA -
func (*PeerstoreStub) PeerInfo ¶ added in v1.1.28
func (ps *PeerstoreStub) PeerInfo(id peer.ID) peer.AddrInfo
PeerInfo -
func (*PeerstoreStub) Peers ¶ added in v1.1.28
func (ps *PeerstoreStub) Peers() peer.IDSlice
Peers -
func (*PeerstoreStub) PeersWithAddrs ¶ added in v1.1.28
func (ps *PeerstoreStub) PeersWithAddrs() peer.IDSlice
PeersWithAddrs -
func (*PeerstoreStub) PeersWithKeys ¶ added in v1.1.28
func (ps *PeerstoreStub) PeersWithKeys() peer.IDSlice
PeersWithKeys -
func (*PeerstoreStub) PrivKey ¶ added in v1.1.28
func (ps *PeerstoreStub) PrivKey(id peer.ID) libp2pCrypto.PrivKey
PrivKey -
func (*PeerstoreStub) PubKey ¶ added in v1.1.28
func (ps *PeerstoreStub) PubKey(id peer.ID) libp2pCrypto.PubKey
PubKey -
func (*PeerstoreStub) Put ¶ added in v1.1.28
func (ps *PeerstoreStub) Put(p peer.ID, key string, val interface{}) error
Put -
func (*PeerstoreStub) RecordLatency ¶ added in v1.1.28
func (ps *PeerstoreStub) RecordLatency(id peer.ID, duration time.Duration)
RecordLatency -
func (*PeerstoreStub) RemoveProtocols ¶ added in v1.1.28
func (ps *PeerstoreStub) RemoveProtocols(id peer.ID, s ...string) error
RemoveProtocols -
func (*PeerstoreStub) SetAddr ¶ added in v1.1.28
func (ps *PeerstoreStub) SetAddr(p peer.ID, addr multiaddr.Multiaddr, ttl time.Duration)
SetAddr -
func (*PeerstoreStub) SetAddrs ¶ added in v1.1.28
func (ps *PeerstoreStub) SetAddrs(p peer.ID, addrs []multiaddr.Multiaddr, ttl time.Duration)
SetAddrs -
func (*PeerstoreStub) SetProtocols ¶ added in v1.1.28
func (ps *PeerstoreStub) SetProtocols(id peer.ID, s ...string) error
SetProtocols -
func (*PeerstoreStub) SupportsProtocols ¶ added in v1.1.28
SupportsProtocols -
func (*PeerstoreStub) UpdateAddrs ¶ added in v1.1.28
UpdateAddrs -
type ReconnecterStub ¶
type ReconnecterStub struct { ReconnectToNetworkCalled func() <-chan struct{} PauseCall func() ResumeCall func() }
ReconnecterStub -
func (*ReconnecterStub) IsInterfaceNil ¶
func (rs *ReconnecterStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ReconnecterStub) ReconnectToNetwork ¶
func (rs *ReconnecterStub) ReconnectToNetwork() <-chan struct{}
ReconnectToNetwork -
type SharderStub ¶
type SharderStub struct { ComputeEvictListCalled func(pidList []peer.ID) []peer.ID HasCalled func(pid peer.ID, list []peer.ID) bool SetPeerShardResolverCalled func(psp p2p.PeerShardResolver) error }
SharderStub -
func (*SharderStub) ComputeEvictionList ¶
func (ss *SharderStub) ComputeEvictionList(pidList []peer.ID) []peer.ID
ComputeEvictionList -
func (*SharderStub) SetPeerShardResolver ¶
func (ss *SharderStub) SetPeerShardResolver(psp p2p.PeerShardResolver) error
SetPeerShardResolver -
type SignerVerifierStub ¶
type SignerVerifierStub struct { SignCalled func(message []byte) ([]byte, error) VerifyCalled func(message []byte, sig []byte, pk []byte) error PublicKeyCalled func() []byte }
SignerVerifierStub -
func (*SignerVerifierStub) IsInterfaceNil ¶
func (svs *SignerVerifierStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*SignerVerifierStub) PublicKey ¶
func (svs *SignerVerifierStub) PublicKey() []byte
PublicKey -
type SyncTimerStub ¶ added in v1.0.150
SyncTimerStub -
func (*SyncTimerStub) CurrentTime ¶ added in v1.0.150
func (sts *SyncTimerStub) CurrentTime() time.Time
CurrentTime -
func (*SyncTimerStub) IsInterfaceNil ¶ added in v1.0.150
func (sts *SyncTimerStub) IsInterfaceNil() bool
IsInterfaceNil -
Source Files ¶
- appStatusHandlerMock.go
- channelLoadBalancerStub.go
- commonSharder.go
- connManagerNotifieeStub.go
- connStub.go
- connectableHostStub.go
- connectionMonitorStub.go
- contextProviderMock.go
- eventBusStub.go
- eventSubscriptionStub.go
- marshalizerStub.go
- messageProcessorStub.go
- multiaddrStub.go
- networkShardingCollectorStub.go
- networkStub.go
- p2pMessageMock.go
- peerDenialEvaluatorStub.go
- peerDiscovererStub.go
- peerShardResolverStub.go
- peerstoreStub.go
- reconnecterStub.go
- sharderStub.go
- signerVerifierStub.go
- streamMock.go
- syncTimerStub.go