EventProcessorClient Constructors

Definition

Overloads

EventProcessorClient()

Initializes a new instance of the EventProcessorClient class.

EventProcessorClient(BlobContainerClient, String, String)

Initializes a new instance of the EventProcessorClient class.

EventProcessorClient(BlobContainerClient, String, String, EventProcessorClientOptions)

Initializes a new instance of the EventProcessorClient class.

EventProcessorClient(BlobContainerClient, String, String, String)

Initializes a new instance of the EventProcessorClient class.

EventProcessorClient(BlobContainerClient, String, String, String, EventProcessorClientOptions)

Initializes a new instance of the EventProcessorClient class.

EventProcessorClient(BlobContainerClient, String, String, String, AzureNamedKeyCredential, EventProcessorClientOptions)

Initializes a new instance of the EventProcessorClient class.

EventProcessorClient(BlobContainerClient, String, String, String, AzureSasCredential, EventProcessorClientOptions)

Initializes a new instance of the EventProcessorClient class.

EventProcessorClient(BlobContainerClient, String, String, String, TokenCredential, EventProcessorClientOptions)

Initializes a new instance of the EventProcessorClient class.

EventProcessorClient()

Source:
EventProcessorClient.cs

Initializes a new instance of the EventProcessorClient class.

protected EventProcessorClient ();
Protected Sub New ()

Applies to

EventProcessorClient(BlobContainerClient, String, String)

Source:
EventProcessorClient.cs

Initializes a new instance of the EventProcessorClient class.

public EventProcessorClient (Azure.Storage.Blobs.BlobContainerClient checkpointStore, string consumerGroup, string connectionString);
new Azure.Messaging.EventHubs.EventProcessorClient : Azure.Storage.Blobs.BlobContainerClient * string * string -> Azure.Messaging.EventHubs.EventProcessorClient
Public Sub New (checkpointStore As BlobContainerClient, consumerGroup As String, connectionString As String)

Parameters

checkpointStore
BlobContainerClient

The client responsible for persisting checkpoints and processor state to durable storage. Processor instances sharing this storage will attempt to coordinate and share work. The associated container is expected to exist.

consumerGroup
String

The name of the consumer group this processor is associated with. The processor will assert exclusive read access to partitions for this group.

connectionString
String

The connection string to use for connecting to the Event Hubs namespace; it is expected that the Event Hub name and the shared key properties are contained in this connection string.

Remarks

The container associated with the checkpointStore is expected to exist; the EventProcessorClient does not assume the ability to manage the storage account and is safe to run with only read/write permission for blobs in the container. It is recommended that this container be unique to the Event Hub and consumer group used by the processor and that it not contain other blobs.

If the connection string is copied from the Event Hubs namespace, it will likely not contain the name of the desired Event Hub, which is needed. In this case, the name can be added manually by adding ";EntityPath=[[ EVENT HUB NAME ]]" to the end of the connection string. For example, ";EntityPath=telemetry-hub".

If you have defined a shared access policy directly on the Event Hub itself, then copying the connection string from that Event Hub will result in a connection string that contains the name.

Applies to

EventProcessorClient(BlobContainerClient, String, String, EventProcessorClientOptions)

Source:
EventProcessorClient.cs

Initializes a new instance of the EventProcessorClient class.

public EventProcessorClient (Azure.Storage.Blobs.BlobContainerClient checkpointStore, string consumerGroup, string connectionString, Azure.Messaging.EventHubs.EventProcessorClientOptions clientOptions);
new Azure.Messaging.EventHubs.EventProcessorClient : Azure.Storage.Blobs.BlobContainerClient * string * string * Azure.Messaging.EventHubs.EventProcessorClientOptions -> Azure.Messaging.EventHubs.EventProcessorClient
Public Sub New (checkpointStore As BlobContainerClient, consumerGroup As String, connectionString As String, clientOptions As EventProcessorClientOptions)

Parameters

checkpointStore
BlobContainerClient

The client responsible for persisting checkpoints and processor state to durable storage. Processor instances sharing this storage will attempt to coordinate and share work. The associated container is expected to exist.

consumerGroup
String

The name of the consumer group this processor is associated with. The processor will assert exclusive read access to partitions for this group.

connectionString
String

The connection string to use for connecting to the Event Hubs namespace; it is expected that the Event Hub name and the shared key properties are contained in this connection string.

clientOptions
EventProcessorClientOptions

The set of options to use for this processor.

Remarks

The container associated with the checkpointStore is expected to exist; the EventProcessorClient does not assume the ability to manage the storage account and is safe to run with only read/write permission for blobs in the container. It is recommended that this container be unique to the Event Hub and consumer group used by the processor and that it not contain other blobs.

If the connection string is copied from the Event Hubs namespace, it will likely not contain the name of the desired Event Hub, which is needed. In this case, the name can be added manually by adding ";EntityPath=[[ EVENT HUB NAME ]]" to the end of the connection string. For example, ";EntityPath=telemetry-hub".

If you have defined a shared access policy directly on the Event Hub itself, then copying the connection string from that Event Hub will result in a connection string that contains the name.

Applies to

EventProcessorClient(BlobContainerClient, String, String, String)

Source:
EventProcessorClient.cs

Initializes a new instance of the EventProcessorClient class.

public EventProcessorClient (Azure.Storage.Blobs.BlobContainerClient checkpointStore, string consumerGroup, string connectionString, string eventHubName);
new Azure.Messaging.EventHubs.EventProcessorClient : Azure.Storage.Blobs.BlobContainerClient * string * string * string -> Azure.Messaging.EventHubs.EventProcessorClient
Public Sub New (checkpointStore As BlobContainerClient, consumerGroup As String, connectionString As String, eventHubName As String)

Parameters

checkpointStore
BlobContainerClient

The client responsible for persisting checkpoints and processor state to durable storage. Processor instances sharing this storage will attempt to coordinate and share work. The associated container is expected to exist.

consumerGroup
String

The name of the consumer group this processor is associated with. The processor will assert exclusive read access to partitions for this group.

connectionString
String

The connection string to use for connecting to the Event Hubs namespace; it is expected that the shared key properties are contained in this connection string, but not the Event Hub name.

eventHubName
String

The name of the specific Event Hub to associate the processor with.

Remarks

The container associated with the checkpointStore is expected to exist; the EventProcessorClient does not assume the ability to manage the storage account and is safe to run with only read/write permission for blobs in the container. It is recommended that this container be unique to the Event Hub and consumer group used by the processor and that it not contain other blobs.

If the connection string is copied from the Event Hub itself, it will contain the name of the desired Event Hub, and can be used directly without passing the eventHubName. The name of the Event Hub should be passed only once, either as part of the connection string or separately.

Applies to

EventProcessorClient(BlobContainerClient, String, String, String, EventProcessorClientOptions)

Source:
EventProcessorClient.cs

Initializes a new instance of the EventProcessorClient class.

public EventProcessorClient (Azure.Storage.Blobs.BlobContainerClient checkpointStore, string consumerGroup, string connectionString, string eventHubName, Azure.Messaging.EventHubs.EventProcessorClientOptions clientOptions);
new Azure.Messaging.EventHubs.EventProcessorClient : Azure.Storage.Blobs.BlobContainerClient * string * string * string * Azure.Messaging.EventHubs.EventProcessorClientOptions -> Azure.Messaging.EventHubs.EventProcessorClient
Public Sub New (checkpointStore As BlobContainerClient, consumerGroup As String, connectionString As String, eventHubName As String, clientOptions As EventProcessorClientOptions)

Parameters

checkpointStore
BlobContainerClient

The client responsible for persisting checkpoints and processor state to durable storage. Processor instances sharing this storage will attempt to coordinate and share work. The associated container is expected to exist.

consumerGroup
String

The name of the consumer group this processor is associated with. The processor will assert exclusive read access to partitions for this group.

connectionString
String

The connection string to use for connecting to the Event Hubs namespace; it is expected that the shared key properties are contained in this connection string, but not the Event Hub name.

eventHubName
String

The name of the specific Event Hub to associate the processor with.

clientOptions
EventProcessorClientOptions

The set of options to use for this processor.

Remarks

The container associated with the checkpointStore is expected to exist; the EventProcessorClient does not assume the ability to manage the storage account and is safe to run with only read/write permission for blobs in the container. It is recommended that this container be unique to the Event Hub and consumer group used by the processor and that it not contain other blobs.

If the connection string is copied from the Event Hub itself, it will contain the name of the desired Event Hub, and can be used directly without passing the eventHubName. The name of the Event Hub should be passed only once, either as part of the connection string or separately.

Applies to

EventProcessorClient(BlobContainerClient, String, String, String, AzureNamedKeyCredential, EventProcessorClientOptions)

Source:
EventProcessorClient.cs

Initializes a new instance of the EventProcessorClient class.

public EventProcessorClient (Azure.Storage.Blobs.BlobContainerClient checkpointStore, string consumerGroup, string fullyQualifiedNamespace, string eventHubName, Azure.AzureNamedKeyCredential credential, Azure.Messaging.EventHubs.EventProcessorClientOptions clientOptions = default);
new Azure.Messaging.EventHubs.EventProcessorClient : Azure.Storage.Blobs.BlobContainerClient * string * string * string * Azure.AzureNamedKeyCredential * Azure.Messaging.EventHubs.EventProcessorClientOptions -> Azure.Messaging.EventHubs.EventProcessorClient
Public Sub New (checkpointStore As BlobContainerClient, consumerGroup As String, fullyQualifiedNamespace As String, eventHubName As String, credential As AzureNamedKeyCredential, Optional clientOptions As EventProcessorClientOptions = Nothing)

Parameters

checkpointStore
BlobContainerClient

The client responsible for persisting checkpoints and processor state to durable storage. Processor instances sharing this storage will attempt to coordinate and share work. The associated container is expected to exist.

consumerGroup
String

The name of the consumer group this processor is associated with. The processor will assert exclusive read access to partitions for this group.

fullyQualifiedNamespace
String

The fully qualified Event Hubs namespace to connect to. This is likely to be similar to {yournamespace}.servicebus.windows.net.

eventHubName
String

The name of the specific Event Hub to associate the processor with.

credential
AzureNamedKeyCredential

The shared access key credential to use for authorization. Access controls may be specified by the Event Hubs namespace or the requested Event Hub, depending on Azure configuration.

clientOptions
EventProcessorClientOptions

The set of options to use for this processor.

Remarks

The container associated with the checkpointStore is expected to exist; the EventProcessorClient does not assume the ability to manage the storage account and is safe to run with only read/write permission for blobs in the container. It is recommended that this container be unique to the Event Hub and consumer group used by the processor and that it not contain other blobs.

Applies to

EventProcessorClient(BlobContainerClient, String, String, String, AzureSasCredential, EventProcessorClientOptions)

Source:
EventProcessorClient.cs

Initializes a new instance of the EventProcessorClient class.

public EventProcessorClient (Azure.Storage.Blobs.BlobContainerClient checkpointStore, string consumerGroup, string fullyQualifiedNamespace, string eventHubName, Azure.AzureSasCredential credential, Azure.Messaging.EventHubs.EventProcessorClientOptions clientOptions = default);
new Azure.Messaging.EventHubs.EventProcessorClient : Azure.Storage.Blobs.BlobContainerClient * string * string * string * Azure.AzureSasCredential * Azure.Messaging.EventHubs.EventProcessorClientOptions -> Azure.Messaging.EventHubs.EventProcessorClient
Public Sub New (checkpointStore As BlobContainerClient, consumerGroup As String, fullyQualifiedNamespace As String, eventHubName As String, credential As AzureSasCredential, Optional clientOptions As EventProcessorClientOptions = Nothing)

Parameters

checkpointStore
BlobContainerClient

The client responsible for persisting checkpoints and processor state to durable storage. Processor instances sharing this storage will attempt to coordinate and share work. The associated container is expected to exist.

consumerGroup
String

The name of the consumer group this processor is associated with. The processor will assert exclusive read access to partitions for this group.

fullyQualifiedNamespace
String

The fully qualified Event Hubs namespace to connect to. This is likely to be similar to {yournamespace}.servicebus.windows.net.

eventHubName
String

The name of the specific Event Hub to associate the processor with.

credential
AzureSasCredential

The shared access signature credential to use for authorization. Access controls may be specified by the Event Hubs namespace or the requested Event Hub, depending on Azure configuration.

clientOptions
EventProcessorClientOptions

The set of options to use for this processor.

Remarks

The container associated with the checkpointStore is expected to exist; the EventProcessorClient does not assume the ability to manage the storage account and is safe to run with only read/write permission for blobs in the container. It is recommended that this container be unique to the Event Hub and consumer group used by the processor and that it not contain other blobs.

Applies to

EventProcessorClient(BlobContainerClient, String, String, String, TokenCredential, EventProcessorClientOptions)

Source:
EventProcessorClient.cs

Initializes a new instance of the EventProcessorClient class.

public EventProcessorClient (Azure.Storage.Blobs.BlobContainerClient checkpointStore, string consumerGroup, string fullyQualifiedNamespace, string eventHubName, Azure.Core.TokenCredential credential, Azure.Messaging.EventHubs.EventProcessorClientOptions clientOptions = default);
new Azure.Messaging.EventHubs.EventProcessorClient : Azure.Storage.Blobs.BlobContainerClient * string * string * string * Azure.Core.TokenCredential * Azure.Messaging.EventHubs.EventProcessorClientOptions -> Azure.Messaging.EventHubs.EventProcessorClient
Public Sub New (checkpointStore As BlobContainerClient, consumerGroup As String, fullyQualifiedNamespace As String, eventHubName As String, credential As TokenCredential, Optional clientOptions As EventProcessorClientOptions = Nothing)

Parameters

checkpointStore
BlobContainerClient

The client responsible for persisting checkpoints and processor state to durable storage. Processor instances sharing this storage will attempt to coordinate and share work. The associated container is expected to exist.

consumerGroup
String

The name of the consumer group this processor is associated with. The processor will assert exclusive read access to partitions for this group.

fullyQualifiedNamespace
String

The fully qualified Event Hubs namespace to connect to. This is likely to be similar to {yournamespace}.servicebus.windows.net.

eventHubName
String

The name of the specific Event Hub to associate the processor with.

credential
TokenCredential

The Azure identity credential to use for authorization. Access controls may be specified by the Event Hubs namespace or the requested Event Hub, depending on Azure configuration.

clientOptions
EventProcessorClientOptions

The set of options to use for this processor.

Remarks

The container associated with the checkpointStore is expected to exist; the EventProcessorClient does not assume the ability to manage the storage account and is safe to run with only read/write permission for blobs in the container. It is recommended that this container be unique to the Event Hub and consumer group used by the processor and that it not contain other blobs.

Applies to