Skip navigation links
A B C D E F G H I L M P R S T U V 

A

addContext(String, Object) - Method in class com.azure.messaging.eventhubs.EventData
Adds a new key value pair to the existing context on Event Data.

B

buildAsyncConsumerClient() - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Creates a new EventHubConsumerAsyncClient based on the options set on this builder.
buildAsyncProducerClient() - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Creates a new EventHubProducerAsyncClient based on options set on this builder.
buildConsumerClient() - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Creates a new EventHubConsumerClient based on the options set on this builder.
buildEventProcessorClient() - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
This will create a new EventProcessorClient configured with the options set in this builder.
buildProducerClient() - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Creates a new EventHubProducerClient based on options set on this builder.

C

CANNOT_SEND_EVENT_BATCH_EMPTY - Static variable in enum com.azure.messaging.eventhubs.Messages
 
Checkpoint - Class in com.azure.messaging.eventhubs.models
A model class to hold checkpoint data.
Checkpoint() - Constructor for class com.azure.messaging.eventhubs.models.Checkpoint
 
CheckpointStore - Interface in com.azure.messaging.eventhubs
An interface that defines the operations for storing and retrieving partition ownership information and checkpoint details for each partition.
checkpointStore(CheckpointStore) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Sets the CheckpointStore the EventProcessorClient will use for storing partition ownership and checkpoint information.
claimOwnership(List<PartitionOwnership>) - Method in interface com.azure.messaging.eventhubs.CheckpointStore
Called to claim ownership of a list of partitions.
CLASS_NOT_A_SUPPORTED_TYPE - Static variable in enum com.azure.messaging.eventhubs.Messages
 
close() - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Disposes of the consumer by closing the underlying connection to the service.
close() - Method in class com.azure.messaging.eventhubs.EventHubConsumerClient
close() - Method in class com.azure.messaging.eventhubs.EventHubProducerAsyncClient
close() - Method in class com.azure.messaging.eventhubs.EventHubProducerClient
CloseContext - Class in com.azure.messaging.eventhubs.models
This class contains information about a partition for which this EventProcessorClient stopped processing.
CloseContext(PartitionContext, CloseReason) - Constructor for class com.azure.messaging.eventhubs.models.CloseContext
Creates a new instance of CloseContext.
CloseReason - Enum in com.azure.messaging.eventhubs.models
Enumeration of all possible reasons a PartitionProcessor may be closed.
com.azure.messaging.eventhubs - package com.azure.messaging.eventhubs
Package containing classes for creating EventHubProducerAsyncClient, EventHubProducerClient, EventHubConsumerAsyncClient, EventHubConsumerClient, or EventProcessorClient to perform operations on Azure Event Hubs.
com.azure.messaging.eventhubs.models - package com.azure.messaging.eventhubs.models
Package containing classes used for creating and configuring events that are being sent-to and received-from Azure Event Hubs service.
configuration(Configuration) - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Sets the configuration store that is used during construction of the service client.
configuration(Configuration) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Sets the configuration store that is used during construction of the service client.
connectionString(String) - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Sets the credential information given a connection string to the Event Hub instance.
connectionString(String, String) - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Sets the credential information given a connection string to the Event Hubs namespace and name to a specific Event Hub instance.
connectionString(String) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Sets the credential information given a connection string to the Event Hub instance.
connectionString(String, String) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Sets the credential information given a connection string to the Event Hubs namespace and name to a specific Event Hub instance.
consumerGroup(String) - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Sets the name of the consumer group this consumer is associated with.
consumerGroup(String) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Sets the consumer group name from which the EventProcessorClient should consume events.
createBatch() - Method in class com.azure.messaging.eventhubs.EventHubProducerAsyncClient
Creates an EventDataBatch that can fit as many events as the transport allows.
createBatch(CreateBatchOptions) - Method in class com.azure.messaging.eventhubs.EventHubProducerAsyncClient
Creates an EventDataBatch configured with the options specified.
createBatch() - Method in class com.azure.messaging.eventhubs.EventHubProducerClient
Creates an EventDataBatch that can fit as many events as the transport allows.
createBatch(CreateBatchOptions) - Method in class com.azure.messaging.eventhubs.EventHubProducerClient
Creates an EventDataBatch configured with the options specified.
CreateBatchOptions - Class in com.azure.messaging.eventhubs.models
The set of options that can be specified when creating an EventDataBatch.
CreateBatchOptions() - Constructor for class com.azure.messaging.eventhubs.models.CreateBatchOptions
 
