- 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.
- getInitialPosition() - Method in class com.azure.messaging.eventhubs.models.InitializationContext
-
Returns the default initial event position from which the processing will start in the absence of a checkpoint in
CheckpointStore
.
- 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
-
- 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
-
- 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.
- 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.
- setInitialPosition(EventPosition) - Method in class com.azure.messaging.eventhubs.models.InitializationContext
-
If a different initial position is desirable for this partition, setting the initial position will start the
event processing from this position.
- 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
-
- 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.