Uses of Class
com.azure.messaging.eventhubs.EventData
Packages that use EventData
Package
Description
Azure Event Hubs is a highly scalable
publish-subscribe service that can ingest millions of events per second and stream them to multiple consumers.
Package containing classes used for creating and configuring events that are being sent-to and received-from Azure
Event Hubs service.
-
Uses of EventData in com.azure.messaging.eventhubs
Methods in com.azure.messaging.eventhubs that return EventDataModifier and TypeMethodDescriptionEventData.addContext(String key, Object value) Adds a new key value pair to the existing context on Event Data.EventData.setBodyAsBinaryData(com.azure.core.util.BinaryData binaryData) Sets a new binary body and correspondingAmqpAnnotatedMessageon the event.EventData.setContentType(String contentType) Sets the MIME type describing the data contained in thegetBody(), intended to allow consumers to make informed decisions for inspecting and processing the event.EventData.setCorrelationId(String correlationId) Sets an application-defined value that represents the context to use for correlation across one or more operations.EventData.setMessageId(String messageId) Sets an application-defined value that uniquely identifies the event.Methods in com.azure.messaging.eventhubs with parameters of type EventDataModifier and TypeMethodDescriptionEventHubBufferedProducerAsyncClient.enqueueEvent(EventData eventData) Enqueues anEventDatainto the buffer to be published to the Event Hub.EventHubBufferedProducerAsyncClient.enqueueEvent(EventData eventData, SendOptions options) Enqueues anEventDatainto the buffer to be published to the Event Hub.EventHubBufferedProducerClient.enqueueEvent(EventData eventData) Enqueues anEventDatainto the buffer to be published to the Event Hub.EventHubBufferedProducerClient.enqueueEvent(EventData eventData, SendOptions options) Enqueues anEventDatainto the buffer to be published to the Event Hub.booleanTries to add aneventto the batch.Method parameters in com.azure.messaging.eventhubs with type arguments of type EventDataModifier and TypeMethodDescriptionEventHubBufferedProducerAsyncClient.enqueueEvents(Iterable<EventData> events) Enqueues a set ofEventDatainto the buffer to be published to the Event Hub.EventHubBufferedProducerAsyncClient.enqueueEvents(Iterable<EventData> events, SendOptions options) Enqueues a set ofEventDatainto the buffer to be published to the Event Hub.EventHubBufferedProducerClient.enqueueEvents(Iterable<EventData> events) Enqueues a set ofEventDatainto the buffer to be published to the Event Hub.EventHubBufferedProducerClient.enqueueEvents(Iterable<EventData> events, SendOptions options) Enqueues a set ofEventDatainto the buffer to be published to the Event Hub.Sends a set of events to the associated Event Hub using a batched approach.EventHubProducerAsyncClient.send(Iterable<EventData> events, SendOptions options) Sends a set of events to the associated Event Hub using a batched approach.voidSends a set of events to the associated Event Hub using a batched approach.voidEventHubProducerClient.send(Iterable<EventData> events, SendOptions options) Sends a set of events to the associated Event Hub using a batched approach. -
Uses of EventData in com.azure.messaging.eventhubs.models
Methods in com.azure.messaging.eventhubs.models that return EventDataModifier and TypeMethodDescriptionPartitionEvent.getData()Gets the event received from the partition.EventContext.getEventData()Returns the event data received from Event Hub.Methods in com.azure.messaging.eventhubs.models that return types with arguments of type EventDataModifier and TypeMethodDescriptionEventBatchContext.getEvents()Returns a list of event data received from Event Hub.SendBatchFailedContext.getEvents()Gets the events that failed to send.SendBatchSucceededContext.getEvents()Gets the set of events in the batch that was published.Constructors in com.azure.messaging.eventhubs.models with parameters of type EventDataModifierConstructorDescriptionEventContext(PartitionContext partitionContext, EventData eventData, CheckpointStore checkpointStore, LastEnqueuedEventProperties lastEnqueuedEventProperties) Creates an instance ofEventContext.PartitionEvent(PartitionContext partitionContext, EventData eventData, LastEnqueuedEventProperties lastEnqueuedEventProperties) Creates an instance of PartitionEvent.Constructor parameters in com.azure.messaging.eventhubs.models with type arguments of type EventDataModifierConstructorDescriptionEventBatchContext(PartitionContext partitionContext, List<EventData> events, CheckpointStore checkpointStore, LastEnqueuedEventProperties lastEnqueuedEventProperties) Creates an instance ofEventBatchContext.SendBatchFailedContext(Iterable<EventData> events, String partitionId, Throwable throwable) Creates a new instance.SendBatchSucceededContext(Iterable<EventData> events, String partitionId) Initializes a new instance of the class.