credential(String, String, TokenCredential) - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Sets the credential information for which Event Hub instance to connect to, and how to authorize against it.
credential(String, String, TokenCredential) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Sets the credential information for which Event Hub instance to connect to, and how to authorize against it.

D

DEFAULT_CONSUMER_GROUP_NAME - Static variable in class com.azure.messaging.eventhubs.EventHubClientBuilder
The name of the default consumer group in the Event Hubs service.

E

earliest() - Static method in class com.azure.messaging.eventhubs.models.EventPosition
Corresponds to the location of the first event present in the partition.
ENCODING_TYPE_NOT_SUPPORTED - Static variable in enum com.azure.messaging.eventhubs.Messages
 
equals(Object) - Method in class com.azure.messaging.eventhubs.EventData
equals(Object) - Method in class com.azure.messaging.eventhubs.models.EventPosition
 
ERROR_OCCURRED_IN_SUBSCRIBER_ERROR - Static variable in enum com.azure.messaging.eventhubs.Messages
 
ERROR_SENDING_BATCH - Static variable in enum com.azure.messaging.eventhubs.Messages
 
ErrorContext - Class in com.azure.messaging.eventhubs.models
This class contains information about an error that occurred while processing events.
ErrorContext(PartitionContext, Throwable) - Constructor for class com.azure.messaging.eventhubs.models.ErrorContext
Creates a new instance of ErrorContext.
EVENT_DATA_DOES_NOT_FIT - Static variable in enum com.azure.messaging.eventhubs.Messages
 
EVENT_PROCESSOR_RUN_END - Static variable in enum com.azure.messaging.eventhubs.Messages
 
EventContext - Class in com.azure.messaging.eventhubs.models
A class that contains EventData and the partition information the event belongs to.
EventContext(PartitionContext, EventData, CheckpointStore, LastEnqueuedEventProperties) - Constructor for class com.azure.messaging.eventhubs.models.EventContext
Creates an instance of EventContext.
EventData - Class in com.azure.messaging.eventhubs
The data structure encapsulating the event being sent-to and received-from Event Hubs.
EventData(byte[]) - Constructor for class com.azure.messaging.eventhubs.EventData
Creates an event containing the body.
EventData(ByteBuffer) - Constructor for class com.azure.messaging.eventhubs.EventData
Creates an event containing the body.
EventData(String) - Constructor for class com.azure.messaging.eventhubs.EventData
Creates an event by encoding the body using UTF-8 charset.
EventDataBatch - Class in com.azure.messaging.eventhubs
A class for aggregating EventData into a single, size-limited, batch.
EventHubClientBuilder - Class in com.azure.messaging.eventhubs
This class provides a fluent builder API to aid the instantiation of EventHubProducerAsyncClient, EventHubProducerClient, EventHubConsumerAsyncClient, and EventHubConsumerClient.
EventHubClientBuilder() - Constructor for class com.azure.messaging.eventhubs.EventHubClientBuilder
Creates a new instance with the default transport AmqpTransportType.AMQP and a non-shared connection.
EventHubConsumerAsyncClient - Class in com.azure.messaging.eventhubs
An asynchronous consumer responsible for reading EventData from either a specific Event Hub partition or all partitions in the context of a specific consumer group.
EventHubConsumerClient - Class in com.azure.messaging.eventhubs
A synchronous consumer responsible for reading EventData from an Event Hub partition in the context of a specific consumer group.
EventHubProducerAsyncClient - Class in com.azure.messaging.eventhubs
An asynchronous producer responsible for transmitting EventData to a specific Event Hub, grouped together in batches.
EventHubProducerClient - Class in com.azure.messaging.eventhubs
A synchronous producer responsible for transmitting EventData to a specific Event Hub, grouped together in batches.
EventHubProperties - Class in com.azure.messaging.eventhubs
Holds information about an Event Hub which can come handy while performing operations like receiving events from a specific partition.
EventPosition - Class in com.azure.messaging.eventhubs.models
Defines a position of an EventData in the Event Hub partition.
EventProcessorClient - Class in com.azure.messaging.eventhubs
EventProcessorClient provides a convenient mechanism to consume events from all partitions of an Event Hub in the context of a consumer group.
EventProcessorClientBuilder - Class in com.azure.messaging.eventhubs
This class provides a fluent builder API to help aid the configuration and instantiation of the EventProcessorClient.
EventProcessorClientBuilder() - Constructor for class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Creates a new instance of EventProcessorClientBuilder.
EXCEPTION_OCCURRED_WHILE_EMITTING - Static variable in enum com.azure.messaging.eventhubs.Messages
 

