Safe Haskell | None |
---|---|
Language | Haskell2010 |
Connection manager core types.
Connection manager is responsible for managing uni- and bi-directional connections and threads which are running network applications using 'network-mux'. In particular it is responsible for:
- opening new connection / reusing connections (for bidirectional connections) and exposes a method to register inbound connections;
- run connection handler, i.e.
ConnectionHandler
, which runs handshake negotiation, notifies connection manager on the results and starts the multiplexer; - error handling for connection threads;
- keeping track of handshake negotiation: whether a unidirectional or duplex connection was negotiated;
- tracking state of each connection;
- keep inbound connections under limits.
Connection manager is designed to work for any Mode
, though
the most useful ones are ResponderMode
and InitiatorResponderMode
:
InitiatorResponderMode
- useful for node-to-node applications, which needs to create outbound connections as well as accept inbound ones;ResponderMode
- useful for server side of node-to-client; it allows us to share the same server between node-to-client and node-to-node;InitiatorMode
- could be used on client side of node-to-client applications.
The calls acquireOutboundConnection
and includeInboundConnection
return
once a connection has been negotiated. The returned handle
contains all
the information that is needed to start and monitor mini-protocols through
the mux interface.
For inbound connections, the connection manager will pass handle (also after negotiation).
┌────────────────────────┐ │ │ ┏━━━━━━━━━━━━━━━━┓ │ ConnectionHandler │ ┃ ┃ │ ┝━━━━━━━▶┃ handle ┃ │ inbound / outbound │ ┃ ┃ │ ┃ │ ┗━━┳━━━━━━━━━━━━━┛ └─────────╂──────────────┘ ┃ ┃ ┃ ▼ ┃ ┏━━━━━━━━━━━━━━━━━┓ ┃ ┃ Control Channel ┃ ┃ ┗━━━━━━┳━━━━━━━━━━┛ ┃ ┃ ┃ ┃ ┃ ▼ ┃ ┌────────────────────────┐ ┃ │ │ ┃ │ Server │◀━━━━━━━━━━┛ │ │ └────────────────────────┘
Termination procedure as well as connection state machine is not described in this haddock, see associated specification.
The handle
is used in `ouroboros-network` package to construct
PeerStateActions
which allow for the outbound governor to
Synopsis
- data AddressType
- data Provenance
- data DataFlow
- data TimeoutExpired
- data ConnectionType
- newtype MaskedAction (m :: Type -> Type) a = MaskedAction {
- runWithUnmask :: (forall x. m x -> m x) -> m a
- type ConnectionHandlerFn handlerTrace socket peerAddr handle handleError version (m :: Type -> Type) = socket -> PromiseWriter m (Either handleError (HandshakeConnectionResult handle version)) -> Tracer m handlerTrace -> ConnectionId peerAddr -> (DiffTime -> socket -> m (Bearer m)) -> MaskedAction m ()
- newtype ConnectionHandler (muxMode :: Mode) handlerTrace socket peerAddr handle handleError version (m :: Type -> Type) = ConnectionHandler {
- connectionHandler :: WithMuxTuple muxMode (ConnectionHandlerFn handlerTrace socket peerAddr handle handleError version m)
- data Inactive
- data ExceptionInHandler where
- ExceptionInHandler :: forall peerAddr. (Typeable peerAddr, Show peerAddr) => !peerAddr -> !SomeException -> ExceptionInHandler
- data HandleErrorType
- data HandshakeConnectionResult handle version
- = HandshakeConnectionQuery
- | HandshakeConnectionResult handle version
- type PrunePolicy peerAddr = StdGen -> Map peerAddr ConnectionType -> Int -> Set peerAddr
- simplePrunePolicy :: Ord peerAddr => PrunePolicy peerAddr
- data ConnectionManager (muxMode :: Mode) socket peerAddr handle handleError (m :: Type -> Type) = ConnectionManager {
- getConnectionManager :: WithMuxMode muxMode (OutboundConnectionManager muxMode socket peerAddr handle handleError m) (InboundConnectionManager muxMode socket peerAddr handle handleError m)
- readState :: STM m (Map peerAddr AbstractState)
- waitForOutboundDemotion :: peerAddr -> STM m ()
- data Connected peerAddr handle handleError
- = Connected !(ConnectionId peerAddr) !DataFlow !handle
- | Disconnected !(ConnectionId peerAddr) !(Maybe handleError)
- data OperationResult a
- resultInState :: OperationResult AbstractState -> AbstractState
- data DemotedToColdRemoteTr
- type AcquireOutboundConnection peerAddr handle handleError (m :: Type -> Type) = peerAddr -> m (Connected peerAddr handle handleError)
- type IncludeInboundConnection socket peerAddr handle handleError (m :: Type -> Type) = Word32 -> socket -> peerAddr -> m (Connected peerAddr handle handleError)
- acquireOutboundConnection :: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasInitiator muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> AcquireOutboundConnection peerAddr handle handleError m
- promotedToWarmRemote :: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasResponder muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> peerAddr -> m (OperationResult AbstractState)
- demotedToColdRemote :: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasResponder muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> peerAddr -> m (OperationResult AbstractState)
- releaseOutboundConnection :: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasInitiator muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> peerAddr -> m (OperationResult AbstractState)
- includeInboundConnection :: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasResponder muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> IncludeInboundConnection socket peerAddr handle handleError m
- releaseInboundConnection :: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasResponder muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> peerAddr -> m (OperationResult DemotedToColdRemoteTr)
- numberOfConnections :: forall (muxMode :: Mode) socket peerAddr handle handleError (m :: Type -> Type). HasResponder muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> STM m Int
- data OutboundConnectionManager (muxMode :: Mode) socket peerAddr handle handleError (m :: Type -> Type) where
- OutboundConnectionManager :: forall (muxMode :: Mode) peerAddr handle handleError (m :: Type -> Type) socket. HasInitiator muxMode ~ 'True => {..} -> OutboundConnectionManager muxMode socket peerAddr handle handleError m
- data InboundConnectionManager (muxMode :: Mode) socket peerAddr handle handleError (m :: Type -> Type) where
- InboundConnectionManager :: forall (muxMode :: Mode) socket peerAddr handle handleError (m :: Type -> Type). HasResponder muxMode ~ 'True => {..} -> InboundConnectionManager muxMode socket peerAddr handle handleError m
- data ConnectionManagerError peerAddr
- = ConnectionExists !Provenance !peerAddr !CallStack
- | ForbiddenConnection !(ConnectionId peerAddr) !CallStack
- | ImpossibleConnection !(ConnectionId peerAddr) !CallStack
- | ConnectionTerminating !(ConnectionId peerAddr) !CallStack
- | ConnectionTerminated !peerAddr !CallStack
- | ImpossibleState !peerAddr !CallStack
- | ForbiddenOperation !peerAddr !AbstractState !CallStack
- | UnknownPeer !peerAddr !CallStack
- data SomeConnectionManagerError = (Typeable addr, Show addr) => SomeConnectionManagerError !(ConnectionManagerError addr)
- data AbstractState
- data ConnectionManagerCounters = ConnectionManagerCounters {
- fullDuplexConns :: !Int
- duplexConns :: !Int
- unidirectionalConns :: !Int
- inboundConns :: !Int
- outboundConns :: !Int
- data WithMuxMode (mode :: Mode) a b where
- WithInitiatorMode :: forall a b. a -> WithMuxMode 'InitiatorMode a b
- WithResponderMode :: forall b a. b -> WithMuxMode 'ResponderMode a b
- WithInitiatorResponderMode :: forall a b. a -> b -> WithMuxMode 'InitiatorResponderMode a b
- withInitiatorMode :: forall (mode :: Mode) a b. HasInitiator mode ~ 'True => WithMuxMode mode a b -> a
- withResponderMode :: forall (mode :: Mode) a b. HasResponder mode ~ 'True => WithMuxMode mode a b -> b
- newEmptyPromiseIO :: (MonadSTM m, MonadThrow (STM m)) => m (PromiseReader m a, PromiseWriter m a)
- newtype PromiseReader (m :: Type -> Type) a = PromiseReader {
- readPromise :: STM m a
- readPromiseIO :: MonadSTM m => PromiseReader m a -> m a
- data PromiseWriter (m :: Type -> Type) a = PromiseWriter {
- writePromise :: a -> STM m ()
- forcePromise :: a -> STM m ()
- data PromiseWriterException = PromiseWriterBlocked
- data AssertionLocation peerAddr
- = ReleaseInboundConnection !(Maybe (ConnectionId peerAddr)) !AbstractState
- | AcquireOutboundConnection !(Maybe (ConnectionId peerAddr)) !AbstractState
- | ReleaseOutboundConnection !(Maybe (ConnectionId peerAddr)) !AbstractState
- | PromotedToWarmRemote !(Maybe (ConnectionId peerAddr)) !AbstractState
- | DemotedToColdRemote !(Maybe (ConnectionId peerAddr)) !AbstractState
- data MaybeUnknown state
- data Transition' state = Transition {}
- type Transition state = Transition' (MaybeUnknown state)
- type AbstractTransition = Transition' AbstractState
- mkTransition :: state -> state -> Transition state
- mkAbsTransition :: AbstractState -> AbstractState -> AbstractTransition
- type TransitionTrace peerAddr state = TransitionTrace' peerAddr (MaybeUnknown state)
- data TransitionTrace' peerAddr state = TransitionTrace {
- ttPeerAddr :: peerAddr
- ttTransition :: Transition' state
- type AbstractTransitionTrace peerAddr = TransitionTrace' peerAddr AbstractState
Connection manager core types
Connection Types
data AddressType Source #
Connection manager supports IPv4
and IPv6
addresses.
Instances
Show AddressType Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> AddressType -> ShowS # show :: AddressType -> String # showList :: [AddressType] -> ShowS # |
data Provenance Source #
Each connection is is either initiated locally (outbound) or by a remote peer (inbound).
Inbound | An inbound connection: one that was initiated by a remote peer. |
Outbound | An outbound connection: one that was initiated by us. |
Instances
Show Provenance Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> Provenance -> ShowS # show :: Provenance -> String # showList :: [Provenance] -> ShowS # | |
Eq Provenance Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types (==) :: Provenance -> Provenance -> Bool # (/=) :: Provenance -> Provenance -> Bool # | |
Ord Provenance Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types compare :: Provenance -> Provenance -> Ordering # (<) :: Provenance -> Provenance -> Bool # (<=) :: Provenance -> Provenance -> Bool # (>) :: Provenance -> Provenance -> Bool # (>=) :: Provenance -> Provenance -> Bool # max :: Provenance -> Provenance -> Provenance # min :: Provenance -> Provenance -> Provenance # |
Each connection negotiates if it is uni- or bi-directional. DataFlow
is a life time property of a connection, once negotiated it never changes.
NOTE: This type is isomorphic to DiffusionMode
for `node-to-node`
connections (see ntnDataFlow
), but it isn't
for `node-to-client` connections (see
`Ouroboros.Network.Diffusion.P2P.ntcDataFlow).
data TimeoutExpired Source #
Boolean like type which indicates if the timeout on OutboundStateDuplex
has expired.
Instances
Show TimeoutExpired Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> TimeoutExpired -> ShowS # show :: TimeoutExpired -> String # showList :: [TimeoutExpired] -> ShowS # | |
Eq TimeoutExpired Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types (==) :: TimeoutExpired -> TimeoutExpired -> Bool # (/=) :: TimeoutExpired -> TimeoutExpired -> Bool # | |
Ord TimeoutExpired Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types compare :: TimeoutExpired -> TimeoutExpired -> Ordering # (<) :: TimeoutExpired -> TimeoutExpired -> Bool # (<=) :: TimeoutExpired -> TimeoutExpired -> Bool # (>) :: TimeoutExpired -> TimeoutExpired -> Bool # (>=) :: TimeoutExpired -> TimeoutExpired -> Bool # max :: TimeoutExpired -> TimeoutExpired -> TimeoutExpired # min :: TimeoutExpired -> TimeoutExpired -> TimeoutExpired # |
data ConnectionType Source #
Either unnegotiated or negotiated unidirectional or duplex connections.
This is not a static property of a connection. It is used by PrunePolicy
.
Note: the order matters, it can be used by a PickPolicy
, e.g.
simplePickPolicy
.
UnnegotiatedConn !Provenance | An unnegotiated connection. |
InboundIdleConn !DataFlow | An inbound idle connection. |
OutboundIdleConn !DataFlow | An outbound idle connection. |
NegotiatedConn !Provenance !DataFlow | A negotiated connection, which is used in only one direction indicated
by |
DuplexConn | A connection which is running in full duplex mode. |
Instances
Show ConnectionType Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> ConnectionType -> ShowS # show :: ConnectionType -> String # showList :: [ConnectionType] -> ShowS # | |
Eq ConnectionType Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types (==) :: ConnectionType -> ConnectionType -> Bool # (/=) :: ConnectionType -> ConnectionType -> Bool # | |
Ord ConnectionType Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types compare :: ConnectionType -> ConnectionType -> Ordering # (<) :: ConnectionType -> ConnectionType -> Bool # (<=) :: ConnectionType -> ConnectionType -> Bool # (>) :: ConnectionType -> ConnectionType -> Bool # (>=) :: ConnectionType -> ConnectionType -> Bool # max :: ConnectionType -> ConnectionType -> ConnectionType # min :: ConnectionType -> ConnectionType -> ConnectionType # |
Connection Handler
ConnectionHandler
provides monadic action which runs handshake
negotiation and starts the multiplexer. It's the component which has access
to underlying socket. There's one-to-one correspondence between sockets and
threads that run the handler.
ConnectionHandlerFn
- is the type of callback executed for each connection. All arguments are provided by the connection manager.
ConnectionHandler
- is a newtype wrapper which provides inbound / outbound handlers depending
on
.Mode
newtype MaskedAction (m :: Type -> Type) a Source #
Handler action is started with asynchronous exceptions masked; this allows to install exception handlers in an async-safe way.
MaskedAction | |
|
type ConnectionHandlerFn handlerTrace socket peerAddr handle handleError version (m :: Type -> Type) = socket -> PromiseWriter m (Either handleError (HandshakeConnectionResult handle version)) -> Tracer m handlerTrace -> ConnectionId peerAddr -> (DiffTime -> socket -> m (Bearer m)) -> MaskedAction m () Source #
MaskedAction which is executed by thread designated for a given connection.
PromiseWriter
allows to notify the ConnectionManager
about the result of
handshake negotiation.
Note: PromiseWriter
could be replaced with an stm action which is
accessing the TVar
which holds state of the connection.
newtype ConnectionHandler (muxMode :: Mode) handlerTrace socket peerAddr handle handleError version (m :: Type -> Type) Source #
Connection handler action. It is index by muxMode ::
.
There's one Mode
ConnectionHandlerFn
per provenance, possibly limited by
muxMode
.
ConnectionHandler | |
|
data ExceptionInHandler where Source #
Exception which where caught in the connection thread and were re-thrown in
the main thread by the rethrowPolicy
.
ExceptionInHandler :: forall peerAddr. (Typeable peerAddr, Show peerAddr) => !peerAddr -> !SomeException -> ExceptionInHandler |
Instances
Exception ExceptionInHandler Source # | |
Show ExceptionInHandler Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> ExceptionInHandler -> ShowS # show :: ExceptionInHandler -> String # showList :: [ExceptionInHandler] -> ShowS # |
data HandleErrorType Source #
Data type used to classify handleErrors
.
HandshakeFailure | Handshake negotiation failed. This is not a protocol error. |
HandshakeProtocolViolation | Handshake protocol error. This should include timeout errors or any IO errors. |
data HandshakeConnectionResult handle version Source #
HandshakeConnectionQuery | Handshake saw a query. |
HandshakeConnectionResult handle version | Handshake resulted in a connection and version. |
Prune Policy
type PrunePolicy peerAddr = StdGen -> Map peerAddr ConnectionType -> Int -> Set peerAddr Source #
PrunePolicy
allows to pick a select peers from which we will disconnect
(we use TCP
reset). The chosen connections will be terminated by the
connection manger once it detects that there are too many inbound
connections.
simplePrunePolicy :: Ord peerAddr => PrunePolicy peerAddr Source #
The simplest PrunePolicy
, it should only be used for tests.
Connection Manager
Connection Manager Arguments
data ConnectionManager (muxMode :: Mode) socket peerAddr handle handleError (m :: Type -> Type) Source #
We identify resources (e.g. Socket
or
HANDLE
) by their address. It is enough for us to use
just the remote address rather than connection identifier, since we need one
connection towards that peer, even if we are connected through multiple
local addresses. It is safe to share a connection manager with multiple
listening sockets.
ConnectionManager | |
|
API
data Connected peerAddr handle handleError Source #
Result of acquireOutboundConnection
or includeInboundConnection
.
Connected !(ConnectionId peerAddr) !DataFlow !handle | We are connected and mux is running. |
Disconnected !(ConnectionId peerAddr) !(Maybe handleError) | There was an error during handshake negotiation. Implementation detail: we return |
data OperationResult a Source #
Custom either type for result of various methods.
Instances
Functor OperationResult Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types fmap :: (a -> b) -> OperationResult a -> OperationResult b # (<$) :: a -> OperationResult b -> OperationResult a # | |
Show a => Show (OperationResult a) Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> OperationResult a -> ShowS # show :: OperationResult a -> String # showList :: [OperationResult a] -> ShowS # |
data DemotedToColdRemoteTr Source #
Return value of releaseInboundConnection
to inform the caller about
the transition.
CommitTr |
|
KeepTr | Either |
Instances
Show DemotedToColdRemoteTr Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> DemotedToColdRemoteTr -> ShowS # show :: DemotedToColdRemoteTr -> String # showList :: [DemotedToColdRemoteTr] -> ShowS # |
type AcquireOutboundConnection peerAddr handle handleError (m :: Type -> Type) = peerAddr -> m (Connected peerAddr handle handleError) Source #
type IncludeInboundConnection socket peerAddr handle handleError (m :: Type -> Type) Source #
Outbound side
acquireOutboundConnection :: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasInitiator muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> AcquireOutboundConnection peerAddr handle handleError m Source #
Include outbound connection into ConnectionManager
.
This executes:
- \(Reserve\) to \(Negotiated^{*}_{Outbound}\) transitions
- \(PromotedToWarm^{Duplex}_{Local}\) transition
- \(Awake^{Duplex}_{Local}\) transition
promotedToWarmRemote :: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasResponder muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> peerAddr -> m (OperationResult AbstractState) Source #
Notify the ConnectionManager
that a remote end promoted us to a
warm peer.
This executes either:
- \(PromotedToWarm^{Duplex}_{Remote}\) transition,
- \(Awake^{*}_{Remote}\) transition
from the specification.
demotedToColdRemote :: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasResponder muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> peerAddr -> m (OperationResult AbstractState) Source #
Notify the ConnectionManager
that a remote end demoted us to a /cold
peer/.
This executes:
- \(DemotedToCold^{*}_{Remote}\) transition.
This method is idempotent.
releaseOutboundConnection Source #
:: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasInitiator muxMode ~ 'True | |
=> ConnectionManager muxMode socket peerAddr handle handleError m | |
-> peerAddr | |
-> m (OperationResult AbstractState) | reports the from-state. |
Release outbound connection.
This executes:
- \(DemotedToCold^{*}_{Local}\) transitions
Inbound side
includeInboundConnection :: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasResponder muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> IncludeInboundConnection socket peerAddr handle handleError m Source #
Include an inbound connection into ConnectionManager
.
This executes:
- \(Reserve\) to \(Negotiated^{*}_{Outbound}\) transitions
- \(PromotedToWarm^{Duplex}_{Local}\) transition
- \(Awake^{Duplex}_{Local}\) transition
releaseInboundConnection :: forall (muxMode :: Mode) socket peerAddr handle handleError m. HasResponder muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> peerAddr -> m (OperationResult DemotedToColdRemoteTr) Source #
Release outbound connection. Returns if the operation was successful.
This executes:
- \(Commit*{*}\) transition
- \(TimeoutExpired\) transition
numberOfConnections :: forall (muxMode :: Mode) socket peerAddr handle handleError (m :: Type -> Type). HasResponder muxMode ~ 'True => ConnectionManager muxMode socket peerAddr handle handleError m -> STM m Int Source #
Number of connections tracked by the server.
Private API
data OutboundConnectionManager (muxMode :: Mode) socket peerAddr handle handleError (m :: Type -> Type) where Source #
Outbound connection manager API.
OutboundConnectionManager | |
|
data InboundConnectionManager (muxMode :: Mode) socket peerAddr handle handleError (m :: Type -> Type) where Source #
Inbound connection manager API. For a server implementation we also need to know how many connections are now managed by the connection manager.
This type is an internal detail of ConnectionManager
InboundConnectionManager | |
|
Exceptions
data ConnectionManagerError peerAddr Source #
Exceptions used by ConnectionManager
.
ConnectionExists !Provenance !peerAddr !CallStack | A connection manager was asked for an outbound connection and there either exists a connection used in outbound direction or a reservation for an outbound connection. |
ForbiddenConnection !(ConnectionId peerAddr) !CallStack | Connection manager was asked for an outbound connection which turned out to be unidirectional inbound, and thus it cannot be re-used.. |
ImpossibleConnection !(ConnectionId peerAddr) !CallStack | Connections that would be forbidden by the kernel ( |
ConnectionTerminating !(ConnectionId peerAddr) !CallStack | Connection is now terminating. |
ConnectionTerminated !peerAddr !CallStack | Connection has terminated. |
ImpossibleState !peerAddr !CallStack | Connection manager in impossible state. |
ForbiddenOperation !peerAddr !AbstractState !CallStack | A forbidden operation in the given connection state. |
UnknownPeer !peerAddr !CallStack | A connection does not exists. Only thrown when an existing connection was expected. |
Instances
(Show peerAddr, Typeable peerAddr) => Exception (ConnectionManagerError peerAddr) Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types toException :: ConnectionManagerError peerAddr -> SomeException # fromException :: SomeException -> Maybe (ConnectionManagerError peerAddr) # displayException :: ConnectionManagerError peerAddr -> String # backtraceDesired :: ConnectionManagerError peerAddr -> Bool # | |
Show peerAddr => Show (ConnectionManagerError peerAddr) Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> ConnectionManagerError peerAddr -> ShowS # show :: ConnectionManagerError peerAddr -> String # showList :: [ConnectionManagerError peerAddr] -> ShowS # |
data SomeConnectionManagerError Source #
Existential wrapper for
. It allows to
use ConnectionManagerError
peerAddrfromException
, without being bothered about the address type.
(Typeable addr, Show addr) => SomeConnectionManagerError !(ConnectionManagerError addr) |
Instances
data AbstractState Source #
Useful for tracing and error messages.
UnknownConnectionSt | Unknown connection. This state indicates the connection manager removed this connection from its state. |
ReservedOutboundSt | |
UnnegotiatedSt !Provenance | |
InboundIdleSt !DataFlow | |
InboundSt !DataFlow | |
OutboundUniSt | |
OutboundDupSt !TimeoutExpired | |
OutboundIdleSt !DataFlow | |
DuplexSt | |
WaitRemoteIdleSt | |
TerminatingSt | |
TerminatedSt |
Instances
Show AbstractState Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> AbstractState -> ShowS # show :: AbstractState -> String # showList :: [AbstractState] -> ShowS # | |
Eq AbstractState Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types (==) :: AbstractState -> AbstractState -> Bool # (/=) :: AbstractState -> AbstractState -> Bool # | |
Ord AbstractState Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types compare :: AbstractState -> AbstractState -> Ordering # (<) :: AbstractState -> AbstractState -> Bool # (<=) :: AbstractState -> AbstractState -> Bool # (>) :: AbstractState -> AbstractState -> Bool # (>=) :: AbstractState -> AbstractState -> Bool # max :: AbstractState -> AbstractState -> AbstractState # min :: AbstractState -> AbstractState -> AbstractState # |
Counters
data ConnectionManagerCounters Source #
Counters for tracing and analysis purposes
ConnectionManagerCounters | |
|
Instances
Mux types
data WithMuxMode (mode :: Mode) a b where Source #
WithInitiatorMode :: forall a b. a -> WithMuxMode 'InitiatorMode a b | |
WithResponderMode :: forall b a. b -> WithMuxMode 'ResponderMode a b | |
WithInitiatorResponderMode :: forall a b. a -> b -> WithMuxMode 'InitiatorResponderMode a b |
withInitiatorMode :: forall (mode :: Mode) a b. HasInitiator mode ~ 'True => WithMuxMode mode a b -> a Source #
withResponderMode :: forall (mode :: Mode) a b. HasResponder mode ~ 'True => WithMuxMode mode a b -> b Source #
Promise
Promise interface, backed by a StrictTMVar
.
Making two separate interfaces: PromiseWriter
and PromiseReader
allows us
to make a clear distinction between consumer and producers threads.
newEmptyPromiseIO :: (MonadSTM m, MonadThrow (STM m)) => m (PromiseReader m a, PromiseWriter m a) Source #
newtype PromiseReader (m :: Type -> Type) a Source #
PromiseReader | |
|
readPromiseIO :: MonadSTM m => PromiseReader m a -> m a Source #
data PromiseWriter (m :: Type -> Type) a Source #
PromiseWriter | |
|
data PromiseWriterException Source #
Instances
Tracing
data AssertionLocation peerAddr Source #
AssertionLocation
contains constructors that situate the location of the tracing so
one can be sure where the assertion came from as well as the all relevant information.
ReleaseInboundConnection !(Maybe (ConnectionId peerAddr)) !AbstractState | |
AcquireOutboundConnection !(Maybe (ConnectionId peerAddr)) !AbstractState | |
ReleaseOutboundConnection !(Maybe (ConnectionId peerAddr)) !AbstractState | |
PromotedToWarmRemote !(Maybe (ConnectionId peerAddr)) !AbstractState | |
DemotedToColdRemote !(Maybe (ConnectionId peerAddr)) !AbstractState |
Instances
Show peerAddr => Show (AssertionLocation peerAddr) Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> AssertionLocation peerAddr -> ShowS # show :: AssertionLocation peerAddr -> String # showList :: [AssertionLocation peerAddr] -> ShowS # |
data MaybeUnknown state Source #
A custom version of Maybe
type, which allows to explicitly represent
connections which are not registered by the connection manager.
Known !state | Known connection in |
Race !state | There is a possible race condition between connection finalizer and
either inbound or outbound connection registration. If that happens we
use |
Unknown | Connection is is not known to the connection manager. |
Instances
Functor MaybeUnknown Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types fmap :: (a -> b) -> MaybeUnknown a -> MaybeUnknown b # (<$) :: a -> MaybeUnknown b -> MaybeUnknown a # | |
Show state => Show (MaybeUnknown state) Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> MaybeUnknown state -> ShowS # show :: MaybeUnknown state -> String # showList :: [MaybeUnknown state] -> ShowS # |
data Transition' state Source #
Instances
Functor Transition' Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types fmap :: (a -> b) -> Transition' a -> Transition' b # (<$) :: a -> Transition' b -> Transition' a # | |
Show state => Show (Transition' state) Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> Transition' state -> ShowS # show :: Transition' state -> String # showList :: [Transition' state] -> ShowS # | |
Eq state => Eq (Transition' state) Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types (==) :: Transition' state -> Transition' state -> Bool # (/=) :: Transition' state -> Transition' state -> Bool # |
type Transition state = Transition' (MaybeUnknown state) Source #
mkTransition :: state -> state -> Transition state Source #
type TransitionTrace peerAddr state = TransitionTrace' peerAddr (MaybeUnknown state) Source #
data TransitionTrace' peerAddr state Source #
TransitionTrace | |
|
Instances
Functor (TransitionTrace' peerAddr) Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types fmap :: (a -> b) -> TransitionTrace' peerAddr a -> TransitionTrace' peerAddr b # (<$) :: a -> TransitionTrace' peerAddr b -> TransitionTrace' peerAddr a # | |
(Show peerAddr, Show state) => Show (TransitionTrace' peerAddr state) Source # | |
Defined in Ouroboros.Network.ConnectionManager.Types showsPrec :: Int -> TransitionTrace' peerAddr state -> ShowS # show :: TransitionTrace' peerAddr state -> String # showList :: [TransitionTrace' peerAddr state] -> ShowS # |
type AbstractTransitionTrace peerAddr = TransitionTrace' peerAddr AbstractState Source #