▼NApache | |
▼NQpid | |
▼NProton | |
►NBuffer | |
CIProtonBuffer | |
CIProtonBufferAccessors | Interface for proton buffer primitive type accessors that can be used with custom types to extend or otherwise customize buffer access |
CIProtonBufferAllocator | Defines the interface for a IProtonBuffer allocator that can be used by the Proton library to allow customization of the buffer types used for IO and application level buffer management |
CIProtonCompositeBuffer | A composite buffer is used to make a collection of other proton buffer instances appear as one cohesive buffer which allows the user to remain ignorant of the underlying buffer structure and in most cases does not require any special handling by the user |
CIReadableComponent | Provides a view of an individual component of a proton buffer during a call to the readable buffer processing methods |
CIWritableComponent | |
CProtonBufferInputStream | Provides a read-only stream view of a proton buffer instance. The stream allows seeking within the readable bytes portion of the provided buffer but does not allow altering the readable length or writing to the buffer |
CProtonBufferOutputStream | Provides a write-only stream accessor of a proton buffer instance. The stream does not allow reading of the buffer that it wraps |
CProtonByteBuffer | A proton buffer implementation that wraps a single heap allocated byte array and provides read and write operations on that array along with self resizing based on capacity limits |
CProtonByteBufferAllocator | An buffer allocator instance that creates heap based buffer objects |
CProtonCompositeBuffer | A composite buffer contains zero, one or more proton buffer instances chained together to behave as if it were one single contiguous buffer which can be read or written to |
►NClient | |
►NConcurrent | |
CAtomicBoolean | Provides a boolean value that may be updated and read atomically |
CAtomicInteger | Simple Atomic abstraction around the integer type to make atomic operations on integer types simpler to manage in code. The default value of this type is zero |
CAtomicLong | Simple Atomic abstraction around the long type to make atomic operations on long types simpler to manage in code. The default value of this type is zero |
CAtomicReference | Provides an object reference that may be updated and read atomically |
CDefaultEventLoop | Default event loop implementation |
CIEventLoop | Single threaded event processing loop interface. Implementations accept queue'd actions to be processed within the event loop in serial fashion |
CIScheduledTask | Represents a scheduled item of work that will be run on the event loop either once or on a repeating basis. The task allows for easy cancelation and for asynchronous awaits via the return completion Task |
CRejectedExecutionException | Exception that is thrown when a "Task" or "Action" that is submitted to an executor implementation is rejected for some reason such as capacity limits being hit or the executor being shut down |
►NExceptions | |
CClientConnectionRedirectedException | A ClientIOException type that defines that the remote peer has requested that this connection be redirected to some alternative peer |
CClientConnectionRemotelyClosedException | Exception thrown when the remote peer actively closes the connection} by sending and AMQP Close frame or when the IO layer is disconnected due to some other reason such as a security error or transient network error |
CClientConnectionSecurityException | Connection level Security Exception used to indicate a security violation has occurred |
CClientConnectionSecuritySaslException | Connection level SASL Security Exception used to indicate a security violation has occurred |
CClientDeliveryAbortedException | Thrown in cases where an action was requested that cannot be performed because the delivery being operated on has been aborted by the remote sender |
CClientDeliveryIsPartialException | Thrown in cases where an action was requested that cannot be performed because the delivery being operated on is only the partial Transfer payload |
CClientDeliveryStateException | Thrown from client API that deal with a Delivery or Tracker where the outcome that results from that API can affect whether the API call succeeded or failed. Such a case might be that a sent message is awaiting a remote Accepted outcome but instead the remote sends Rejected outcome |
CClientException | Represents a non-fatal exception that occurs from a Client connection or one of its resources. These error types can typically be recovered from without a full tear down and rebuild of the connection. One example might be a failure to commit a transaction due to a forced roll back on the remote side of the connection |
CClientIdleTimeoutException | Thrown when the Client fails a connection due to idle timeout |
CClientIllegalStateException | A non-fatal exception type thrown when an operation was attempted but the client resource was in a state that does not allow the operation |
CClientIOException | Exception type that is thrown when the client has encountered an unrecoverable error |
CClientLinkRedirectedException | Root exception type for cases of remote closure or client created Sender or Receiver |
CClientLinkRemotelyClosedException | Root exception type for cases of remote closure or client created Sender or Receiver |
CClientMessageFormatViolationException | Exception thrown from Message instances when the body section specified violates the configure message format of the message that is being created |
CClientOperationTimedOutException | Indicates that an operation in the client timed out waiting for completion |
CClientResourceRemotelyClosedException | Root exception type for cases of remote closure or client created resources other than the Client Connection} which will throw exceptions rooted from the ClientConnectionRemotelyClosedException to indicate a fatal connection level error that requires a new connection to be created |
CClientSendTimedOutException | Thrown when a message send operation times out either waiting for credit or waiting for some other resource to be ready to allow a send to trigger |
CClientSessionRemotelyClosedException | Root exception type for cases of remote closure or client created Session |
CClientTransactionDeclarationException | Thrown when a transaction declaration fails or is rejected by the remote |
CClientTransactionInDoubtException | Thrown when a transaction operation fails and state is now unknown |
CClientTransactionNotActiveException | Thrown when a client attempt to commit or roll-back when no transaction has been declared |
CClientTransactionRolledBackException | Thrown when a transaction operation fails due to the remote having already rolled back the transaction |
CClientUnsupportedOperationException | Specialization of the non-fatal illegal state exception that indicates that the error relates to an attempt to perform some operation that is not supported either due to access restriction or due to the resource being used not having implemented that behavior |
►NImplementation | |
CClientAccepted | Client version of the proton Accepted delivery state |
CClientConnection | The client connection class manages a single connection to a remote AMQP peer and handles connection errors and reconnection operations if those are enabled |
CClientConnectionCapabilities | Tracks available known capabilities for the connection to allow the client to know what features are supported on the current connection |
CClientDelivery | Client inbound delivery API that wraps the proton resources and provides API to operate on them |
CClientDeliveryState | Client implementation of a delivery state mapping to the proton types |
CClientErrorCondition | Client error condition implementation which serves as a layer over the proton based version allowing for external implementations and mapping to / from Symbol types which the client tries not to expose |
CClientInstance | The client type servers as a container of connections and provides a means of closing all open connection in a single operation which can be performed synchronously or provides a Task type that allows a caller to be notified once all connections have been closed |
CClientLinkType | |
CClientMessage | |
CClientModified | Client version of the proton Modified delivery state |
CClientNextReceiverSelector | |
CClientNoOpStreamTracker | |
CClientNoOpTracker | |
CClientReceiver | Client receiver implementation which provides a wrapper around the proton receiver link and processes incoming deliveries with options for queueing with a credit window |
CClientReceiverLinkType | Base type used to implement common AMQP receiver operations shared by all the client's receiver types |
CClientRedirect | Support class that houses the information and API needed to process redirection information sent from a remote |
CClientRejected | Client version of the proton Rejected delivery state |
CClientReleased | Client version of the proton Released delivery state |
CClientSender | Sender implementation that send complete messages on a remote link |
CClientSession | Client session that wraps a proton session instance and provides the higher level clint API for managing links and creating session scoped transaction instances |
CClientStreamDelivery | The stream delivery type manages the underlying state of an incoming streaming message delivery and provides the stream type used to read and block for reads when not all requested message data has arrived. The delivery will also manage settlement of a streaming delivery and apply receiver configuration rules like auto settlement to the delivery as incoming portions of the message arrive |
CClientStreamReceiver | Implements the streaming message receiver which allows for reading of large messages in smaller chunks. The API allows for multiple calls to receiver but any call that happens after a large message receives begins will be blocked until the previous large message is fully read and the next arrives |
CClientStreamReceiverMessage | |
CClientStreamSender | Implements the stream sender using a stateful current outgoing message that prevents any sends other than to the current message until the current is completed |
CClientStreamSenderMessage | |
CClientStreamSession | |
CClientStreamTracker | |
CClientTracker | |
CClientTransactional | Client version of the proton Transactional delivery state |
CClientTransportProxy | Creates a proxy layer between a transport instance and an engine instance which isolates concerns of mapping the events from a transport to a given engine instance and prevents possible misdirected event routing during reconnects etc where the active transport and engine will switch |
►NTransport | |
CIOContext | Represents an IO context used by clients to commicate with remote services and provides a single threaded event loop used to manage IO based work and connection related services |
CITransport | Base transport interface which defines the API of a wire level IO transport used by the client |
CTcpTransport | A TCP only transport implementation that provides extension points for SSL and or WS based transports to add their handlers. These transports are registered with an event loop where all transport work and events are processed in serial fashion with the same thread |
►NUtilities | |
CFifoDeliveryQueue | Simple first in / first out delivery queue with no reordering for priority or other criteria |
CIDeliveryQueue | A generic delivery queue used to hold messages or other delivery objects that need to be consumed in order and also provides put-back options for redelivery scenarios |
CIdGenerator | |
CReconnectLocationPool | |
CClientOptions | |
CConnectionEvent | An event object that accompanies events fired to handlers configured in the Connection options which are signaled during specific Connection event points |
CConnectionOptions | |
CDisconnectionEvent | An event object that accompanies events fired to handlers configured in the Connection options which are signaled during specific Connection event points |
CIAdvancedMessage | A single AMQP Message instance used by senders and receivers to provide a lower level abstraction around an AMQP message than the basic IMessage type but still provides the IMessage interface simpler access where needed |
CIClient | The Container that hosts one ore more AMQP connections that share a given AMQP container Id |
CIConnection | A single AMQP Connection instance |
CIDelivery | A single AMQP delivery tracker instance |
CIDeliveryState | |
CIErrorCondition | An immutable error condition that carries information that aids in determining the factors that lead to the error |
CILink | A single AMQP link which can be a sender or receiver instance but each expose a common set of link properties whose API is presented here |
CIMessage | A single AMQP Message instance used by senders and receivers to provide a high level abstraction around an AMQP message |
CIReceiver | A single AMQP receiver instance |
CISender | A single AMQP sender instance |
CISession | A single AMQP session instance |
CISource | Represents the remote Source instance for a sender or receiver link |
CIStreamDelivery | A specialized delivery type that is returned from the stream receiver which can be used to read incoming large messages that are streamed via multiple incoming AMQP transfer frames |
CIStreamReceiver | A single AMQP stream receiver instance |
CIStreamReceiverMessage | A specialized message type that represents a streamed delivery possibly spanning many incoming AMQP transfer frames from the remote peer. It is possible for various calls in this message type to block while awaiting the receipt of sufficient bytes to provide the result |
CIStreamSender | A single AMQP stream sender instance which can be used to transmit large message payloads to the remote without needing to load the full message contents into memory. The streaming sender will also provide flow control that attempts to provide additional safety values for out of memory situations |
CIStreamSenderMessage | A specialized streaming message type used to operate on a streamed message which allows message data to be written in one or more transfer frames to the remote allowing for very large message transmission with limited memory overhead |
CIStreamTracker | Special streaming sender related tracker that is linked to a stream sender message and provides the tracker functions for those types of messages |
CITarget | Represents the remote Target instance for a sender or receiver link |
CITracker | A single AMQP delivery tracker instance |
COutputStreamOptions | Options class that controls various aspects of a write only stream instance created to write the contents of a section of a stream sender message |
CReceiverOptions | |
CReconnectLocation | Represents a fixed location that can be used for connection by the client should the initially specified connection location be unreachable or become unavailable during the lifetime of the connection |
CReconnectOptions | Reconnection options which will control how a connection deals will connection loss and or inability to connect to the host it was provided at create time |
CSaslOptions | Options that control how the SASL authentication process is performed |
CSenderOptions | |
CSessionOptions | |
CSourceOptions | Options used to configure the source when a terminus is being created |
CSslOptions | Options that control the SSL level transport configuration |
CStreamReceiverOptions | |
CStreamSenderOptions | Special sender options that are applied the streaming senders which allow transmission of large message payloads |
CTargetOptions | |
CTerminusOptions | Base options type for the terminus configuration for Source and Target types that configure the nodes for Sender and Receiver links |
CTransportOptions | Options that control the I/O level transport configuration |
►NCodec | |
►NDecoders | |
►NMessaging | |
CAcceptedTypeDecoder | |
CAmqpSequenceTypeDecoder | |
CAmqpValueTypeDecoder | |
CApplicationPropertiesTypeDecoder | |
CDataTypeDecoder | |
CDeleteOnCloseTypeDecoder | |
CDeleteOnNoLinksOrMessagesTypeDecoder | |
CDeleteOnNoLinksTypeDecoder | |
CDeleteOnNoMessagesTypeDecoder | |
CDeliveryAnnotationsTypeDecoder | |
CFooterTypeDecoder | |
CHeaderTypeDecoder | |
CMessageAnnotationsTypeDecoder | |
CModifiedTypeDecoder | |
CPropertiesTypeDecoder | |
CReceivedTypeDecoder | |
CRejectedTypeDecoder | |
CReleasedTypeDecoder | |
CSourceTypeDecoder | |
CTargetTypeDecoder | |
►NPrimitives | |
CAbstractArrayTypeDecoder | |
CAbstractBinaryTypeDecoder | |
CAbstractListTypeDecoder | Base list type decoder used by decoders of various AMQP types that represent list style serialized objects |
CAbstractMapTypeDecoder | Base map type decoder used by decoders of various AMQP types that represent map style serialized objects |
CAbstractStringTypeDecoder | Base map type decoder used by decoders of various AMQP types that represent map style serialized objects |
CAbstractSymbolTypeDecoder | Base symbol type decoder used by decoders of various AMQP types that represent map style serialized objects |
CArray32TypeDecoder | |
CArray8TypeDecoder | |
CBinary32TypeDecoder | |
CBinary8TypeDecoder | |
CBooleanFalseTypeDecoder | |
CBooleanTrueTypeDecoder | |
CBooleanTypeDecoder | |
CByteTypeDecoder | |
CCharacterTypeDecoder | |
CDecimal128TypeDecoder | |
CDecimal32TypeDecoder | |
CDecimal64TypeDecoder | |
CDoubleTypeDecoder | |
CFloatTypeDecoder | |
CIBinaryTypeDecoder | |
CIListTypeDecoder | Interface for type decoders that handle AMQP List encodings |
CIMapTypeDecoder | Interface for type decoders that handle AMQP Map encodings |
CInteger32TypeDecoder | |
CInteger8TypeDecoder | |
CIStringTypeDecoder | Interface for type decoders that handle AMQP Map encodings |
CISymbolTypeDecoder | Interface for type decoders that handle AMQP Symbol encodings |
CList0TypeDecoder | |
CList32TypeDecoder | |
CList8TypeDecoder | |
CLong32TypeDecoder | |
CLong8TypeDecoder | |
CMap32TypeDecoder | |
CMap8TypeDecoder | |
CNullTypeDecoder | |
CShortTypeDecoder | |
CString32TypeDecoder | |
CString8TypeDecoder | |
CSymbol32TypeDecoder | |
CSymbol8TypeDecoder | |
CTimestampTypeDecoder | |
CUnsignedByteTypeDecoder | |
CUnsignedInteger0TypeDecoder | |
CUnsignedInteger32TypeDecoder | |
CUnsignedInteger8TypeDecoder | |
CUnsignedLong0TypeDecoder | |
CUnsignedLong64TypeDecoder | |
CUnsignedLong8TypeDecoder | |
CUnsignedShortTypeDecoder | |
CUuidTypeDecoder | |
►NSecurity | |
CSaslChallengeTypeDecoder | |
CSaslInitTypeDecoder | |
CSaslMechanismsTypeDecoder | |
CSaslOutcomeTypeDecoder | |
CSaslResponseTypeDecoder | |
►NTransactions | |
CCoordinatorTypeDecoder | |
CDeclaredTypeDecoder | |
CDeclareTypeDecoder | |
CDischargeTypeDecoder | |
CTransactionalStateTypeDecoder | |
►NTransport | |
CAttachTypeDecoder | |
CBeginTypeDecoder | |
CCloseTypeDecoder | |
CDetachTypeDecoder | |
CDispositionTypeDecoder | |
CEndTypeDecoder | |
CErrorConditionTypeDecoder | |
CFlowTypeDecoder | |
COpenTypeDecoder | |
CTransferTypeDecoder | |
CAbstractDescribedTypeDecoder | |
CAbstractPrimitiveTypeDecoder | |
CProtonDecoder | |
CProtonDecoderFactory | Defines a factory class that creates Proton specific Decoder types |
CProtonDecoderState | |
CProtonStreamDecoder | |
CProtonStreamDecoderFactory | Defines a factory class that creates Proton specific Decoder types |
CProtonStreamDecoderState | |
CUnknownDescribedTypeDecoder | |
►NEncoders | |
►NMessaging | |
CAcceptedTypeEncoder | |
CAmqpSequenceTypeEncoder | |
CAmqpValueTypeEncoder | |
CApplicationPropertiesTypeEncoder | |
CDataTypeEncoder | |
CDeleteOnCloseTypeEncoder | |
CDeleteOnNoLinksOrMessagesTypeEncoder | |
CDeleteOnNoLinksTypeEncoder | |
CDeleteOnNoMessagesTypeEncoder | |
CDeliveryAnnotationsTypeEncoder | |
CFooterTypeEncoder | |
CHeaderTypeEncoder | |
CMessageAnnotationsTypeEncoder | |
CModifiedTypeEncoder | |
CPropertiesTypeEncoder | |
CReceivedTypeEncoder | |
CRejectedTypeEncoder | |
CReleasedTypeEncoder | |
CSourceTypeEncoder | |
CTargetTypeEncoder | |
►NPrimitives | |
CArrayTypeEncoder | Interface for an type encoders that handle primitive types |
CBinaryTypeEncoder | Type encoder that handles writing Binary types |
CBooleanTypeEncoder | Type encoder that handles writing Boolean types |
CByteTypeEncoder | Type encoder that handles writing Byte types |
CCharacterTypeEncoder | Type encoder that handles writing Char types |
CDecimal128TypeEncoder | Type encoder that handles writing Decimal128 types |
CDecimal32TypeEncoder | Type encoder that handles writing Decimal32 types |
CDecimal64TypeEncoder | Type encoder that handles writing Decimal64 types |
CDoubleTypeEncoder | Type encoder that handles writing Double types |
CFloatTypeEncoder | Type encoder that handles writing Float types |
CIntegerTypeEncoder | Type encoder that handles writing Integer types |
CListTypeEncoder | Type encoder that handles writing List types |
CLongTypeEncoder | Type encoder that handles writing Long types |
CMapTypeEncoder | Type encoder that handles writing Map types |
CNullTypeEncoder | Type encoder that handles writing Null types |
CShortTypeEncoder | Type encoder that handles writing Short types |
CStringTypeEncoder | Type encoder that handles writing String types |
CSymbolTypeEncoder | Type encoder that handles writing Symbol types |
CTimestampTypeEncoder | Type encoder that handles writing Timestamp types |
CUnsignedByteTypeEncoder | Type encoder that handles writing UnsignedByte types |
CUnsignedIntegerTypeEncoder | Type encoder that handles writing UnsignedInteger types |
CUnsignedLongTypeEncoder | Type encoder that handles writing UnsignedLong types |
CUnsignedShortTypeEncoder | Type encoder that handles writing UnsignedShort types |
CUuidTypeEncoder | Type encoder that handles writing Uuid types |
►NSecurity | |
CSaslChallengeTypeEncoder | |
CSaslInitTypeEncoder | |
CSaslMechanismsTypeEncoder | |
CSaslOutcomeTypeEncoder | |
CSaslResponseTypeEncoder | |
►NTransactions | |
CCoordinatorTypeEncoder | |
CDeclaredTypeEncoder | |
CDeclareTypeEncoder | |
CDischargeTypeEncoder | |
CTransactionalStateTypeEncoder | |
►NTransport | |
CAttachTypeEncoder | |
CBeginTypeEncoder | |
CCloseTypeEncoder | |
CDetachTypeEncoder | |
CDispositionTypeEncoder | |
CEndTypeEncoder | |
CErrorConditionTypeEncoder | |
CFlowTypeEncoder | |
COpenTypeEncoder | |
CTransferTypeEncoder | |
CAbstractDescribedListTypeEncoder | |
CAbstractDescribedMapTypeEncoder | |
CAbstractDescribedTypeEncoder | |
CAbstractPrimitiveTypeEncoder | |
CDeliveryTagTypeEncoder | |
CIPrimitiveTypeEncoder | Interface for an type encoders that handle primitive types |
CIUtf8Encoder | Interface for an external UTF8 Encoder that can be supplied by a client which implements custom encoding logic optimized for the application using the Codec |
CProtonEncoder | |
CProtonEncoderFactory | Defines a factory class that creates Proton specific Encoder types |
CProtonEncoderState | |
CUnknownDescribedTypeEncoder | |
CDecodeEOFException | Decode exception thrown when a decode operation fails because it reached the end of available input before fully decoding the value it is currently working with |
CDecodeException | |
CEncodeException | |
CIDecoder | Defines a Decoder that handles translating the encoded AMQP performative bytes into the appropriate Proton AMQP types |
CIDecoderState | Defines a state object that is used with the AMQP Decoder type to hold intermediate state and provide additional functionality that can be used during the decode process |
CIDescribedTypeDecoder | |
CIDescribedTypeEncoder | |
CIEncoder | Defines an Encoder type that translates AMQP performatives into their encoded byte representations |
CIEncoderState | Defines a state object that is used with the AMQP Encoder type to hold intermediate state and provide additional functionality that can be used during the encode process |
CIPrimitiveArrayTypeDecoder | Defines an interface for an decoder of a primitive array types |
CIPrimitiveTypeDecoder | Defines an interface for an decoder of a primitive types |
CIStreamDecoder | Defines a Decoder that handles translating the encoded AMQP performative bytes into the appropriate Proton AMQP types |
CIStreamDecoderState | Defines a state object that is used with the AMQP Decoder type to hold intermediate state and provide additional functionality that can be used during the decode process |
CIStreamDescribedTypeDecoder | |
CIStreamTypeDecoder | Defines an interface for an decoder of a specific type |
CITypeDecoder | Defines an interface for an decoder of a specific type |
CITypeEncoder | Defines an interface for an encoder of a specific type |
CIUtf8Decoder | Interface for an external UTF8 Decoder that can be supplied by a client which implements custom decoding logic optimized for the application using the Codec |
CIUtf8StreamDecoder | Interface for an external UTF8 Decoder that can be supplied by a client which implements custom decoding logic optimized for the application using the Codec |
►NEngine | |
►NExceptions | |
CEngineFailedException | Engine state exception thrown when an operation cannot be performed on an already failed engine instance |
CEngineNotStartedException | Engine state exception thrown when an operation cannot be performed on an not yet started engine instance |
CEngineNotWritableException | Engine state exception thrown when an data ingest operation cannot be performed on an engine that is not currently accepting input |
CEngineShutdownException | Engine state exception thrown when an operation cannot be performed on an already shutdown engine instance |
CEngineStartedException | Engine state exception thrown when an operation cannot be performed on an already started engine instance |
CEngineStateException | Root type for exceptions thrown from the engine due to state violations |
CFrameDecodingException | |
CFrameEncodingException | |
CIdleTimeoutException | Error thrown when the Engine idle checking detects a timeout condition and shuts down the engine and places it in an error state |
CMalformedAMQPHeaderException | |
CProtocolViolationException | Exception type that indicates an IO error has occurred that is likely unrecoverable |
CProtonException | Base exception types that backs most exceptions that are generated from the Proton engine during it's operation |
CProtonIOException | Exception type that indicates an IO error has occured that is likely unrecoverable |
►NImplementation | |
►NSasl | |
CProtonDefaultSaslClientAuthenticator | A Proton default SASL client authenticator which only supports remote SASL exchanges where the ANONYMOUS mechanism is an published option |
CProtonDefaultSaslServerAuthenticator | Proton default SASL server authenticator which fails any incoming authentication requests. A misconfigured engine will not inadvertently allow for SASL authentication to occur but instead reject all attempts with a SASL auth failure |
CProtonEngineSaslDriver | Engine SASL Driver implementation which handles the configuration and initial engine setup which provides the handling of SASL exchanges between clients and server |
CProtonSaslClientContext | SASL Context for SASL client instances which handles the client side management of the SASL exchange |
CProtonSaslContext | Engine handler that manages the SASL authentication process that occurs either on the client or server end of the SASL exchange |
CProtonSaslHandler | Engine handler that manages the SASL authentication process that occurs either on the client or server end of the SASL exchange |
CProtonSaslServerContext | SASL Context for SASL client instances which handles the client side management of the SASL exchange |
CProtonAttachments | |
CProtonConnection | Implements the mechanics of managing a single AMQP connection associated with the provided engine instance |
CProtonEmptyTagGenerator | Creates instance of delivery tags that have an empty byte buffer body |
CProtonEndpoint | Base endpoint class that provides some of the most common endpoint implementations and some API for internal use when dealing with events |
CProtonEngine | Creates instance of delivery tags that have an empty byte buffer body |
CProtonEngineConfiguration | Implementation of engine configuration options along with Proton specific internal configuration and state update handling based on the current configuration and remote interactions |
CProtonEngineFactory | |
CProtonEngineHandlerContext | A context object that is assigned to each new engine handler that is inserted into an engine handler pipeline |
CProtonEngineNoOpSaslDriver | A Default No-Op SASL context that is used to provide the engine with a stub when no SASL is configured for the operating engine |
CProtonEnginePipeline | Implements the pipeline of engine read and write handlers used by the proton engine to read and write AMQP performatives |
CProtonEnginePipelineProxy | Wrapper around the internal ProtonEnginePipeline used to present a guarded pipeline to the outside world when the Engine::pipeline method is used to gain access to the pipeline. The proxy will ensure that any read or write calls enforce Engine state such as not started and shutdown |
CProtonFrameDecodingHandler | Frame encoder for outgoing AMQP and SASL performatives and Headers |
CProtonFrameEncodingHandler | Frame encoder for outgoing AMQP and SASL performatives and Headers |
CProtonFrameLoggingHandler | Frame logger for outgoing AMQP and SASL performatives and Headers |
CProtonIncomingDelivery | Proton Incoming Delivery implementation that wraps all the details of managing the read of delivery payload and management of delivery state |
CProtonLink | Common base for Sender and Receiver links which provides services that both endpoints require that are the same between them |
CProtonLinkCreditState | |
CProtonOutgoingDelivery | Outgoing delivery implementation that manges the state and payload writes for this delivery |
CProtonPerformativeHandler | Proton Engine handler that routes incoming and outgoing performatives |
CProtonPooledTagGenerator | A builtin proton delivery tag generator that creates tag values from an ever increasing sequence id value |
CProtonReceiver | Proton Receiver link implementation which manages the receipt of new deliveries and credit associated with the link. Delivery outcomes and settlement states can also be managed from the receiver link |
CProtonSender | Proton Sender link implementation which manages the state of the Sender end of an attached link and provides resources for sending deliveries and managing the state of sent deliveries |
CProtonSequentialTagGenerator | A builtin proton delivery tag generator that creates tag values from an ever increasing sequence id value |
CProtonSession | Implements the mechanics of managing a single AMQP session associated with the provided connection instance |
CProtonSessionIncomingWindow | Tracks the incoming window and provides management of that window in relation to receiver links |
CProtonSessionOutgoingWindow | Holds Session level credit window information for outgoing transfers from a Session. The window is constrained by the remote incoming capacity restrictions or if present outgoing restrictions on pending transfers |
CProtonTransaction | Base class for ITransaction types in the Proton engine which provides the basic API implementation that all transactions will expose |
CProtonTransactionController | Proton transaction controller abstraction that provides the transaction services for a Sender link that transmits the transaction Declare and Discharge commands which control the lifetime and outcome of a running transaction |
CProtonTransactionManager | Proton transaction manager abstraction that provides the transaction services for a Receiver link that handles the transaction Declare and Discharge commands which control the lifetime and outcome of a running transaction |
CProtonUuidTagGenerator | A builtin proton delivery tag generator that creates tag value backed by a generated Uuid (Guid) instance |
CUnmodifiableLinkCreditState | An unmodifiable snapshot view of link credit state |
►NSasl | |
►NClient | |
CAbstractMechanism | Common base for SASL mechanism types that provides basic service to ease the creation of SASL mechanisms |
CAbstractScramSHAMechanism | Common base for SASL mechanism types that provides basic service to ease the creation of SASL mechanisms |
CAnonymousMechanism | Implementation of the SASL Anonymous mechanism |
CCramMD5Mechanism | Implementation of the SASL CRAM-MD5 mechanism |
CDelegatedSaslCredentialsProvider | SASL Credentials Provider instance that accepts delegate methods which can provide the credentials upon request |
CExternalMechanism | Implementation of the SASL External mechanism |
CIMechanism | Interface that is implemented by all SASL mechanisms provided in this package |
CISaslCredentialsProvider | Interface for a supplier of login credentials used by the SASL Authenticator to select and configure the client SASL mechanism |
CPlainMechanism | Implementation of the SASL Plain mechanism |
CSaslAuthenticator | Handles SASL traffic from the proton engine and drives the authentication process for a client connection |
CSaslMechanismSelector | Client side mechanism used to select a matching mechanism from the server offered list of mechanisms. The client configures the list of allowed Mechanism names and when the server mechanisms are offered mechanism is chosen from the allowed set. If the client does not configure any mechanisms then the selector chooses from all supported SASL Mechanism types implemented in the Proton library |
CScramSHA1Mechanism | Implements the SASL Scram SHA1 authentication Mechanism |
CScramSHA256Mechanism | Implements the SASL Scram SHA256 authentication Mechanism |
CScramSHA512Mechanism | Implements the SASL Scram SHA512 authentication Mechanism |
CXOauth2Mechanism | Implementation of the SASL XOAUTH2 mechanism |
CAuthenticationException | Indicates the remote failed the Authentication of the client |
CISaslClientAuthenticator | Listener for SASL frame arrival to facilitate relevant handling for the SASL authentication of the client side of the SASL exchange. See the AMQP specification SASL negotiation process overview for related detail |
CISaslClientContext | Root context of a SASL authentication API which provides common elements used in both clients and servers |
CISaslContext | Root context of a SASL authentication API which provides common elements used in both clients and servers |
CISaslServerAuthenticator | Listener for SASL frame arrival to facilitate relevant handling for the SASL authentication of the server side of the SASL exchange. See the AMQP specification SASL negotiation process overview for related detail |
CISaslServerContext | SASL Server operating context used by an Engine that has been configured as a SASL server or that has receiver an AMQP header thereby forcing it into becoming the server side of the SASL exchange |
CMechanismMismatchException | Base exception type for exceptions encountered during SASL authentication |
CSaslException | Base exception type for exceptions encountered during SASL authentication |
CSaslSystemException | Indicates that a SASL handshake has failed with a 'sys", 'sys-perm', or 'sys-temp' outcome code as defined by: |
CAmqpPerformativeEnvelopePool | |
CEmptyEnvelope | An empty incoming AMQP envelope that is used for signalling that an empty AMQP frame was read |
CHeaderEnvelope | Frame object that carries an AMQP Performative |
CIAttachments | Attachments API used to provide additional state data to live alongside specific Proton AMQP resources |
CIConnection | Represents an AMQP Connection which is owned by a single engine instance |
CIDeliveryTagGenerator | Delivery tag generators can be assigned to sender links in order to allow the link to automatically assign a transfer tag to each outbound delivery. Depending on the Sender different tag generators can operate in a fashion that is most efficient for that link such as caching tags for links that will produce a large number of messages to avoid GC overhead, while for other links simpler generator types could be used |
CIEndpoint | Represents an AMQP Connection which is owned by a single engine instance |
CIEngine | Defines an AMQP Protocol Engine interface that should be used to implement an AMQP Engine |
CIEngineConfiguration | Configuration options for the Engine |
CIEngineFactory | Interface used to define the basic mechanisms for creating Engine instances |
CIEngineHandler | Handler of engine events that is queued into the events pipeline |
CIEngineHandlerContext | Context object that is provided to the engine handler APIs to allow for forwarding of events to the next handler or other updates |
CIEnginePipeline | The engine pipeline contains a list of handlers that deal with incoming and outgoing AMQP frames such as logging and encoders and decoders |
CIEngineSaslDriver | |
CIIncomingDelivery | Represents an incoming delivery that is received by a local receiver from a remote sender on an open link |
CILink | Base API for all AMQP Sender and Receiver links |
CILinkCreditState | Interface that defines an object that captures the current link credit state |
CIncomingAmqpEnvelope | Frame object that carries an AMQP Performative |
CIOutgoingDelivery | Represents an outgoing delivery that is sent from a local sender to a remote receiver on an open link |
CIReceiver | AMQP Receiver link resource |
CISender | AMQP Sender link resource |
CISession | The engine pipeline contains a list of handlers that deal with incoming and outgoing AMQP frames such as logging and encoders and decoders |
CITransaction | A Transaction object that hold information and context for a single Transaction |
CITransactionController | Transaction Controller link that implements the mechanics of declaring and discharging AMQP transactions. A transaction controller is typically used at the client side of an AMQP link to create transaction instances which the client application will enlist its incoming and outgoing deliveries into |
CITransactionManager | Transaction Manager endpoint that implements the mechanics of handling the declaration of and the requested discharge of AMQP transactions. Typically an AMQP server instance will host the transaction management services that are used by client resources to declare and discharge transaction and handle the associated of deliveries that are enlisted in active transactions |
COutgoingAmqpEnvelope | Frame object that carries an AMQP Performative |
CPerformativeEnvelope | Base class for envelope types that travel through the engine |
CSaslEnvelope | Frame object that carries an AMQP Performative |
►NLogging | |
CIProtonLogger | Proton defined logging API used to abstract the ultimate source of the logging service and provide consistent API mechanics to the proton code |
CProtonDefaultLoggerProvider | The Proton default logger provider implementation |
►NTypes | |
►NMessaging | |
CAccepted | |
CAmqpSequence | |
CAmqpValue | |
CApplicationProperties | |
CData | |
CDeleteOnClose | |
CDeleteOnNoLinks | |
CDeleteOnNoLinksOrMessages | |
CDeleteOnNoMessages | |
CDeliveryAnnotations | |
CFooter | |
CHeader | |
CIBodySection | |
CILifetimePolicy | |
CIOutcome | Serves as a marker interface for the AMQP Outcome types |
CISection | |
CITerminus | |
CMessageAnnotations | |
CModified | |
CProperties | |
CReceived | |
CRejected | |
CReleased | |
CSource | |
CTarget | |
►NSecurity | |
CISaslPerformative | |
CISaslPerformativeHandler | Handler Interface that can be used to implement a visitor pattern of processing the SASL exchange process |
CSaslChallenge | |
CSaslInit | |
CSaslMechanisms | |
CSaslOutcome | |
CSaslResponse | |
►NTransactions | |
CCoordinator | |
CDeclare | |
CDeclared | |
CDischarge | |
CIGlobalTxnId | |
CTransactionalState | |
►NTransport | |
CAmqpHeader | |
CAttach | |
CBegin | |
CClose | |
CDetach | |
CDisposition | |
CEnd | |
CErrorCondition | |
CFlow | |
CIDeliveryState | |
CIHeaderHandler | Interface that defines a visitor for AMQP Header instances which can be used to process incoming and outgoing AMQP headers or other related processing |
CIPerformative | |
CIPerformativeHandler | Handler Interface that can be used to implement a visitor pattern of processing the AMQP performative types as they are sent or received |
COpen | |
CTransfer | |
CDecimal128 | |
CDecimal32 | |
CDecimal64 | |
CDeliveryTag | A representation of the byte value that comprises the delivery tag that is assigned to the first transfer frame of each new delivery |
CIDeliveryTag | A representation of the byte value that comprises the delivery tag that is assigned to the first transfer frame of each new delivery |
CIDescribedType | |
CSymbol | |
CUnknownDescribedType | Defines an object that can carry an AMQP descriptor and some object which was decoded from the encoding of an AMQP described type not known to the codec in use when decoding it |
►NUtilities | |
CArrayDeque | A resizable-array implementation of the IDeque interface which has no capacity restrictions. The backing array will grow as necessary to support usage. This collection is not thread-safe. Null elements are prohibited in this collection |
CIDeque | A linear collection type that supports element insertion and removal at both ends. This double ended queue type will most commonly be implemented with no underlying fixed capacity limit however the interface allows for restricted capacity versions to be implemented all the same |
CLinkedSplayedDictionary | A Linked node version of the Splayed Dictionary that provides consisted enumeration of dictionary entries based on insertion order over natural or comparer based enumeration from the default splayed dictionary implementation |
CRingQueue | Simple Ring Queue implementation that has an enforced max size value |
►CSplayedDictionary | A splay tree based dictionary implementation that provides fast access to recently visited entries and offered enumeration based on the natural ordering or comparer defined ordering of dictionary entries |
CSplayedEntry | |