F

FAILED_CLOSE_CONSUMER_PARTITION - Static variable in enum com.azure.messaging.eventhubs.Messages
 
FAILED_TO_CLAIM_OWNERSHIP - Static variable in enum com.azure.messaging.eventhubs.Messages
 
fromEnqueuedTime(Instant) - Static method in class com.azure.messaging.eventhubs.models.EventPosition
Creates a position at the given Instant.
fromOffset(long) - Static method in class com.azure.messaging.eventhubs.models.EventPosition
Creates a position to an event in the partition at the provided offset.
fromSequenceNumber(long) - Static method in class com.azure.messaging.eventhubs.models.EventPosition
Creates a position to an event in the partition at the provided sequence number.
fromSequenceNumber(long, boolean) - Static method in class com.azure.messaging.eventhubs.models.EventPosition
Creates a position at the given sequence number.

G

getBeginningSequenceNumber() - Method in class com.azure.messaging.eventhubs.PartitionProperties
Gets the starting sequence number of the partition's message stream.
getBody() - Method in class com.azure.messaging.eventhubs.EventData
Gets the actual payload/data wrapped by EventData.
getBodyAsString() - Method in class com.azure.messaging.eventhubs.EventData
Returns event data as UTF-8 decoded string.
getCloseReason() - Method in class com.azure.messaging.eventhubs.models.CloseContext
Returns the reason for stopping the event processing.
getConsumerGroup() - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Gets the consumer group this consumer is reading events as a part of.
getConsumerGroup() - Method in class com.azure.messaging.eventhubs.EventHubConsumerClient
Gets the consumer group this consumer is reading events as a part of.
getConsumerGroup() - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Gets the consumer group name associated with this checkpoint.
getConsumerGroup() - Method in class com.azure.messaging.eventhubs.models.PartitionContext
Gets the consumer group name associated with the consumer of an Event Hub.
getConsumerGroup() - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Gets the consumer group name associated with this ownership record.
getCount() - Method in class com.azure.messaging.eventhubs.EventDataBatch
Gets the number of events in the batch.
getCreatedAt() - Method in class com.azure.messaging.eventhubs.EventHubProperties
Gets the instant, in UTC, at which Event Hub was created.
getData() - Method in class com.azure.messaging.eventhubs.models.PartitionEvent
Gets the event received from the partition.
getEnqueuedDateTime() - Method in class com.azure.messaging.eventhubs.models.EventPosition
Gets the instant, in UTC, from which the next available event should be chosen.
getEnqueuedTime() - Method in class com.azure.messaging.eventhubs.EventData
Gets the instant, in UTC, of when the event was enqueued in the Event Hub partition.
getEnqueuedTime() - Method in class com.azure.messaging.eventhubs.models.LastEnqueuedEventProperties
Gets the date and time, in UTC, that the last observed event was enqueued in the partition.
getETag() - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Gets the ETag that was generated by the last known successful update to the partition ownership record.
getEventData() - Method in class com.azure.messaging.eventhubs.models.EventContext
Returns the event data received from Event Hub.
getEventHubName() - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Gets the Event Hub name this client interacts with.
getEventHubName() - Method in class com.azure.messaging.eventhubs.EventHubConsumerClient
Gets the Event Hub name this client interacts with.
getEventHubName() - Method in class com.azure.messaging.eventhubs.EventHubProducerAsyncClient
Gets the Event Hub name this client interacts with.
getEventHubName() - Method in class com.azure.messaging.eventhubs.EventHubProducerClient
Gets the Event Hub name this client interacts with.
getEventHubName() - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Gets the Event Hub name associated with this checkpoint.
getEventHubName() - Method in class com.azure.messaging.eventhubs.models.PartitionContext
Gets the Event Hub name.
getEventHubName() - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Gets the Event Hub name associated with this ownership record.
getEventHubName() - Method in class com.azure.messaging.eventhubs.PartitionProperties
Gets the name of the Event Hub that contains the partition.
getEventHubProperties() - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Retrieves information about an Event Hub, including the number of partitions present and their identifiers.
getEventHubProperties() - Method in class com.azure.messaging.eventhubs.EventHubConsumerClient
Retrieves information about an Event Hub, including the number of partitions present and their identifiers.
getEventHubProperties() - Method in class com.azure.messaging.eventhubs.EventHubProducerAsyncClient
Retrieves information about an Event Hub, including the number of partitions present and their identifiers.
getEventHubProperties() - Method in class com.azure.messaging.eventhubs.EventHubProducerClient
Retrieves information about an Event Hub, including the number of partitions present and their identifiers.
getFullyQualifiedNamespace() - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Gets the fully qualified Event Hubs namespace that the connection is associated with.
getFullyQualifiedNamespace() - Method in class com.azure.messaging.eventhubs.EventHubConsumerClient
Gets the fully qualified Event Hubs namespace that the connection is associated with.
getFullyQualifiedNamespace() - Method in class com.azure.messaging.eventhubs.EventHubProducerAsyncClient
Gets the fully qualified Event Hubs namespace that the connection is associated with.
getFullyQualifiedNamespace() - Method in class com.azure.messaging.eventhubs.EventHubProducerClient
Gets the fully qualified Event Hubs namespace that the connection is associated with.
getFullyQualifiedNamespace() - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Returns the fully qualified namespace of the Event Hub.
getFullyQualifiedNamespace() - Method in class com.azure.messaging.eventhubs.models.PartitionContext
Returns the fully qualified namespace of the Event Hub.
getFullyQualifiedNamespace() - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Returns the fully qualified namespace of the Event Hub.
getId() - Method in class com.azure.messaging.eventhubs.PartitionProperties
Gets the identifier of the partition within the Event Hub.
getIdentifier() - Method in class com.azure.messaging.eventhubs.EventProcessorClient
The identifier is a unique name given to this event processor instance.
getLastEnqueuedEventProperties() - Method in class com.azure.messaging.eventhubs.models.EventContext
Returns the properties of the last enqueued event in this partition.
getLastEnqueuedEventProperties() - Method in class com.azure.messaging.eventhubs.models.PartitionEvent
Gets the properties of the last enqueued event in this partition.
getLastEnqueuedOffset() - Method in class com.azure.messaging.eventhubs.PartitionProperties
Gets the offset of the last enqueued message in the partition's stream.
getLastEnqueuedSequenceNumber() - Method in class com.azure.messaging.eventhubs.PartitionProperties
Gets the last sequence number of the partition's message stream.
getLastEnqueuedTime() - Method in class com.azure.messaging.eventhubs.PartitionProperties
Gets the instant, in UTC, of the last enqueued message in the partition's stream.
getLastModifiedTime() - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Gets the last modified time of this ownership record as epoch millis.
getMaximumSizeInBytes() - Method in class com.azure.messaging.eventhubs.models.CreateBatchOptions
Gets the maximum size to allow for the batch of events, in bytes.
getMaxSizeInBytes() - Method in class com.azure.messaging.eventhubs.EventDataBatch
Gets the maximum size, in bytes, of the EventDataBatch.
getMessage(String) - Static method in enum com.azure.messaging.eventhubs.Messages
 
