ouroboros-network-0.16.0.0: A networking layer for the Ouroboros blockchain protocol
Safe HaskellSafe-Inferred
LanguageHaskell2010

Ouroboros.Network.NodeToNode

Description

This is the starting point for a module that will bring together the overall node to node protocol, as a collection of mini-protocols.

Synopsis

Documentation

nodeToNodeProtocols Source #

Arguments

MiniProtocolParameters 
NodeToNodeProtocols muxMode initiatorCtx responderCtx bytes m a b 
NodeToNodeVersion 
PeerSharing

Node's own PeerSharing value

OuroborosBundle muxMode initiatorCtx responderCtx bytes m a b 

Make an OuroborosApplication for the bundle of mini-protocols that make up the overall node-to-node protocol.

This function specifies the wire format protocol numbers.

The application specific protocol numbers start from 2. The MiniProtocolNum 0 is reserved for the Handshake protocol, while MiniProtocolNum 1 is reserved for DeltaQ messages. Handshake protocol is not included in NodeToNodeProtocols as it runs before mux is started but it reusing MuxBearer to send and receive messages. Only when the handshake protocol succeeds, we will know which protocols to run / multiplex.

These are chosen to not overlap with the node to client protocol numbers (and the handshake protocol number). This is not essential for correctness, but is helpful to allow a single shared implementation of tools that can analyse both protocols, e.g. wireshark plugins.

data NodeToNodeProtocols appType initiatorCtx responderCtx bytes m a b Source #

Constructors

NodeToNodeProtocols 

Fields

type NodeToNodeProtocolsWithExpandedCtx appType ntnAddr bytes m a b = NodeToNodeProtocols appType (ExpandedInitiatorContext ntnAddr m) (ResponderContext ntnAddr) bytes m a b Source #

type NodeToNodeProtocolsWithMinimalCtx appType ntnAddr bytes m a b = NodeToNodeProtocols appType (MinimalInitiatorContext ntnAddr) (ResponderContext ntnAddr) bytes m a b Source #

data MiniProtocolParameters Source #

Constructors

MiniProtocolParameters 

Fields

data NodeToNodeVersion Source #

Enumeration of node to node protocol versions.

Constructors

NodeToNodeV_7

Changes:

  • new KeepAlive codec
  • Enable CardanoNodeToNodeVersion5, i.e., Alonzo
NodeToNodeV_8

Changes:

  • Enable block diffusion pipelining in ChainSync and BlockFetch logic.
NodeToNodeV_9

Changes:

  • Enable CardanoNodeToNodeVersion6, i.e., Babbage
NodeToNodeV_10

Changes:

  • Enable full duplex connections.
NodeToNodeV_11

Changes:

  • Adds a new extra parameter to handshake: PeerSharing This version is needed to support the new Peer Sharing miniprotocol older versions that are negotiated will appear as not participating in Peer Sharing to newer versions.
  • Adds query to NodeToClientVersionData.
NodeToNodeV_12

No changes.

(In the past, this enabled Conway, but the negotiated NodeToNodeVersion no longer en-/disables eras.)

NodeToNodeV_13

Changes:

  • Removed PeerSharingPrivate constructor
  • Fixed Codec to disable PeerSharing with buggy versions 11 and 12.
  • Disable PeerSharing with InitiatorOnly nodes, since they do not run peer sharing server side and can not reply to requests.

Instances

Instances details
Bounded NodeToNodeVersion 
Instance details

Defined in Ouroboros.Network.NodeToNode.Version

Enum NodeToNodeVersion 
Instance details

Defined in Ouroboros.Network.NodeToNode.Version

Generic NodeToNodeVersion 
Instance details

Defined in Ouroboros.Network.NodeToNode.Version

Associated Types

type Rep NodeToNodeVersionTypeType #

Show NodeToNodeVersion 
Instance details

Defined in Ouroboros.Network.NodeToNode.Version

NFData NodeToNodeVersion 
Instance details

Defined in Ouroboros.Network.NodeToNode.Version

