mock

package
v0.0.2 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Oct 31, 2023 License: GPL-3.0 Imports: 18 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

func NewStreamMock

func NewStreamMock() *streamMock

NewStreamMock -

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) Close

func (ashm *AppStatusHandlerMock) Close()

Close -

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

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) Close

func (cmns *ConnManagerNotifieeStub) Close() error

Close -

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 -

func (*ConnManagerNotifieeStub) UntagPeer

func (cmns *ConnManagerNotifieeStub) UntagPeer(p peer.ID, tag string)

UntagPeer -

func (*ConnManagerNotifieeStub) UpsertTag

func (cmns *ConnManagerNotifieeStub) UpsertTag(p peer.ID, tag string, upsert func(int) int)

UpsertTag -

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) Close

func (cs *ConnStub) Close() error

Close -

func (*ConnStub) GetStreams

func (cs *ConnStub) GetStreams() []network.Stream

GetStreams -

func (*ConnStub) LocalMultiaddr

func (cs *ConnStub) LocalMultiaddr() multiaddr.Multiaddr

LocalMultiaddr -

func (*ConnStub) LocalPeer

func (cs *ConnStub) LocalPeer() peer.ID

LocalPeer -

func (*ConnStub) LocalPrivateKey

func (cs *ConnStub) LocalPrivateKey() libp2pCrypto.PrivKey

LocalPrivateKey -

func (*ConnStub) NewStream

func (cs *ConnStub) NewStream() (network.Stream, error)

NewStream -

func (*ConnStub) RemoteMultiaddr

func (cs *ConnStub) RemoteMultiaddr() multiaddr.Multiaddr

RemoteMultiaddr -

func (*ConnStub) RemotePeer

func (cs *ConnStub) RemotePeer() peer.ID

RemotePeer -

func (*ConnStub) RemotePublicKey

func (cs *ConnStub) RemotePublicKey() libp2pCrypto.PubKey

RemotePublicKey -

func (*ConnStub) Stat

func (cs *ConnStub) Stat() network.Stat

Stat -

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) Close

func (hs *ConnectableHostStub) Close() error

Close -

func (*ConnectableHostStub) ConnManager

func (hs *ConnectableHostStub) ConnManager() connmgr.ConnManager

ConnManager -

func (*ConnectableHostStub) Connect

func (hs *ConnectableHostStub) Connect(ctx context.Context, pi peer.AddrInfo) error

Connect -

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) ID

func (hs *ConnectableHostStub) ID() peer.ID

ID -

func (*ConnectableHostStub) IsInterfaceNil

func (hs *ConnectableHostStub) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*ConnectableHostStub) Mux

Mux -

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

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

func (ebs *EventBusStub) Emitter(eventType interface{}, opts ...event.EmitterOpt) (event.Emitter, error)

Emitter -

func (*EventBusStub) GetAllEventTypes

func (ebs *EventBusStub) GetAllEventTypes() []reflect.Type

GetAllEventTypes -

func (*EventBusStub) Subscribe

func (ebs *EventBusStub) Subscribe(eventType interface{}, opts ...event.SubscriptionOpt) (event.Subscription, error)

Subscribe -

type EventSubscriptionStub

type EventSubscriptionStub struct {
	CloseCalled func() error
	OutCalled   func() <-chan interface{}
}

EventSubscriptionStub -

func (*EventSubscriptionStub) Close

func (ess *EventSubscriptionStub) Close() error

Close -

func (*EventSubscriptionStub) Out

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 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) Close

func (ns *NetworkStub) Close() error

Close -

func (*NetworkStub) ClosePeer

func (ns *NetworkStub) ClosePeer(pid peer.ID) error

ClosePeer -

func (*NetworkStub) Connectedness

func (ns *NetworkStub) Connectedness(pid peer.ID) network.Connectedness

Connectedness -

func (*NetworkStub) Conns

func (ns *NetworkStub) Conns() []network.Conn

Conns -

func (*NetworkStub) ConnsToPeer

func (ns *NetworkStub) ConnsToPeer(p peer.ID) []network.Conn

ConnsToPeer -

func (*NetworkStub) DialPeer

func (ns *NetworkStub) DialPeer(_ context.Context, _ peer.ID) (network.Conn, error)

DialPeer -

func (*NetworkStub) InterfaceListenAddresses

func (ns *NetworkStub) InterfaceListenAddresses() ([]multiaddr.Multiaddr, error)

InterfaceListenAddresses -

func (*NetworkStub) Listen

func (ns *NetworkStub) Listen(...multiaddr.Multiaddr) error

Listen -

func (*NetworkStub) ListenAddresses

