Uses of Class
com.microsoft.azure.eventhubs.EventHubException
-
Packages that use EventHubException Package Description com.microsoft.azure.eventhubs com.microsoft.azure.eventhubs.impl -
-
Uses of EventHubException in com.microsoft.azure.eventhubs
Subclasses of EventHubException in com.microsoft.azure.eventhubs Modifier and Type Class Description classAuthorizationFailedExceptionAuthorization failed exception is thrown when error is encountered during authorizing user's permission to run the intended operations.classCommunicationExceptionThis exception is thrown when there is a client side connectivity issue.classIllegalEntityExceptionThis exception is thrown for the following reasons: When the entity user attempted to connect does not exist The entity user wants to connect is disabledclassOperationCancelledExceptionThis exception is thrown when the underlying AMQP layer encounter an abnormal link abort or disconnect of connection in an unexpected fashion.classPayloadSizeExceededExceptionthis 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.classQuotaExceededExceptionclassReceiverDisconnectedExceptionThis 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.classServerBusyExceptionServer busy exception is thrown when the current entity's activity has put excessive load onto the service.classTimeoutExceptionThis exception is thrown when the operation has exceeded the predetermined time limit.Methods in com.microsoft.azure.eventhubs that throw EventHubException Modifier and Type Method Description voidEventHubClient. closeSync()voidPartitionReceiver. closeSync()voidPartitionSender. closeSync()default EventDataBatchEventHubClient. createBatch()Creates an Empty Collection ofEventData.EventDataBatchEventHubClient. createBatch(BatchOptions options)Creates an Empty Collection ofEventData.CompletableFuture<PartitionReceiver>EventHubClient. createEpochReceiver(String consumerGroupName, String partitionId, EventPosition eventPosition, long epoch)Create a Epoch based EventHub receiver with given partition id and start receiving from the beginning of the partition stream.CompletableFuture<PartitionReceiver>EventHubClient. createEpochReceiver(String consumerGroupName, String partitionId, EventPosition eventPosition, long epoch, ReceiverOptions receiverOptions)Create a Epoch based EventHub receiver with given partition id and start receiving from the beginning of the partition stream.default PartitionReceiverEventHubClient. createEpochReceiverSync(String consumerGroupName, String partitionId, EventPosition eventPosition, long epoch)Synchronous version ofEventHubClient.createEpochReceiver(String, String, EventPosition, long).default PartitionReceiverEventHubClient. createEpochReceiverSync(String consumerGroupName, String partitionId, EventPosition eventPosition, long epoch, ReceiverOptions receiverOptions)Synchronous version ofEventHubClient.createEpochReceiver(String, String, EventPosition, long).static EventHubClientEventHubClient. createFromConnectionStringSync(String connectionString, RetryPolicy retryPolicy, ScheduledExecutorService executor)Synchronous version ofEventHubClient.createFromConnectionString(String, ScheduledExecutorService).static EventHubClientEventHubClient. createFromConnectionStringSync(String connectionString, RetryPolicy retryPolicy, ScheduledExecutorService executor, ProxyConfiguration configuration)static EventHubClientEventHubClient. createFromConnectionStringSync(String connectionString, RetryPolicy retryPolicy, ScheduledExecutorService executor, ProxyConfiguration configuration, Duration maximumSilentTime)static EventHubClientEventHubClient. createFromConnectionStringSync(String connectionString, ScheduledExecutorService executor)Synchronous version ofEventHubClient.createFromConnectionString(String, ScheduledExecutorService).CompletableFuture<PartitionSender>EventHubClient. createPartitionSender(String partitionId)Create aPartitionSenderwhich can publishEventData's directly to a specific EventHub partition (sender type iii.default PartitionSenderEventHubClient. createPartitionSenderSync(String partitionId)Synchronous version ofEventHubClient.createPartitionSender(String).CompletableFuture<PartitionReceiver>EventHubClient. createReceiver(String consumerGroupName, String partitionId, EventPosition eventPosition)Create the EventHub receiver with given partition id and start receiving from the specified starting offset.CompletableFuture<PartitionReceiver>EventHubClient. createReceiver(String consumerGroupName, String partitionId, EventPosition eventPosition, ReceiverOptions receiverOptions)Create the EventHub receiver with given partition id and start receiving from the specified starting offset.default PartitionReceiverEventHubClient. createReceiverSync(String consumerGroupName, String partitionId, EventPosition eventPosition)Synchronous version ofEventHubClient.createReceiver(String, String, EventPosition).default PartitionReceiverEventHubClient. createReceiverSync(String consumerGroupName, String partitionId, EventPosition eventPosition, ReceiverOptions receiverOptions)Synchronous version ofEventHubClient.createReceiver(String, String, EventPosition).default Iterable<EventData>PartitionReceiver. receiveSync(int maxEventCount)Synchronous version ofPartitionReceiver.receive(int).default voidEventHubClient. sendSync(EventData data)Synchronous version ofEventHubClient.send(EventData).default voidEventHubClient. sendSync(EventDataBatch eventDatas)Synchronous version ofEventHubClient.send(EventDataBatch).default voidEventHubClient. sendSync(EventData eventData, String partitionKey)Synchronous version ofEventHubClient.send(EventData, String).default voidEventHubClient. sendSync(Iterable<EventData> eventDatas)Synchronous version ofEventHubClient.send(Iterable).default voidEventHubClient. sendSync(Iterable<EventData> eventDatas, String partitionKey)Synchronous version ofEventHubClient.send(Iterable, String).default voidPartitionSender. sendSync(EventData data)Synchronous version ofPartitionSender.send(EventData)Api.default voidPartitionSender. sendSync(EventDataBatch eventDatas)Synchronous version ofPartitionSender.send(EventDataBatch)default voidPartitionSender. sendSync(Iterable<EventData> eventDatas)Synchronous version ofPartitionSender.send(Iterable).voidReceiverOptions. setPrefetchCount(int prefetchCount)Set the number of events that can be pre-fetched and cached at thePartitionReceiver. -
Uses of EventHubException in com.microsoft.azure.eventhubs.impl
Methods in com.microsoft.azure.eventhubs.impl that throw EventHubException Modifier and Type Method Description EventDataBatchEventHubClientImpl. createBatch(BatchOptions options)CompletableFuture<PartitionReceiver>EventHubClientImpl. createEpochReceiver(String consumerGroupName, String partitionId, EventPosition eventPosition, long epoch)CompletableFuture<PartitionReceiver>EventHubClientImpl. createEpochReceiver(String consumerGroupName, String partitionId, EventPosition eventPosition, long epoch, ReceiverOptions receiverOptions)CompletableFuture<PartitionSender>EventHubClientImpl. createPartitionSender(String partitionId)CompletableFuture<PartitionReceiver>EventHubClientImpl. createReceiver(String consumerGroupName, String partitionId, EventPosition eventPosition)CompletableFuture<PartitionReceiver>EventHubClientImpl. createReceiver(String consumerGroupName, String partitionId, EventPosition eventPosition, ReceiverOptions receiverOptions)TExceptionUtil.SyncFactory. execute()voidExceptionUtil.SyncFactoryVoid. execute()TExceptionUtil.SyncFactoryWithIllegalArgException. execute()TExceptionUtil.SyncFactoryWithIOException. execute()static intAmqpUtil. getDataSerializedSize(org.apache.qpid.proton.message.Message amqpMessage)static <T> TExceptionUtil. sync(ExceptionUtil.SyncFactory<T> factory)static voidExceptionUtil. syncVoid(ExceptionUtil.SyncFactoryVoid factory)static <T> TExceptionUtil. syncWithIllegalArgException(ExceptionUtil.SyncFactoryWithIllegalArgException<T> factory)static <T> TExceptionUtil. syncWithIOException(ExceptionUtil.SyncFactoryWithIOException<T> factory)
-