getName() - Method in class com.azure.messaging.eventhubs.EventHubProperties
Gets the name of the Event Hub.
getOffset() - Method in class com.azure.messaging.eventhubs.EventData
Gets the offset of the event when it was received from the associated Event Hub partition.
getOffset() - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Gets the offset of the last successfully processed event to store as checkpoint.
getOffset() - Method in class com.azure.messaging.eventhubs.models.EventPosition
Gets the relative position for event in the context of the stream.
getOffset() - Method in class com.azure.messaging.eventhubs.models.LastEnqueuedEventProperties
Gets the offset of the last observed event enqueued in the partition.
getOwnerId() - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Sets the unique event processor identifier as the owner of the partition id in this ownership record.
getOwnerLevel() - Method in class com.azure.messaging.eventhubs.models.ReceiveOptions
Gets the owner level for this consumer.
getPartitionContext() - Method in class com.azure.messaging.eventhubs.models.CloseContext
Returns the partition information for which the processing stopped.
getPartitionContext() - Method in class com.azure.messaging.eventhubs.models.ErrorContext
Returns the partition information where the error occurred.
getPartitionContext() - Method in class com.azure.messaging.eventhubs.models.EventContext
Returns the partition information associated with the received event.
getPartitionContext() - Method in class com.azure.messaging.eventhubs.models.InitializationContext
Returns the partition information for which the event processing is going to start.
getPartitionContext() - Method in class com.azure.messaging.eventhubs.models.PartitionEvent
Returns the partition information associated with the event data.
getPartitionId() - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Gets the partition id associated with this checkpoint.
getPartitionId() - Method in class com.azure.messaging.eventhubs.models.CreateBatchOptions
Gets the identifier of the Event Hub partition that the events in the EventDataBatch will be sent to.
getPartitionId() - Method in class com.azure.messaging.eventhubs.models.PartitionContext
Gets the partition id of the Event Hub.
getPartitionId() - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Gets the partition id associated with this ownership record.
getPartitionId() - Method in class com.azure.messaging.eventhubs.models.SendOptions
Gets the identifier of the Event Hub partition that the events will be sent to.
getPartitionIds() - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Retrieves the identifiers for the partitions of an Event Hub.
getPartitionIds() - Method in class com.azure.messaging.eventhubs.EventHubConsumerClient
Retrieves the identifiers for the partitions of an Event Hub.
getPartitionIds() - Method in class com.azure.messaging.eventhubs.EventHubProducerAsyncClient
Retrieves the identifiers for the partitions of an Event Hub.
getPartitionIds() - Method in class com.azure.messaging.eventhubs.EventHubProducerClient
Retrieves the identifiers for the partitions of an Event Hub.
getPartitionIds() - Method in class com.azure.messaging.eventhubs.EventHubProperties
Gets the list of partition identifiers of the Event Hub.
getPartitionKey() - Method in class com.azure.messaging.eventhubs.EventData
Gets the partition hashing key if it was set when originally publishing the event.
getPartitionKey() - Method in class com.azure.messaging.eventhubs.models.CreateBatchOptions
Gets the partition routing key on an event batch.
getPartitionKey() - Method in class com.azure.messaging.eventhubs.models.SendOptions
Gets the hashing key on an event batch.
getPartitionProperties(String) - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Retrieves information about a specific partition for an Event Hub, including elements that describe the available events in the partition event stream.
getPartitionProperties(String) - Method in class com.azure.messaging.eventhubs.EventHubConsumerClient
Retrieves information about a specific partition for an Event Hub, including elements that describe the available events in the partition event stream.
getPartitionProperties(String) - Method in class com.azure.messaging.eventhubs.EventHubProducerAsyncClient
Retrieves information about a specific partition for an Event Hub, including elements that describe the available events in the partition event stream.
getPartitionProperties(String) - Method in class com.azure.messaging.eventhubs.EventHubProducerClient
Retrieves information about a specific partition for an Event Hub, including elements that describe the available events in the partition event stream.
getProperties() - Method in class com.azure.messaging.eventhubs.EventData
Gets the set of free-form event properties which may be used for passing metadata associated with the event with the event body during Event Hubs operations.
getRetrievalTime() - Method in class com.azure.messaging.eventhubs.models.LastEnqueuedEventProperties
Gets the date and time, in UTC, that the information about the last enqueued event was retrieved.
getSequenceNumber() - Method in class com.azure.messaging.eventhubs.EventData
Gets the sequence number assigned to the event when it was enqueued in the associated Event Hub partition.
getSequenceNumber() - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Gets the sequence number of the last successfully processed event to store as checkpoint.
getSequenceNumber() - Method in class com.azure.messaging.eventhubs.models.EventPosition
Gets the sequence number of the event.
getSequenceNumber() - Method in class com.azure.messaging.eventhubs.models.LastEnqueuedEventProperties
Gets the sequence number of the last observed event to be enqueued in the partition.
getSizeInBytes() - Method in class com.azure.messaging.eventhubs.EventDataBatch
Gets the size of the EventDataBatch in bytes.
getSystemProperties() - Method in class com.azure.messaging.eventhubs.EventData
Properties that are populated by Event Hubs service.
getThrowable() - Method in class com.azure.messaging.eventhubs.models.ErrorContext
Returns the error that occurred during event processing.
getTrackLastEnqueuedEventProperties() - Method in class com.azure.messaging.eventhubs.models.ReceiveOptions
Gets whether or not the receive operation should request information on the last enqueued event on its associated partition, and track that information as events are received.

H

hashCode() - Method in class com.azure.messaging.eventhubs.EventData
hashCode() - Method in class com.azure.messaging.eventhubs.models.EventPosition
 

I

InitializationContext - Class in com.azure.messaging.eventhubs.models
The initialization context that is supplied to EventProcessorClientBuilder.processPartitionInitialization(Consumer) before the EventProcessorClient instance begins processing events from a partition.
InitializationContext(PartitionContext) - Constructor for class com.azure.messaging.eventhubs.models.InitializationContext
Creates an instance of InitializationContext for the partition provided in the PartitionContext.
initialPartitionEventPosition(Map<String, EventPosition>) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Sets the map containing the event position to use for each partition if a checkpoint for the partition does not exist in CheckpointStore.
isEmpty() - Method in class com.azure.messaging.eventhubs.PartitionProperties
Indicates whether or not the partition is currently empty.
isInclusive() - Method in class com.azure.messaging.eventhubs.models.EventPosition
Gets the boolean value of if the event is included.
isRunning() - Method in class com.azure.messaging.eventhubs.EventProcessorClient
Returns true if the event processor is running.

L

LastEnqueuedEventProperties - Class in com.azure.messaging.eventhubs.models
A set of information about the enqueued state of a partition, as observed by the consumer.
LastEnqueuedEventProperties(Long, Long, Instant, Instant) - Constructor for class com.azure.messaging.eventhubs.models.LastEnqueuedEventProperties
Creates an instance with the last enqueued event information set.
latest() - Static method in class com.azure.messaging.eventhubs.models.EventPosition
Corresponds to the end of the partition, where no more events are currently enqueued.
listCheckpoints(String, String, String) - Method in interface com.azure.messaging.eventhubs.CheckpointStore
Called to get the list of checkpoints from the underlying data store.
listOwnership(String, String, String) - Method in interface com.azure.messaging.eventhubs.CheckpointStore
Called to get the list of all existing partition ownership from the underlying data store.
LOAD_BALANCING_FAILED - Static variable in enum com.azure.messaging.eventhubs.Messages
 