func (ns *NetworkStub) ListenAddresses() []multiaddr.Multiaddr

ListenAddresses -

func (*NetworkStub) LocalPeer

func (ns *NetworkStub) LocalPeer() peer.ID

LocalPeer -

func (*NetworkStub) NewStream

func (ns *NetworkStub) NewStream(context.Context, peer.ID) (network.Stream, error)

NewStream -

func (*NetworkStub) Notify

func (ns *NetworkStub) Notify(notifee network.Notifiee)

Notify -

func (*NetworkStub) Peers

func (ns *NetworkStub) Peers() []peer.ID

Peers -

func (*NetworkStub) Peerstore

func (ns *NetworkStub) Peerstore() peerstore.Peerstore

Peerstore -

func (*NetworkStub) Process

func (ns *NetworkStub) Process() goprocess.Process

Process -

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
	TopicsField    []string
	SignatureField []byte
	KeyField       []byte
	PeerField      core.PeerID
	PayloadField   []byte
	TimestampField int64
}

P2PMessageMock -

func (*P2PMessageMock) Data

func (msg *P2PMessageMock) Data() []byte

Data -

func (*P2PMessageMock) From

func (msg *P2PMessageMock) From() []byte

From -

func (*P2PMessageMock) IsInterfaceNil

func (msg *P2PMessageMock) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*P2PMessageMock) Key

func (msg *P2PMessageMock) Key() []byte

Key -

func (*P2PMessageMock) Payload

func (msg *P2PMessageMock) Payload() []byte

Payload -

func (*P2PMessageMock) Peer

func (msg *P2PMessageMock) Peer() core.PeerID

Peer -

func (*P2PMessageMock) SeqNo

func (msg *P2PMessageMock) SeqNo() []byte

SeqNo -

func (*P2PMessageMock) Signature

func (msg *P2PMessageMock) Signature() []byte

Signature -

func (*P2PMessageMock) Timestamp

func (msg *P2PMessageMock) Timestamp() int64

Timestamp -

func (*P2PMessageMock) Topics

func (msg *P2PMessageMock) Topics() []string

Topics -

type PeerDenialEvaluatorStub

type PeerDenialEvaluatorStub struct {
	UpsertPeerIDCalled func(pid core.PeerID, duration time.Duration) error
	IsDeniedCalled     func(pid core.PeerID) bool
}

PeerDenialEvaluatorStub -

func (*PeerDenialEvaluatorStub) IsDenied

func (pdes *PeerDenialEvaluatorStub) IsDenied(pid core.PeerID) bool

IsDenied -

func (*PeerDenialEvaluatorStub) IsInterfaceNil

func (pdes *PeerDenialEvaluatorStub) IsInterfaceNil() bool

IsInterfaceNil -

func (*PeerDenialEvaluatorStub) UpsertPeerID

func (pdes *PeerDenialEvaluatorStub) UpsertPeerID(pid core.PeerID, duration time.Duration) error

UpsertPeerID -

type PeerDiscovererStub

type PeerDiscovererStub struct {
	BootstrapCalled func() error
	CloseCalled     func() error
}

PeerDiscovererStub -

func (*PeerDiscovererStub) Bootstrap

func (pds *PeerDiscovererStub) Bootstrap() error

Bootstrap -

func (*PeerDiscovererStub) IsInterfaceNil

func (pds *PeerDiscovererStub) IsInterfaceNil() bool

IsInterfaceNil returns true if there is no value under the interface

func (*PeerDiscovererStub) Name

func (pds *PeerDiscovererStub) Name() string

Name -

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 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) Has

func (ss *SharderStub) Has(pid peer.ID, list []peer.ID) bool

Has -

func (*SharderStub) IsInterfaceNil

func (ss *SharderStub) IsInterfaceNil() bool

IsInterfaceNil -

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 -

func (*SignerVerifierStub) Sign

func (svs *SignerVerifierStub) Sign(message []byte) ([]byte, error)

Sign -

func (*SignerVerifierStub) Verify

func (svs *SignerVerifierStub) Verify(message []byte, sig []byte, pk []byte) error

Verify -

type SyncTimerStub added in v0.0.2

type SyncTimerStub struct {
	CurrentTimeCalled func() time.Time
}

SyncTimerStub -

func (*SyncTimerStub) CurrentTime added in v0.0.2

func (sts *SyncTimerStub) CurrentTime() time.Time

CurrentTime -

func (*SyncTimerStub) IsInterfaceNil added in v0.0.2

func (sts *SyncTimerStub) IsInterfaceNil() bool

IsInterfaceNil -

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL