 Consume
Consume
Consume events from Azure Event Hubs.
type: "io.kestra.plugin.azure.eventhubs.Consume"Examples
Consume data events from Azure EventHubs.
id: azure_eventhubs_consume_data_events
namespace: company.team
tasks:
  - id: consume_from_eventhub
    type: io.kestra.plugin.azure.eventhubs.Consume
    eventHubName: my_eventhub
    namespace: my_eventhub_namespace
    connectionString: "{{ secret('EVENTHUBS_CONNECTION') }}"
    bodyDeserializer: JSON
    consumerGroup: "$Default"
    checkpointStoreProperties:
      containerName: kestra
      connectionString: "{{ secret('BLOB_CONNECTION') }}"
Properties
checkpointStoreProperties *Requiredobject
The config properties to be used for configuring the BlobCheckpointStore.
Azure Event Hubs Checkpoint Store can be used for storing checkpoints while processing events from Azure Event Hubs.
eventHubName *Requiredstring
The event hub to read from.
namespace *Requiredstring
Namespace name of the event hub to connect to.
bodyDeserializer string
STRINGSTRINGBINARYIONJSONThe Deserializer to be used for serializing the event value.
bodyDeserializerProperties object
{}The config properties to be passed to the Deserializer.
Configs in key/value pairs.
clientMaxRetries integerstring
5The maximum number of retry attempts before considering a client operation to have failed.
clientRetryDelay integerstring
500The maximum permissible delay between retry attempts in milliseconds.
connectionString string
Connection string of the Storage Account.
consumerGroup string
$DefaultThe consumer group.
customEndpointAddress string
Custom endpoint address when connecting to the Event Hubs service.
enqueueTime string
The ISO Datetime to be used when PartitionStartingPosition is configured to INSTANT.
Configs in key/value pairs.
maxBatchSizePerPartition integerstring
50The maximum number of events to consume per event hub partition per poll.
maxDuration string
PT10SdurationThe max time duration to wait to receive events from all partitions.
maxWaitTimePerPartition string
PT5SdurationThe max time duration to wait to receive a batch of events up to the maxBatchSizePerPartition.
partitionStartingPosition string
EARLIESTEARLIESTLATESTINSTANTThe starting position.
sasToken string
The SAS token to use for authenticating requests.
This string should only be the query parameters (with or without a leading '?') and not a full URL.
Outputs
eventsCount integer
Number of events consumed from Azure Event Hubs.
uri string
uriURI of a kestra internal storage file containing the messages.