M

MESSAGE_NOT_OF_TYPE - Static variable in enum com.azure.messaging.eventhubs.Messages
 
Messages - Enum in com.azure.messaging.eventhubs
I18n messages loaded from the messages.properties file located within the same package.

P

PartitionContext - Class in com.azure.messaging.eventhubs.models
A model class to contain partition information of an Event Hub.
PartitionContext(String, String, String, String) - Constructor for class com.azure.messaging.eventhubs.models.PartitionContext
Creates an instance of PartitionContext that contains partition information.
PartitionEvent - Class in com.azure.messaging.eventhubs.models
A container for EventData along with the partition information for this event data.
PartitionEvent(PartitionContext, EventData, LastEnqueuedEventProperties) - Constructor for class com.azure.messaging.eventhubs.models.PartitionEvent
Creates an instance of PartitionEvent.
PartitionOwnership - Class in com.azure.messaging.eventhubs.models
A model class to hold partition ownership information.
PartitionOwnership() - Constructor for class com.azure.messaging.eventhubs.models.PartitionOwnership
 
PartitionProperties - Class in com.azure.messaging.eventhubs
A set of information for a single partition of an Event Hub.
prefetchCount(int) - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Sets the count used by the receiver to control the number of events the Event Hub consumer will actively receive and queue locally without regard to whether a receive operation is currently active.
PROCESS_SPAN_SCOPE_TYPE_ERROR - Static variable in enum com.azure.messaging.eventhubs.Messages
 
