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 BlacklistHandlerStub
- type ChannelLoadBalancerStub
- func (clbs *ChannelLoadBalancerStub) AddChannel(pipe string) 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) LocalMultiaddr() multiaddr.Multiaddr
- func (cs *ConnStub) LocalPeer() peer.ID
- func (cs *ConnStub) LocalPrivateKey() libp2pCrypto.PrivKey
- func (cs *ConnStub) NewStream() (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 MarshalizerStub
- type MessageProcessorStub
- 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 NilBlacklistHandler
- 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) Peer() p2p.PeerID
- func (msg *P2PMessageMock) SeqNo() []byte
- func (msg *P2PMessageMock) Signature() []byte
- func (msg *P2PMessageMock) Topics() []string
- type PeerDiscovererStub
- type PeerShardResolverStub
- type PrioSharderStub
- func (pss *PrioSharderStub) GetDistance(a, b sorting.SortedID) *big.Int
- func (pss *PrioSharderStub) GetShard(id peer.ID) uint32
- func (pss *PrioSharderStub) IsInterfaceNil() bool
- func (pss *PrioSharderStub) SetPeerShardResolver(psp p2p.PeerShardResolver) error
- func (pss *PrioSharderStub) SortList(peers []peer.ID, ref peer.ID) ([]peer.ID, bool)
- type ReconnecterStub
- type ReconnecterWithPauseAndResumeStub
- func (rs *ReconnecterWithPauseAndResumeStub) IsInterfaceNil() bool
- func (rs *ReconnecterWithPauseAndResumeStub) KickWatchdog() error
- func (rs *ReconnecterWithPauseAndResumeStub) Pause()
- func (rs *ReconnecterWithPauseAndResumeStub) ReconnectToNetwork() <-chan struct{}
- func (rs *ReconnecterWithPauseAndResumeStub) Resume()
- func (rs *ReconnecterWithPauseAndResumeStub) StartWatchdog(time.Duration) error
- func (rs *ReconnecterWithPauseAndResumeStub) StopWatchdog() error
- type SharderStub
- type SignerVerifierStub
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 BlacklistHandlerStub ¶
func (*BlacklistHandlerStub) Has ¶
func (bhs *BlacklistHandlerStub) Has(key string) bool
func (*BlacklistHandlerStub) IsInterfaceNil ¶
func (bhs *BlacklistHandlerStub) IsInterfaceNil() bool
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 }
ChannelLoadBalancerStub -
func (*ChannelLoadBalancerStub) AddChannel ¶
func (clbs *ChannelLoadBalancerStub) AddChannel(pipe string) error
AddChannel -
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 { 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() (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 MarshalizerStub ¶
type MarshalizerStub struct { MarshalCalled func(obj interface{}) ([]byte, error) UnmarshalCalled func(obj interface{}, buff []byte) error }
func (*MarshalizerStub) IsInterfaceNil ¶
func (ms *MarshalizerStub) IsInterfaceNil() bool
func (*MarshalizerStub) Marshal ¶
func (ms *MarshalizerStub) Marshal(obj interface{}) ([]byte, error)
func (*MarshalizerStub) Unmarshal ¶
func (ms *MarshalizerStub) Unmarshal(obj interface{}, buff []byte) error
type MessageProcessorStub ¶
type MessageProcessorStub struct {
ProcessMessageCalled func(message p2p.MessageP2P, fromConnectedPeer p2p.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 p2p.PeerID) error
ProcessReceivedMessage -
type NetworkShardingCollectorStub ¶
type NetworkShardingCollectorStub struct {
UpdatePeerIdPublicKeyCalled func(pid p2p.PeerID, pk []byte)
}
NetworkShardingCollectorStub -
func (*NetworkShardingCollectorStub) IsInterfaceNil ¶
func (nscs *NetworkShardingCollectorStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*NetworkShardingCollectorStub) UpdatePeerIdPublicKey ¶
func (nscs *NetworkShardingCollectorStub) UpdatePeerIdPublicKey(pid p2p.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 NilBlacklistHandler ¶
type NilBlacklistHandler struct { }
NilBlacklistHandler is a mock implementation of BlacklistHandler that does not manage black listed keys (all keys [peers] are whitelisted)
func (*NilBlacklistHandler) Has ¶
func (nbh *NilBlacklistHandler) Has(_ string) bool
Has outputs false (all peers are white listed)
func (*NilBlacklistHandler) IsInterfaceNil ¶
func (nbh *NilBlacklistHandler) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
type P2PMessageMock ¶
type P2PMessageMock struct { FromField []byte DataField []byte SeqNoField []byte TopicsField []string SignatureField []byte KeyField []byte PeerField p2p.PeerID }
P2PMessageMock -
func (*P2PMessageMock) IsInterfaceNil ¶
func (msg *P2PMessageMock) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
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 p2p.PeerID) core.P2PPeerInfo
}
PeerShardResolverStub -
func (*PeerShardResolverStub) GetPeerInfo ¶
func (psrs *PeerShardResolverStub) GetPeerInfo(pid p2p.PeerID) core.P2PPeerInfo
GetPeerInfo -
func (*PeerShardResolverStub) IsInterfaceNil ¶
func (psrs *PeerShardResolverStub) IsInterfaceNil() bool
IsInterfaceNil -
type PrioSharderStub ¶
type PrioSharderStub struct { GetShardCalled func(id peer.ID) uint32 GetDistanceCalled func(a, b interface{}) *big.Int SortListCalled func(peers []peer.ID, ref peer.ID) ([]peer.ID, bool) SetPeerShardResolverCalled func(psp p2p.PeerShardResolver) error }
PrioSharderStub -
func (*PrioSharderStub) GetDistance ¶
func (pss *PrioSharderStub) GetDistance(a, b sorting.SortedID) *big.Int
GetDistance -
func (*PrioSharderStub) GetShard ¶
func (pss *PrioSharderStub) GetShard(id peer.ID) uint32
GetShard -
func (*PrioSharderStub) IsInterfaceNil ¶
func (pss *PrioSharderStub) IsInterfaceNil() bool
IsInterfaceNil -
func (*PrioSharderStub) SetPeerShardResolver ¶
func (pss *PrioSharderStub) SetPeerShardResolver(psp p2p.PeerShardResolver) error
SetPeerShardResolver -
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 ReconnecterWithPauseAndResumeStub ¶
type ReconnecterWithPauseAndResumeStub struct { ReconnectToNetworkCalled func() <-chan struct{} PauseCall func() ResumeCall func() }
func (*ReconnecterWithPauseAndResumeStub) IsInterfaceNil ¶
func (rs *ReconnecterWithPauseAndResumeStub) IsInterfaceNil() bool
IsInterfaceNil returns true if there is no value under the interface
func (*ReconnecterWithPauseAndResumeStub) KickWatchdog ¶
func (rs *ReconnecterWithPauseAndResumeStub) KickWatchdog() error
func (*ReconnecterWithPauseAndResumeStub) Pause ¶
func (rs *ReconnecterWithPauseAndResumeStub) Pause()
func (*ReconnecterWithPauseAndResumeStub) ReconnectToNetwork ¶
func (rs *ReconnecterWithPauseAndResumeStub) ReconnectToNetwork() <-chan struct{}
func (*ReconnecterWithPauseAndResumeStub) Resume ¶
func (rs *ReconnecterWithPauseAndResumeStub) Resume()
func (*ReconnecterWithPauseAndResumeStub) StartWatchdog ¶
func (rs *ReconnecterWithPauseAndResumeStub) StartWatchdog(time.Duration) error
func (*ReconnecterWithPauseAndResumeStub) StopWatchdog ¶
func (rs *ReconnecterWithPauseAndResumeStub) StopWatchdog() error
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 }
func (*SignerVerifierStub) IsInterfaceNil ¶
func (svs *SignerVerifierStub) IsInterfaceNil() bool
func (*SignerVerifierStub) PublicKey ¶
func (svs *SignerVerifierStub) PublicKey() []byte
Source Files ¶
- appStatusHandlerMock.go
- blacklistHandlerStub.go
- channelLoadBalancerStub.go
- commonSharder.go
- connManagerNotifieeStub.go
- connStub.go
- connectableHostStub.go
- connectionMonitorStub.go
- contextProviderMock.go
- marshalizerStub.go
- messageProcessorStub.go
- networkShardingCollectorStub.go
- networkStub.go
- nilBlacklistHandler.go
- p2pMessageMock.go
- peerDiscovererStub.go
- peerShardResolverStub.go
- prioSharderStub.go
- reconnecterStub.go
- reconnecterWithPauseAndResumeStub.go
- sharderStub.go
- signerVerifierStub.go
- streamMock.go