EventProcessor<TPartition> Constructors
Definition
Important
Some information relates to prerelease product that may be substantially modified before it’s released. Microsoft makes no warranties, express or implied, with respect to the information provided here.
Overloads
EventProcessor<TPartition>() |
Initializes a new instance of the EventProcessor<TPartition> class. |
EventProcessor<TPartition>(Int32, String, String, EventProcessorOptions) |
Initializes a new instance of the EventProcessor<TPartition> class. |
EventProcessor<TPartition>(Int32, String, String, String, EventProcessorOptions) |
Initializes a new instance of the EventProcessor<TPartition> class. |
EventProcessor<TPartition>(Int32, String, String, String, AzureNamedKeyCredential, EventProcessorOptions) |
Initializes a new instance of the EventProcessor<TPartition> class. |
EventProcessor<TPartition>(Int32, String, String, String, AzureSasCredential, EventProcessorOptions) |
Initializes a new instance of the EventProcessor<TPartition> class. |
EventProcessor<TPartition>(Int32, String, String, String, TokenCredential, EventProcessorOptions) |
Initializes a new instance of the EventProcessor<TPartition> class. |
EventProcessor<TPartition>()
- Source:
- EventProcessor.cs
- Source:
- EventProcessor.cs
Initializes a new instance of the EventProcessor<TPartition> class.
protected EventProcessor ();
Protected Sub New ()
Applies to
EventProcessor<TPartition>(Int32, String, String, EventProcessorOptions)
- Source:
- EventProcessor.cs
- Source:
- EventProcessor.cs
Initializes a new instance of the EventProcessor<TPartition> class.
protected EventProcessor (int eventBatchMaximumCount, string consumerGroup, string connectionString, Azure.Messaging.EventHubs.Primitives.EventProcessorOptions options = default);
new Azure.Messaging.EventHubs.Primitives.EventProcessor<'Partition (requires 'Partition :> Azure.Messaging.EventHubs.Primitives.EventProcessorPartition and 'Partition : (new : unit -> 'Partition))> : int * string * string * Azure.Messaging.EventHubs.Primitives.EventProcessorOptions -> Azure.Messaging.EventHubs.Primitives.EventProcessor<'Partition (requires 'Partition :> Azure.Messaging.EventHubs.Primitives.EventProcessorPartition and 'Partition : (new : unit -> 'Partition))>
Protected Sub New (eventBatchMaximumCount As Integer, consumerGroup As String, connectionString As String, Optional options As EventProcessorOptions = Nothing)
Parameters
- eventBatchMaximumCount
- Int32
The desired number of events to include in a batch to be processed. This size is the maximum count in a batch; the actual count may be smaller, depending on whether events are available in the Event Hub.
- 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.
- options
- EventProcessorOptions
The set of options to use for the processor.
Exceptions
Occurs when the requested eventBatchMaximumCount
is less than 1.
Remarks
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
EventProcessor<TPartition>(Int32, String, String, String, EventProcessorOptions)
- Source:
- EventProcessor.cs
- Source:
- EventProcessor.cs
Initializes a new instance of the EventProcessor<TPartition> class.
protected EventProcessor (int eventBatchMaximumCount, string consumerGroup, string connectionString, string eventHubName, Azure.Messaging.EventHubs.Primitives.EventProcessorOptions options = default);
new Azure.Messaging.EventHubs.Primitives.EventProcessor<'Partition (requires 'Partition :> Azure.Messaging.EventHubs.Primitives.EventProcessorPartition and 'Partition : (new : unit -> 'Partition))> : int * string * string * string * Azure.Messaging.EventHubs.Primitives.EventProcessorOptions -> Azure.Messaging.EventHubs.Primitives.EventProcessor<'Partition (requires 'Partition :> Azure.Messaging.EventHubs.Primitives.EventProcessorPartition and 'Partition : (new : unit -> 'Partition))>
Protected Sub New (eventBatchMaximumCount As Integer, consumerGroup As String, connectionString As String, eventHubName As String, Optional options As EventProcessorOptions = Nothing)
Parameters
- eventBatchMaximumCount
- Int32
The desired number of events to include in a batch to be processed. This size is the maximum count in a batch; the actual count may be smaller, depending on whether events are available in the Event Hub.
- 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.
- options
- EventProcessorOptions
The set of options to use for the processor.
Exceptions
Occurs when the requested eventBatchMaximumCount
is less than 1.
Remarks
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
EventProcessor<TPartition>(Int32, String, String, String, AzureNamedKeyCredential, EventProcessorOptions)
- Source:
- EventProcessor.cs
- Source:
- EventProcessor.cs
Initializes a new instance of the EventProcessor<TPartition> class.
protected EventProcessor (int eventBatchMaximumCount, string consumerGroup, string fullyQualifiedNamespace, string eventHubName, Azure.AzureNamedKeyCredential credential, Azure.Messaging.EventHubs.Primitives.EventProcessorOptions options = default);
new Azure.Messaging.EventHubs.Primitives.EventProcessor<'Partition (requires 'Partition :> Azure.Messaging.EventHubs.Primitives.EventProcessorPartition and 'Partition : (new : unit -> 'Partition))> : int * string * string * string * Azure.AzureNamedKeyCredential * Azure.Messaging.EventHubs.Primitives.EventProcessorOptions -> Azure.Messaging.EventHubs.Primitives.EventProcessor<'Partition (requires 'Partition :> Azure.Messaging.EventHubs.Primitives.EventProcessorPartition and 'Partition : (new : unit -> 'Partition))>
Protected Sub New (eventBatchMaximumCount As Integer, consumerGroup As String, fullyQualifiedNamespace As String, eventHubName As String, credential As AzureNamedKeyCredential, Optional options As EventProcessorOptions = Nothing)
Parameters
- eventBatchMaximumCount
- Int32
The desired number of events to include in a batch to be processed. This size is the maximum count in a batch; the actual count may be smaller, depending on whether events are available in the Event Hub.
- 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.
- options
- EventProcessorOptions
The set of options to use for the processor.
Exceptions
Occurs when the requested eventBatchMaximumCount
is less than 1.
Applies to
EventProcessor<TPartition>(Int32, String, String, String, AzureSasCredential, EventProcessorOptions)
- Source:
- EventProcessor.cs
- Source:
- EventProcessor.cs
Initializes a new instance of the EventProcessor<TPartition> class.
protected EventProcessor (int eventBatchMaximumCount, string consumerGroup, string fullyQualifiedNamespace, string eventHubName, Azure.AzureSasCredential credential, Azure.Messaging.EventHubs.Primitives.EventProcessorOptions options = default);
new Azure.Messaging.EventHubs.Primitives.EventProcessor<'Partition (requires 'Partition :> Azure.Messaging.EventHubs.Primitives.EventProcessorPartition and 'Partition : (new : unit -> 'Partition))> : int * string * string * string * Azure.AzureSasCredential * Azure.Messaging.EventHubs.Primitives.EventProcessorOptions -> Azure.Messaging.EventHubs.Primitives.EventProcessor<'Partition (requires 'Partition :> Azure.Messaging.EventHubs.Primitives.EventProcessorPartition and 'Partition : (new : unit -> 'Partition))>
Protected Sub New (eventBatchMaximumCount As Integer, consumerGroup As String, fullyQualifiedNamespace As String, eventHubName As String, credential As AzureSasCredential, Optional options As EventProcessorOptions = Nothing)
Parameters
- eventBatchMaximumCount
- Int32
The desired number of events to include in a batch to be processed. This size is the maximum count in a batch; the actual count may be smaller, depending on whether events are available in the Event Hub.
- 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 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.
- options
- EventProcessorOptions
The set of options to use for the processor.
Exceptions
Occurs when the requested eventBatchMaximumCount
is less than 1.
Applies to
EventProcessor<TPartition>(Int32, String, String, String, TokenCredential, EventProcessorOptions)
- Source:
- EventProcessor.cs
- Source:
- EventProcessor.cs
Initializes a new instance of the EventProcessor<TPartition> class.
protected EventProcessor (int eventBatchMaximumCount, string consumerGroup, string fullyQualifiedNamespace, string eventHubName, Azure.Core.TokenCredential credential, Azure.Messaging.EventHubs.Primitives.EventProcessorOptions options = default);
new Azure.Messaging.EventHubs.Primitives.EventProcessor<'Partition (requires 'Partition :> Azure.Messaging.EventHubs.Primitives.EventProcessorPartition and 'Partition : (new : unit -> 'Partition))> : int * string * string * string * Azure.Core.TokenCredential * Azure.Messaging.EventHubs.Primitives.EventProcessorOptions -> Azure.Messaging.EventHubs.Primitives.EventProcessor<'Partition (requires 'Partition :> Azure.Messaging.EventHubs.Primitives.EventProcessorPartition and 'Partition : (new : unit -> 'Partition))>
Protected Sub New (eventBatchMaximumCount As Integer, consumerGroup As String, fullyQualifiedNamespace As String, eventHubName As String, credential As TokenCredential, Optional options As EventProcessorOptions = Nothing)
Parameters
- eventBatchMaximumCount
- Int32
The desired number of events to include in a batch to be processed. This size is the maximum count in a batch; the actual count may be smaller, depending on whether events are available in the Event Hub.
- 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 managed 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.
- options
- EventProcessorOptions
The set of options to use for the processor.
Exceptions
Occurs when the requested eventBatchMaximumCount
is less than 1.
Applies to
Azure SDK for .NET