processError(Consumer<ErrorContext>) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
The function that is called when an error occurs while processing events.
processEvent(Consumer<EventContext>) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
The function that is called for each event received by this EventProcessorClient.
processPartitionClose(Consumer<CloseContext>) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
The function that is called when a processing for a partition stops.
processPartitionInitialization(Consumer<InitializationContext>) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
The function that is called before processing starts for a partition.
proxyOptions(ProxyOptions) - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Sets the proxy configuration to use for EventHubAsyncClient.
proxyOptions(ProxyOptions) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Sets the proxy configuration to use for EventHubAsyncClient.

R

receive() - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Consumes events from all partitions starting from the beginning of each partition.
receive(boolean) - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Consumes events from all partitions.
receive(boolean, ReceiveOptions) - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Consumes events from all partitions configured with a set of receiveOptions.
receiveFromPartition(String, EventPosition) - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Consumes events from a single partition starting at startingPosition.
receiveFromPartition(String, EventPosition, ReceiveOptions) - Method in class com.azure.messaging.eventhubs.EventHubConsumerAsyncClient
Consumes events from a single partition starting at startingPosition with a set of receive options.
receiveFromPartition(String, int, EventPosition) - Method in class com.azure.messaging.eventhubs.EventHubConsumerClient
Receives a batch of events from the Event Hub partition.
receiveFromPartition(String, int, EventPosition, Duration) - Method in class com.azure.messaging.eventhubs.EventHubConsumerClient
Receives a batch of events from the Event Hub partition.
receiveFromPartition(String, int, EventPosition, Duration, ReceiveOptions) - Method in class com.azure.messaging.eventhubs.EventHubConsumerClient
Receives a batch of events from the Event Hub partition.
ReceiveOptions - Class in com.azure.messaging.eventhubs.models
Set of options that can be specified when receiving events from an EventHubConsumerAsyncClient or EventHubConsumerClient.
ReceiveOptions() - Constructor for class com.azure.messaging.eventhubs.models.ReceiveOptions
 
REQUEST_VALUE_NOT_VALID - Static variable in enum com.azure.messaging.eventhubs.Messages
 
retry(AmqpRetryOptions) - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Sets the retry policy for EventHubAsyncClient.
retry(AmqpRetryOptions) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Sets the retry policy for EventHubAsyncClient.

S

send(EventDataBatch) - Method in class com.azure.messaging.eventhubs.EventHubProducerAsyncClient
Sends the batch to the associated Event Hub.
send(EventDataBatch) - Method in class com.azure.messaging.eventhubs.EventHubProducerClient
Sends the batch to the associated Event Hub.
SendOptions - Class in com.azure.messaging.eventhubs.models
The set of options that can be specified when sending a set of events to influence the way in which events are sent to the Event Hubs service.
SendOptions() - Constructor for class com.azure.messaging.eventhubs.models.SendOptions
 
