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 class
AuthorizationFailedException
Authorization failed exception is thrown when error is encountered during authorizing user's permission to run the intended operations.class
CommunicationException
This exception is thrown when there is a client side connectivity issue.class
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 disabledclass
OperationCancelledException
This exception is thrown when the underlying AMQP layer encounter an abnormal link abort or disconnect of connection in an unexpected fashion.class
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.class
QuotaExceededException
class
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.class
ServerBusyException
Server busy exception is thrown when the current entity's activity has put excessive load onto the service.class
TimeoutException
This 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 void
EventHubClient. closeSync()
void
PartitionReceiver. closeSync()
void
PartitionSender. closeSync()
default EventDataBatch
EventHubClient. createBatch()
Creates an Empty Collection ofEventData
.EventDataBatch
EventHubClient. 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 PartitionReceiver
EventHubClient. createEpochReceiverSync(String consumerGroupName, String partitionId, EventPosition eventPosition, long epoch)
Synchronous version ofEventHubClient.createEpochReceiver(String, String, EventPosition, long)
.default PartitionReceiver
EventHubClient. createEpochReceiverSync(String consumerGroupName, String partitionId, EventPosition eventPosition, long epoch, ReceiverOptions receiverOptions)
Synchronous version ofEventHubClient.createEpochReceiver(String, String, EventPosition, long)
.static EventHubClient
EventHubClient. createFromConnectionStringSync(String connectionString, RetryPolicy retryPolicy, ScheduledExecutorService executor)
Synchronous version ofEventHubClient.createFromConnectionString(String, ScheduledExecutorService)
.static EventHubClient
EventHubClient. createFromConnectionStringSync(String connectionString, RetryPolicy retryPolicy, ScheduledExecutorService executor, ProxyConfiguration configuration)
static EventHubClient
EventHubClient. createFromConnectionStringSync(String connectionString, RetryPolicy retryPolicy, ScheduledExecutorService executor, ProxyConfiguration configuration, Duration maximumSilentTime)
static EventHubClient
EventHubClient. createFromConnectionStringSync(String connectionString, ScheduledExecutorService executor)
Synchronous version ofEventHubClient.createFromConnectionString(String, ScheduledExecutorService)
.CompletableFuture<PartitionSender>
EventHubClient. createPartitionSender(String partitionId)
Create aPartitionSender
which can publishEventData
's directly to a specific EventHub partition (sender type iii.default PartitionSender
EventHubClient. 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 PartitionReceiver
EventHubClient. createReceiverSync(String consumerGroupName, String partitionId, EventPosition eventPosition)
Synchronous version ofEventHubClient.createReceiver(String, String, EventPosition)
.default PartitionReceiver
EventHubClient. 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 void
EventHubClient. sendSync(EventData data)
Synchronous version ofEventHubClient.send(EventData)
.default void
EventHubClient. sendSync(EventDataBatch eventDatas)
Synchronous version ofEventHubClient.send(EventDataBatch)
.default void
EventHubClient. sendSync(EventData eventData, String partitionKey)
Synchronous version ofEventHubClient.send(EventData, String)
.default void
EventHubClient. sendSync(Iterable<EventData> eventDatas)
Synchronous version ofEventHubClient.send(Iterable)
.default void
EventHubClient. sendSync(Iterable<EventData> eventDatas, String partitionKey)
Synchronous version ofEventHubClient.send(Iterable, String)
.default void
PartitionSender. sendSync(EventData data)
Synchronous version ofPartitionSender.send(EventData)
Api.default void
PartitionSender. sendSync(EventDataBatch eventDatas)
Synchronous version ofPartitionSender.send(EventDataBatch)
default void
PartitionSender. sendSync(Iterable<EventData> eventDatas)
Synchronous version ofPartitionSender.send(Iterable)
.void
ReceiverOptions. 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 EventDataBatch
EventHubClientImpl. 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)
T
ExceptionUtil.SyncFactory. execute()
void
ExceptionUtil.SyncFactoryVoid. execute()
T
ExceptionUtil.SyncFactoryWithIllegalArgException. execute()
T
ExceptionUtil.SyncFactoryWithIOException. execute()
static int
AmqpUtil. getDataSerializedSize(org.apache.qpid.proton.message.Message amqpMessage)
static <T> T
ExceptionUtil. sync(ExceptionUtil.SyncFactory<T> factory)
static void
ExceptionUtil. syncVoid(ExceptionUtil.SyncFactoryVoid factory)
static <T> T
ExceptionUtil. syncWithIllegalArgException(ExceptionUtil.SyncFactoryWithIllegalArgException<T> factory)
static <T> T
ExceptionUtil. syncWithIOException(ExceptionUtil.SyncFactoryWithIOException<T> factory)
-