All Classes
-
All Classes Interface Summary Class Summary Enum Summary Exception Summary Class Description AmqpConnection AmqpConstants AmqpErrorCode AmqpException All AmqpExceptions - which EventHub client handles internally.AmqpLink AmqpReceiver AmqpResponseCode AmqpSender AmqpUtil AuthorizationFailedException Authorization failed exception is thrown when error is encountered during authorizing user's permission to run the intended operations.AzureActiveDirectoryTokenProvider AzureActiveDirectoryTokenProvider.AuthenticationCallback BaseLinkHandler BatchOptions BatchOptions is used to createEventDataBatch
es.ClientConstants CommunicationException This exception is thrown when there is a client side connectivity issue.ConnectionHandler ConnectionStringBuilder ConnectionStringBuilder
can be used to construct a connection string which can establish communication with Event Hub instances.CustomIOHandler DispatchHandler ErrorContext EventData The data structure encapsulating the Event being sent-to and received-from EventHubs.EventData.SystemProperties EventDataBatch Helper for creating a batch/collection of EventData objects to be used while Sending to EventHubsEventDataImpl EventHubClient Anchor class - all EventHub client operations STARTS here.EventHubClientImpl EventHubClientOptions Convenient container for options for creating anEventHubClient
All options default to not specified (null)EventHubException This is the base exception that service bus will produce for all error cases.EventHubRuntimeInformation Holds information about Event Hubs which can come handy while performing data-plane operations likeEventHubClient.createPartitionSender(String)
andEventHubClient.createReceiver(String, String, EventPosition)
EventPosition Defines a position of anEventData
in the event hub partition.EventPositionImpl ExceptionUtil ExceptionUtil.SyncFactory<T> ExceptionUtil.SyncFactoryVoid ExceptionUtil.SyncFactoryWithIllegalArgException<T> ExceptionUtil.SyncFactoryWithIOException<T> FaultTolerantObject<T extends IOObject> IllegalConnectionStringFormatException This exception is thrown when the connection string provided does not meet the requirement for connection.IllegalEntityException This exception is thrown for the following reasons: When the entity user attempted to connect does not exist The entity user wants to connect is disabledIOObject IOObject.IOObjectState IteratorUtil ITokenProvider JsonSecurityToken Extend SecurityToken with some specifics for a JSon Web TokenManagedIdentityTokenProvider MessageReceiver Common Receiver that abstracts all amqp related details translates event-driven reactor model into async receive ApiMessageSender Abstracts all amqp related details translates event-driven reactor model into async send ApiMessagingFactory Abstracts all amqp related details and exposes AmqpConnection object Manages connection life-cycleMessagingFactory.MessagingFactoryBuilder MessagingFactory.ReactorFactory Operation<T> OperationCancelledException This exception is thrown when the underlying AMQP layer encounter an abnormal link abort or disconnect of connection in an unexpected fashion.OperationResult<T,E extends Throwable> PartitionReceiveHandler The handler to invoke after receivingEventData
s from Microsoft Azure EventHubs.PartitionReceiver This is a logical representation of receiving from a EventHub partition.PartitionRuntimeInformation PartitionSender This sender class is a logical representation of sending events to a specific EventHub partition.PassByRef<T> PayloadSizeExceededException this exception is thrown when user attempts to send a event data or brokered message that has exceeded the allowed payload size as defined by the service.ProtonUtil ProxyConfiguration ProxyConfiguration.ProxyAuthenticationType Supported methods of proxy authentication.QuotaExceededException ReactorDispatcher Reactor
is not thread-safe - all calls toProton
API's should be - on the Reactor Thread.ReactorHandler ReceiveLinkHandler ReceivePump ReceivePump.IPartitionReceiver ReceiverContext ReceiverDisconnectedException This exception is thrown when a EventHubReceiver is being disconnected because of one of the following reason: user attempts to connect a non-epoch receiver to a event hub partition, when there is an epoch receiver connected to the partition.ReceiverOptions Represents various optional behaviors which can be turned on or off during the creation of aPartitionReceiver
.ReceiverRuntimeInformation Represents the temporal end of stream information of an EventHubs Partition.ReceiverSettingsProvider ReplayableWorkItem<T> RequestResponseChannel RequestResponseCloser RequestResponseOpener RetryExponential RetryPolicy implementation where the delay between retries will grow in an exponential manner.RetryPolicy SecurityToken A generic representation of a security token.SenderContext SendLinkHandler ServerBusyException Server busy exception is thrown when the current entity's activity has put excessive load onto the service.SessionHandler SessionProvider SharedAccessSignatureTokenProvider StringUtil TimeoutException This exception is thrown when the operation has exceeded the predetermined time limit.TimeoutTracker TrackingUtil TransportType All TransportType switches available for communicating to EventHubs service.WebSocketConnectionHandler WebSocketProxyConnectionHandler WorkItem<T>