setConsumerGroup(String) - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Sets the consumer group name associated with this checkpoint.
setConsumerGroup(String) - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Sets the consumer group name associated with this ownership record.
setETag(String) - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Sets the ETag with the last known successful update to partition ownership record.
setEventHubName(String) - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Sets the Event Hub name associated with this checkpoint.
setEventHubName(String) - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Sets the Event Hub name associated with this ownership record.
setFullyQualifiedNamespace(String) - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Sets the fully qualified namespace of the Event Hub.
setFullyQualifiedNamespace(String) - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Sets the fully qualified namespace of the Event Hub.
setLastModifiedTime(Long) - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Sets the last modified time of this ownership record as epoch millis.
setMaximumSizeInBytes(int) - Method in class com.azure.messaging.eventhubs.models.CreateBatchOptions
Sets the maximum size for the batch of events, in bytes.
setOffset(Long) - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Sets the offset of the last successfully processed event to store as checkpoint.
setOwnerId(String) - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Returns the unique event processor identifier that owns the partition id in this ownership record.
setOwnerLevel(Long) - Method in class com.azure.messaging.eventhubs.models.ReceiveOptions
Sets the ownerLevel value on this receive operation.
setPartitionId(String) - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Sets the partition id associated with this checkpoint.
setPartitionId(String) - Method in class com.azure.messaging.eventhubs.models.CreateBatchOptions
Sets the identifier of the Event Hub partition that the events in the EventDataBatch will be sent to.
setPartitionId(String) - Method in class com.azure.messaging.eventhubs.models.PartitionOwnership
Sets the partition id associated with this ownership record.
setPartitionId(String) - Method in class com.azure.messaging.eventhubs.models.SendOptions
Sets the identifier of the Event Hub partition that the events will be sent to.
setPartitionKey(String) - Method in class com.azure.messaging.eventhubs.models.CreateBatchOptions
Sets a hashing key to be provided for the batch of events.
setPartitionKey(String) - Method in class com.azure.messaging.eventhubs.models.SendOptions
Sets a hashing key to be provided for the batch of events, which instructs the Event Hubs service to map this key to a specific partition.
setSequenceNumber(Long) - Method in class com.azure.messaging.eventhubs.models.Checkpoint
Sets the sequence number of the last successfully processed event to store as checkpoint.
setTrackLastEnqueuedEventProperties(boolean) - Method in class com.azure.messaging.eventhubs.models.ReceiveOptions
Sets whether or not the receive operation should request information on the last enqueued event on its associated partition, and track that information as events are received.
shareConnection() - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Toggles the builder to use the same connection for producers or consumers that are built from this instance.
start() - Method in class com.azure.messaging.eventhubs.EventProcessorClient
Starts processing of events for all partitions of the Event Hub that this event processor can own, assigning a dedicated PartitionProcessor to each partition.
stop() - Method in class com.azure.messaging.eventhubs.EventProcessorClient
Stops processing events for all partitions owned by this event processor.

T

toString() - Method in class com.azure.messaging.eventhubs.models.EventPosition
 
trackLastEnqueuedEventProperties(boolean) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Sets whether or not the event processor should request information on the last enqueued event on its associated partition, and track that information as events are received.
transportType(AmqpTransportType) - Method in class com.azure.messaging.eventhubs.EventHubClientBuilder
Sets the transport type by which all the communication with Azure Event Hubs occurs.
transportType(AmqpTransportType) - Method in class com.azure.messaging.eventhubs.EventProcessorClientBuilder
Sets the transport type by which all the communication with Azure Event Hubs occurs.
tryAdd(EventData) - Method in class com.azure.messaging.eventhubs.EventDataBatch
Tries to add an event to the batch.

U

updateCheckpoint(Checkpoint) - Method in interface com.azure.messaging.eventhubs.CheckpointStore
Updates the checkpoint in the data store for a partition.
updateCheckpoint() - Method in class com.azure.messaging.eventhubs.models.EventContext
Updates the checkpoint synchronously for this partition using the event data.
updateCheckpointAsync() - Method in class com.azure.messaging.eventhubs.models.EventContext
Updates the checkpoint asynchronously for this partition using the event data in this EventContext.

V

valueOf(String) - Static method in enum com.azure.messaging.eventhubs.Messages
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.azure.messaging.eventhubs.models.CloseReason
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.azure.messaging.eventhubs.Messages
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.azure.messaging.eventhubs.models.CloseReason
Returns an array containing the constants of this enum type, in the order they are declared.
A B C D E F G H I L M P R S T U V 
Skip navigation links
Visit the Azure for Java Developerssite for more Java documentation, including quick starts, tutorials, and code samples.

Copyright © 2020 Microsoft Corporation. All rights reserved.