Methods

rnfNodeToNodeVersion → () #

Eq NodeToNodeVersion 
Instance details

Defined in Ouroboros.Network.NodeToNode.Version

Ord NodeToNodeVersion 
Instance details

Defined in Ouroboros.Network.NodeToNode.Version

type Rep NodeToNodeVersion 
Instance details

Defined in Ouroboros.Network.NodeToNode.Version

type Rep NodeToNodeVersion = D1 ('MetaData "NodeToNodeVersion" "Ouroboros.Network.NodeToNode.Version" "ouroboros-network-api-0.7.2.0-inplace" 'False) ((C1 ('MetaCons "NodeToNodeV_7" 'PrefixI 'False) (U1TypeType) :+: (C1 ('MetaCons "NodeToNodeV_8" 'PrefixI 'False) (U1TypeType) :+: C1 ('MetaCons "NodeToNodeV_9" 'PrefixI 'False) (U1TypeType))) :+: ((C1 ('MetaCons "NodeToNodeV_10" 'PrefixI 'False) (U1TypeType) :+: C1 ('MetaCons "NodeToNodeV_11" 'PrefixI 'False) (U1TypeType)) :+: (C1 ('MetaCons "NodeToNodeV_12" 'PrefixI 'False) (U1TypeType) :+: C1 ('MetaCons "NodeToNodeV_13" 'PrefixI 'False) (U1TypeType))))

data NetworkConnectTracers addr vNumber Source #

Tracer used by connectToNode (and derivatives, like connectTo or 'Ouroboros.Network.NodeToClient.connectTo).

Constructors

NetworkConnectTracers 

Fields

data NetworkServerTracers addr vNumber Source #

Tracers required by a server which handles inbound connections.

Constructors

NetworkServerTracers 

Fields

data NetworkMutableState addr Source #

Mutable state maintained by the network component.

Constructors

NetworkMutableState 

Fields

data AcceptedConnectionsLimit Source #

Policy which governs how to limit the number of accepted connections.

Constructors

AcceptedConnectionsLimit 

Fields

withServer Source #

Arguments

SocketSnocket 
NetworkServerTracers SockAddr NodeToNodeVersion 
NetworkMutableState SockAddr 
AcceptedConnectionsLimit 
Socket

a configured socket to be used be the server. The server will call bind and listen methods but it will not set any socket or tcp options on it.

Versions NodeToNodeVersion NodeToNodeVersionData (OuroborosApplicationWithMinimalCtx ResponderMode SockAddr ByteString IO a b) 
ErrorPolicies 
IO Void 

A specialised version of withServerNode. It forks a thread which runs an accept loop (server thread):

  • when the server thread throws an exception the main thread rethrows it (by wait)
  • when an async exception is thrown to kill the main thread the server thread will be cancelled as well (by withAsync)

P2P Governor

data PeerAdvertise Source #

Should this peer be advertised to other peers asking for known peers? For certain peers specified by configuration it would be an appropriate policy to keep them private.

Instances

Instances details
FromJSON PeerAdvertise 
Instance details

Defined in Ouroboros.Network.PeerSelection.PeerAdvertise

ToJSON PeerAdvertise 
Instance details

Defined in Ouroboros.Network.PeerSelection.PeerAdvertise

Generic PeerAdvertise 
Instance details

Defined in Ouroboros.Network.PeerSelection.PeerAdvertise

Associated Types

type Rep PeerAdvertiseTypeType #

Show PeerAdvertise 
Instance details

Defined in Ouroboros.Network.PeerSelection.PeerAdvertise

Eq PeerAdvertise 
Instance details

Defined in Ouroboros.Network.PeerSelection.PeerAdvertise

Ord PeerAdvertise 
Instance details

Defined in Ouroboros.Network.PeerSelection.PeerAdvertise

type Rep PeerAdvertise 
Instance details

Defined in Ouroboros.Network.PeerSelection.PeerAdvertise

type Rep PeerAdvertise = D1 ('MetaData "PeerAdvertise" "Ouroboros.Network.PeerSelection.PeerAdvertise" "ouroboros-network-api-0.7.2.0-inplace" 'False) (C1 ('MetaCons "DoNotAdvertisePeer" 'PrefixI 'False) (U1TypeType) :+: C1 ('MetaCons "DoAdvertisePeer" 'PrefixI 'False) (U1TypeType))

data PeerSelectionTargets Source #

Adjustable targets for the peer selection mechanism.

These are used by the peer selection governor as targets. They are used by the peer churn governor loop as knobs to adjust, to influence the peer selection governor.

The known, established and active peer targets are targets both from below and from above: the governor will attempt to grow or shrink the sets to hit these targets.

Unlike the other targets, the root peer target is "one sided", it is only a target from below. The governor does not try to shrink the root set to hit it, it simply stops looking for more.

There is also an implicit target that enough local root peers are selected as active. This comes from the configuration for local roots, and is not an independently adjustable target.

Constructors

PeerSelectionTargets 

Fields

Subscription Workers

IP subscription worker

data IPSubscriptionTarget Source #

Constructors

IPSubscriptionTarget 

Fields

data NetworkSubscriptionTracers withIPList addr vNumber Source #

IP subscription tracers.

Constructors

NetworkSubscriptionTracers 

Fields

data SubscriptionParams a target Source #

ipSubscriptionWorker and dnsSubscriptionWorker parameters

Constructors

SubscriptionParams 

Fields

DNS subscription worker

data NetworkDNSSubscriptionTracers vNumber addr Source #

DNS subscription tracers.

Constructors

NetworkDNSSubscriptionTracers 

Fields

Versions

newtype Versions vNum vData r Source #

The version map supported by the local agent keyed on the version identifier.

Each Version contains a function which takes negotiated version data and returns negotiated application (the r type variable).

If one needs to combine multiple versions the simplest way is to use one of the combinators: foldMapVersions, combineVersions or the Semigroup instance directly:

fold $ (simpleSingletonVersions ...)
      :| [ (simpleSingletonVersions ...)
         , (simpleSingletonVersions ...)
         , ...
         ]

Constructors

Versions 

Fields

Instances

Instances details
Functor (Versions vNum extra) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Version

Methods

fmap ∷ (a → b) → Versions vNum extra a → Versions vNum extra b #

(<$) ∷ a → Versions vNum extra b → Versions vNum extra a #

Ord vNum ⇒ Semigroup (Versions vNum vData r) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Version

Methods

(<>)Versions vNum vData r → Versions vNum vData r → Versions vNum vData r #

sconcatNonEmpty (Versions vNum vData r) → Versions vNum vData r #

stimesIntegral b ⇒ b → Versions vNum vData r → Versions vNum vData r #

data DiffusionMode Source #

The flag which indicates whether the node runs only initiator or both initiator or responder node.

This data structure has two proposes:

  • instruct the diffusion layer if it should listen on incoming connections;
  • it is communicated via NodeToNodeVersionData during handshake negotiation. In non-p2p mode we always send InitiatorOnlyDiffusionMode, in p2p mode we send exactly what the diffusion is given. In non-p2p mode every connection outbound port is ephemeral, the remote side cannot connect to it, however in p2p mode the outbound port is actually the port on which the node is listening (if it runs in InitiatorAndResponderDiffusionMode).

simpleSingletonVersions ∷ vNum → vData → r → Versions vNum vData r Source #

Singleton smart constructor for Versions.

foldMapVersions ∷ (Ord vNum, Foldable f, HasCallStack) ⇒ (x → Versions vNum extra r) → f x → Versions vNum extra r Source #

Useful for folding multiple Versions.

A foldMap restricted to the Versions Semigroup.

PRECONDITION: f x is non-empty.

combineVersions ∷ (Ord vNum, Foldable f, HasCallStack) ⇒ f (Versions vNum extra r) → Versions vNum extra r Source #

Codecs

nodeToNodeHandshakeCodec ∷ ∀ (m ∷ TypeType). MonadST m ⇒ Codec (Handshake NodeToNodeVersion Term) DeserialiseFailure m ByteString Source #

Handshake codec for the node-to-node protocol suite.

Re-exports

data ExpandedInitiatorContext addr (m ∷ TypeType) Source #

Context passed to initiator mini-protocol execution.

newtype MinimalInitiatorContext addr Source #

A context passed to initiator mini-protocol execution for non-p2p applications.

Instances

Instances details
Functor MinimalInitiatorContext 
Instance details

Defined in Ouroboros.Network.Context

newtype ResponderContext addr Source #

Context passed to each responder mini-protocol execution.

Constructors

ResponderContext 

Fields

Instances

Instances details
Functor ResponderContext 
Instance details

Defined in Ouroboros.Network.Context

Methods

fmap ∷ (a → b) → ResponderContext a → ResponderContext b #

(<$) ∷ a → ResponderContext b → ResponderContext a #

data ConnectionId addr Source #

Connection is identified by local and remote address.

TODO: the type variable which this data type fills in is called peerid. We should renamed to connectionId.

Constructors

ConnectionId 

Fields

Instances

Instances details
Functor ConnectionId 
Instance details

Defined in Ouroboros.Network.ConnectionId

Methods

fmap ∷ (a → b) → ConnectionId a → ConnectionId b #

(<$) ∷ a → ConnectionId b → ConnectionId a #

ShowProxy addr ⇒ ShowProxy (ConnectionId addr ∷ Type) 
Instance details

Defined in Ouroboros.Network.ConnectionId

Methods

showProxyProxy (ConnectionId addr) → String Source #

Generic (ConnectionId addr) 
Instance details

Defined in Ouroboros.Network.ConnectionId

Associated Types

type Rep (ConnectionId addr) ∷ TypeType #

Methods

fromConnectionId addr → Rep (ConnectionId addr) x #

toRep (ConnectionId addr) x → ConnectionId addr #

Show addr ⇒ Show (ConnectionId addr) 
Instance details

Defined in Ouroboros.Network.ConnectionId

Methods

showsPrecIntConnectionId addr → ShowS #

showConnectionId addr → String #

showList ∷ [ConnectionId addr] → ShowS #

Eq addr ⇒ Eq (ConnectionId addr) 
Instance details

Defined in Ouroboros.Network.ConnectionId

Methods

(==)ConnectionId addr → ConnectionId addr → Bool #

(/=)ConnectionId addr → ConnectionId addr → Bool #

Ord addr ⇒ Ord (ConnectionId addr)

Order first by remoteAddress then by localAddress.

Note: we relay on the fact that remoteAddress is an order preserving map (which allows us to use mapKeysMonotonic in some cases).

Instance details

Defined in Ouroboros.Network.ConnectionId

Methods

compareConnectionId addr → ConnectionId addr → Ordering #

(<)ConnectionId addr → ConnectionId addr → Bool #

(<=)ConnectionId addr → ConnectionId addr → Bool #

(>)ConnectionId addr → ConnectionId addr → Bool #

(>=)ConnectionId addr → ConnectionId addr → Bool #

maxConnectionId addr → ConnectionId addr → ConnectionId addr #

minConnectionId addr → ConnectionId addr → ConnectionId addr #

Hashable a ⇒ Hashable (ConnectionId a) 
Instance details

Defined in Ouroboros.Network.ConnectionId

Typeable addr ⇒ NoThunks (ConnectionId addr) 
Instance details

Defined in Ouroboros.Network.ConnectionId

type Rep (ConnectionId addr) 
Instance details

Defined in Ouroboros.Network.ConnectionId

type Rep (ConnectionId addr) = D1 ('MetaData "ConnectionId" "Ouroboros.Network.ConnectionId" "ouroboros-network-framework-0.13.1.0-inplace" 'False) (C1 ('MetaCons "ConnectionId" 'PrefixI 'True) (S1 ('MetaSel ('Just "localAddress") 'NoSourceUnpackedness 'SourceStrict 'DecidedStrict) (Rec0 addr) :*: S1 ('MetaSel ('Just "remoteAddress") 'NoSourceUnpackedness 'SourceStrict 'DecidedStrict) (Rec0 addr)))

data ControlMessage Source #

Control signal sent to a mini-protocol. Expected to exit, on Continue it should continue its operation

Constructors

Continue

Continue operation.

Quiesce

Hold on, e.g. do not sent messages until resumed. This is not used for any hot protocol.

Terminate

The client is expected to terminate as soon as possible.

Instances

Instances details
Show ControlMessage 
Instance details

Defined in Ouroboros.Network.ControlMessage

Eq ControlMessage 
Instance details

Defined in Ouroboros.Network.ControlMessage

type ControlMessageSTM (m ∷ TypeType) = STM m ControlMessage Source #

ControlMessageSTM should depend on muxMode (we only need to schedule stop for initiator side). This is not done only because this would break tests, but once the old api is removed it should be possible.

data IsBigLedgerPeer Source #

A boolean like type. Big ledger peers are the largest SPOs which control 90% of staked stake.

Note that IsBigLedgerPeer indicates a role that peer plays in the eclipse evasion, e.g. that a peer was explicitly selected as a big ledger peer, e.g. IsNotBigLedgerPeer does not necessarily mean that the peer isn't a big ledger peer. This is because we select root peers from all ledger peers (including big ones).

Instances

Instances details
Eq IsBigLedgerPeer 
Instance details

Defined in Ouroboros.Network.PeerSelection.LedgerPeers.Type

data Handshake (vNumber ∷ k) (vParams ∷ k1) Source #

The handshake mini-protocol is used initially to agree the version and associated parameters of the protocol to use for all subsequent communication.

Instances

Instances details
ShowProxy (Handshake vNumber vParams ∷ Type) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

Methods

showProxyProxy (Handshake vNumber vParams) → String Source #

Show (ClientHasAgency st) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

Show (ServerHasAgency st) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

NFData (ClientHasAgency st) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

Methods

rnfClientHasAgency st → () #

NFData (NobodyHasAgency st) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

Methods

rnfNobodyHasAgency st → () #

NFData (ServerHasAgency st) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

Methods

rnfServerHasAgency st → () #

(Show vNumber, Show vParams) ⇒ Show (Message (Handshake vNumber vParams) from to) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

Methods

showsPrecIntMessage (Handshake vNumber vParams) from to → ShowS #

showMessage (Handshake vNumber vParams) from to → String #

showList ∷ [Message (Handshake vNumber vParams) from to] → ShowS #

(NFData vNumber, NFData vParams) ⇒ NFData (Message (Handshake vNumber vParams) from to) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

Methods

rnfMessage (Handshake vNumber vParams) from to → () #

NFData (PeerHasAgency pr st) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

Methods

rnfPeerHasAgency pr st → () #

Protocol (Handshake vNumber vParams) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

Associated Types

data Message (Handshake vNumber vParams) st st' Source #

data ClientHasAgency st Source #

data ServerHasAgency st Source #

data NobodyHasAgency st Source #

data ClientHasAgency (st ∷ Handshake vNumber vParams) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

data ClientHasAgency (st ∷ Handshake vNumber vParams) where
data Message (Handshake vNumber vParams) (from ∷ Handshake vNumber vParams) (to ∷ Handshake vNumber vParams) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

data Message (Handshake vNumber vParams) (from ∷ Handshake vNumber vParams) (to ∷ Handshake vNumber vParams) where
data NobodyHasAgency (st ∷ Handshake vNumber vParams) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

data NobodyHasAgency (st ∷ Handshake vNumber vParams) where
data ServerHasAgency (st ∷ Handshake vNumber vParams) 
Instance details

Defined in Ouroboros.Network.Protocol.Handshake.Type

data ServerHasAgency (st ∷ Handshake vNumber vParams) where

data LocalAddresses addr Source #

Constructors

LocalAddresses 

Fields

  • laIpv4Maybe addr

    Local IPv4 address to use, Nothing indicates don't use IPv4

  • laIpv6Maybe addr

    Local IPv6 address to use, Nothing indicates don't use IPv6

  • laUnixMaybe addr

    Local Unix address to use, Nothing indicates don't use Unix sockets

Instances

Instances details
Semigroup (LocalAddresses addr) 
Instance details

Defined in Ouroboros.Network.Subscription.Worker

Methods

(<>)LocalAddresses addr → LocalAddresses addr → LocalAddresses addr #

sconcatNonEmpty (LocalAddresses addr) → LocalAddresses addr #

stimesIntegral b ⇒ b → LocalAddresses addr → LocalAddresses addr #

Show addr ⇒ Show (LocalAddresses addr) 
Instance details

Defined in Ouroboros.Network.Subscription.Worker

Methods

showsPrecIntLocalAddresses addr → ShowS #

showLocalAddresses addr → String #

showList ∷ [LocalAddresses addr] → ShowS #

Eq addr ⇒ Eq (LocalAddresses addr) 
Instance details

Defined in Ouroboros.Network.Subscription.Worker

Methods

(==)LocalAddresses addr → LocalAddresses addr → Bool #

(/=)LocalAddresses addr → LocalAddresses addr → Bool #

data Socket Source #

Basic type for a socket.

Instances

Instances details
Show Socket 
Instance details

Defined in Network.Socket.Types

Methods

showsPrecIntSocketShowS #

showSocketString #

showList ∷ [Socket] → ShowS #

Eq Socket 
Instance details

Defined in Network.Socket.Types

Methods

(==)SocketSocketBool #

(/=)SocketSocketBool #

Exceptions

data ExceptionInHandler where Source #

Exception which where caught in the connection thread and were re-thrown in the main thread by the rethrowPolicy.

Constructors

ExceptionInHandler ∷ ∀ peerAddr. (Typeable peerAddr, Show peerAddr) ⇒ !peerAddr → !SomeExceptionExceptionInHandler 

Error Policies and Peer state

data ErrorPolicies Source #

List of error policies for exception handling and a policy for handing application return values.

Constructors

ErrorPolicies 

Fields

remoteNetworkErrorPolicyErrorPolicies Source #

A minimal error policy for remote peers, which only handles exceptions raised by `ouroboros-network`.

localNetworkErrorPolicyErrorPolicies Source #

Error policy for local clients. This is equivalent to nullErrorPolicies, but explicit in the errors which can be caught.

We are very permissive here, and very strict in the networkErrorPolicy. After any failure the client will be killed and not penalised by this policy. This allows to restart the local client without a delay.

data ErrorPolicy where Source #

Constructors

ErrorPolicy 

Fields

Instances

Instances details
Show ErrorPolicy 
Instance details

Defined in Ouroboros.Network.ErrorPolicy

data SuspendDecision t Source #

Semigroup of commands which acts on PeerState. The t variable might be initiated to DiffTime or Time m.

This semigroup allows to either suspend both consumer and producer or just the consumer part.

Constructors

SuspendPeer !t !t

peer is suspend; The first t is the time until which a local producer is suspended, the second one is the time until which a local consumer is suspended.

SuspendConsumer !t

suspend local consumer / initiator side until t (this mean we are not allowing to communicate with the producer / responder of a remote peer).

Throw

throw an error from the main thread.

Instances

Instances details
Functor SuspendDecision 
Instance details

Defined in Ouroboros.Network.Subscription.PeerState

Methods

fmap ∷ (a → b) → SuspendDecision a → SuspendDecision b #

(<$) ∷ a → SuspendDecision b → SuspendDecision a #

Ord t ⇒ Semigroup (SuspendDecision t)

The semigroup instance. Note that composing SuspendPeer with SuspendConsumer gives SuspendPeer. SuspendPeer and SuspendConsumer form a sub-semigroup.

Instance details

Defined in Ouroboros.Network.Subscription.PeerState

Show t ⇒ Show (SuspendDecision t) 
Instance details

Defined in Ouroboros.Network.Subscription.PeerState

Eq t ⇒ Eq (SuspendDecision t) 
Instance details

Defined in Ouroboros.Network.Subscription.PeerState

Ord t ⇒ Ord (SuspendDecision t) 
Instance details

Defined in Ouroboros.Network.Subscription.PeerState

SAct (SuspendDecision Time) (Maybe (PeerState m))

Action of SuspendDecision on Maybe PeerState. We use this action together with alter function.

Note: SuspendDecision does not act on PeerState, only the sub-semigroup generated by SuspendConsumer and SuspendPeer does.

Instance details

Defined in Ouroboros.Network.Subscription.PeerState

Traces

data AcceptConnectionsPolicyTrace Source #

Trace for the AcceptConnectionsLimit policy.

data TraceSendRecv ps where Source #

Structured Tracer output for runPeer and derivitives.

Constructors

TraceSendMsg ∷ ∀ ps. AnyMessageAndAgency ps → TraceSendRecv ps 
TraceRecvMsg ∷ ∀ ps. AnyMessageAndAgency ps → TraceSendRecv ps 

Instances

Instances details
Show (AnyMessageAndAgency ps) ⇒ Show (TraceSendRecv ps) 
Instance details

Defined in Ouroboros.Network.Driver.Simple

Methods

showsPrecIntTraceSendRecv ps → ShowS #

showTraceSendRecv ps → String #

showList ∷ [TraceSendRecv ps] → ShowS #

data ErrorPolicyTrace Source #

Trace data for error policies

Constructors

ErrorPolicySuspendPeer (Maybe (ConnectionOrApplicationExceptionTrace SomeException)) DiffTime DiffTime

suspending peer with a given exception until

ErrorPolicySuspendConsumer (Maybe (ConnectionOrApplicationExceptionTrace SomeException)) DiffTime

suspending consumer until

ErrorPolicyLocalNodeError (ConnectionOrApplicationExceptionTrace SomeException)

caught a local exception

ErrorPolicyResumePeer

resume a peer (both consumer and producer)

ErrorPolicyKeepSuspended

consumer was suspended until producer will resume

ErrorPolicyResumeConsumer

resume consumer

ErrorPolicyResumeProducer

resume producer

ErrorPolicyUnhandledApplicationException SomeException

an application throwed an exception, which was not handled by any ErrorPolicy.

ErrorPolicyUnhandledConnectionException SomeException

connect throwed an exception, which was not handled by any ErrorPolicy.

ErrorPolicyAcceptException IOException

accept throwed an exception

Instances

Instances details
Show ErrorPolicyTrace 
Instance details

Defined in Ouroboros.Network.ErrorPolicy

data WithIPList a Source #

Constructors

WithIPList 

Instances

Instances details
Show a ⇒ Show (WithIPList a) 
Instance details

Defined in Ouroboros.Network.Subscription.Ip

Methods

showsPrecIntWithIPList a → ShowS #

showWithIPList a → String #

showList ∷ [WithIPList a] → ShowS #

data WithDomainName a Source #

Constructors

WithDomainName 

Fields

Instances

Instances details
Show a ⇒ Show (WithDomainName a) 
Instance details

Defined in Ouroboros.Network.Subscription.Dns

data WithAddr addr a Source #

Constructors

WithAddr 

Fields

Instances

Instances details
(Show addr, Show a) ⇒ Show (WithAddr addr a) 
Instance details

Defined in Ouroboros.Network.ErrorPolicy

Methods

showsPrecIntWithAddr addr a → ShowS #

showWithAddr addr a → String #

showList ∷ [WithAddr addr a] → ShowS #

type HandshakeTr ntnAddr ntnVersion = WithMuxBearer (ConnectionId ntnAddr) (TraceSendRecv (Handshake ntnVersion Term)) Source #

For Consensus ThreadNet Tests

Orphan instances