Package | Description |
---|---|
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 containing classes used for creating and configuring events that are being sent-to and received-from Azure
Event Hubs service.
|
Modifier and Type | Method and Description |
---|---|
Flux<PartitionEvent> |
EventHubConsumerAsyncClient.receiveFromPartition(String partitionId,
EventPosition startingPosition)
Consumes events from a single partition starting at
startingPosition . |
Flux<PartitionEvent> |
EventHubConsumerAsyncClient.receiveFromPartition(String partitionId,
EventPosition startingPosition,
ReceiveOptions receiveOptions)
Consumes events from a single partition starting at
startingPosition with a set of receive options . |
IterableStream<PartitionEvent> |
EventHubConsumerClient.receiveFromPartition(String partitionId,
int maximumMessageCount,
EventPosition startingPosition)
Receives a batch of
events from the Event Hub partition. |
IterableStream<PartitionEvent> |
EventHubConsumerClient.receiveFromPartition(String partitionId,
int maximumMessageCount,
EventPosition startingPosition,
Duration maximumWaitTime)
Receives a batch of
events from the Event Hub partition. |
IterableStream<PartitionEvent> |
EventHubConsumerClient.receiveFromPartition(String partitionId,
int maximumMessageCount,
EventPosition startingPosition,
Duration maximumWaitTime,
ReceiveOptions receiveOptions)
Receives a batch of
events from the Event Hub partition. |
Modifier and Type | Method and Description |
---|---|
static EventPosition |
EventPosition.earliest()
Corresponds to the location of the first event present in the partition.
|
static EventPosition |
EventPosition.fromEnqueuedTime(Instant enqueuedDateTime)
Creates a position at the given
Instant . |
static EventPosition |
EventPosition.fromOffset(long offset)
Corresponds to the event in the partition at the provided offset, inclusive of that event.
|
static EventPosition |
EventPosition.fromSequenceNumber(long sequenceNumber)
Creates a position to an event in the partition at the provided sequence number.
|
static EventPosition |
EventPosition.fromSequenceNumber(long sequenceNumber,
boolean isInclusive)
Creates a position at the given sequence number.
|
EventPosition |
InitializationContext.getInitialPosition()
Returns the default initial event position from which the processing will start in the absence of a checkpoint in
CheckpointStore . |
static EventPosition |
EventPosition.latest()
Corresponds to the end of the partition, where no more events are currently enqueued.
|
Modifier and Type | Method and Description |
---|---|
void |
InitializationContext.setInitialPosition(EventPosition initialPosition)
If a different initial position is desirable for this partition, setting the initial position will start the
event processing from this position.
|
Constructor and Description |
---|
InitializationContext(PartitionContext partitionContext,
EventPosition initialPosition)
Creates an instance of InitializationContext for the partition provided in the
PartitionContext . |
Copyright © 2019 Microsoft Corporation. All rights reserved.