EventHubConsumerGroup Class
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.
Represents the consumer group within an Event Hub. This class creates receivers for a specific consumer group within an Event Hub. This can be the default consumer group or another user-created consumer group.
public sealed class EventHubConsumerGroup : Microsoft.ServiceBus.Messaging.ClientEntity
type EventHubConsumerGroup = class
inherit ClientEntity
Public NotInheritable Class EventHubConsumerGroup
Inherits ClientEntity
- Inheritance
Fields
DefaultGroupName |
The name of the default ConsumerGroup that is pre-created when creating EventHub. |
EndOfStream |
The constant that denotes the end of a stream. This can be used as an offset argument in receiver creation to start receiving from the latest event, instead of a specific point in time/offset value. |
StartOfStream |
The constant that denotes the start of a stream. This can be used as an offset argument in receiver creation. |
Properties
EnableReceiverRuntimeMetric |
Gets or sets a value indicating whether the runtime metric of a receiver is enabled. |
EventHubPath |
Gets the event hub path. |
GroupName |
Gets the name of the consumer group. |
IsClosed | (Inherited from ClientEntity) |
PrefetchCount |
Gets or sets the number of events that any receive operation will actively cache. By default, this value is inherited from EventHubClient. The default value is 10,000. |
PrefetchSizeInBytes |
Gets or sets the maximum size (in bytes) in total that any receive operation will actively cache. The size of each event data is determined by the SerializedSizeInBytes property. |
RetryPolicy | (Inherited from ClientEntity) |
ThisLock | (Inherited from ClientEntity) |
Methods
Abort() |
Performs abort functionality on the messaging entity. (Inherited from ClientEntity) |
Close() |
Sends a cleanup message to Service Bus to signal the completion of the usage of an entity. (Inherited from ClientEntity) |
CloseAsync() |
Sends a cleanup message asynchronously to Service Bus to signal the completion of the usage of an entity. (Inherited from ClientEntity) |
CreateReceiver(String, DateTime, Int64, ReceiverOptions) |
Creates a new Event Hubs receiver in the specified partition, starting at the specified date and time.
You can use the created receiver to receive events for one Event Hubs partition, specified by |
CreateReceiver(String, DateTime, ReceiverOptions) |
Creates a new Event Hubs receiver in the specified partition, starting at the specified date and time.
You can use the created receiver to receive events for one Event Hubs partition, specified by |
CreateReceiver(String, EventPosition, Nullable<Int64>, ReceiverOptions) |
Creates a new Event Hubs receiver in the specified partition, at the specified starting position. You
can use the created receiver to receive events for one Event Hubs partition, specified by |
CreateReceiver(String, Int64, ReceiverOptions) |
Creates a new Event Hubs receiver in the specified partition, and the specified epoch value. You
can use the created receiver to receive events for one Event Hubs partition, specified by |
CreateReceiver(String, ReceiverOptions) |
Creates a new Event Hubs receiver in the specified partition. You can use the
created receiver to receive events for one Event Hubs partition, specified by |
CreateReceiver(String, String, Boolean, Int64, ReceiverOptions) |
Creates a new Event Hubs receiver in the specified partition, at the specified starting offset. You
can use the created receiver to receive events for one Event Hubs partition, specified by |
CreateReceiver(String, String, Boolean, ReceiverOptions) |
Creates a new Event Hubs receiver in the specified partition, at the specified starting offset. You
can use the created receiver to receive events for one Event Hubs partition, specified by |
CreateReceiver(String, String, Int64, ReceiverOptions) |
Creates a new Event Hubs receiver in the specified partition, at the specified starting offset. |
CreateReceiver(String, String, ReceiverOptions) |
Creates a new Event Hubs receiver in the specified partition, at the specified starting offset. You
can use the created receiver to receive events for one Event Hubs partition, specified by |
CreateReceiverAsync(String, DateTime, Int64, ReceiverOptions) |
Asynchronous version of CreateReceiver(String, DateTime, Int64, ReceiverOptions). |
CreateReceiverAsync(String, DateTime, ReceiverOptions) |
Asynchronous version of CreateReceiver(String, DateTime, ReceiverOptions). |
CreateReceiverAsync(String, EventPosition, Nullable<Int64>, ReceiverOptions) |
Asynchronous version of CreateReceiver(String, EventPosition, Nullable<Int64>, ReceiverOptions). |
CreateReceiverAsync(String, Int64, ReceiverOptions) |
Asynchronous version of CreateReceiver(String, Int64, ReceiverOptions). |
CreateReceiverAsync(String, ReceiverOptions) |
Asynchronous version of CreateReceiver(String, ReceiverOptions). |
CreateReceiverAsync(String, String, Boolean, Int64, ReceiverOptions) |
Asynchronous version of CreateReceiver(String, String, Boolean, Int64, ReceiverOptions). |
CreateReceiverAsync(String, String, Boolean, ReceiverOptions) |
Asynchronous version of CreateReceiver(String, String, Boolean, ReceiverOptions). |
CreateReceiverAsync(String, String, Int64, ReceiverOptions) |
Asynchronous version of CreateReceiver(String, String, Int64, ReceiverOptions). |
CreateReceiverAsync(String, String, ReceiverOptions) |
Asynchronous version of CreateReceiver(String, ReceiverOptions). |
Fault() |
For internal use only. Do not inherit from this class. (Inherited from ClientEntity) |
OnAbort() | (Inherited from ClientEntity) |
OnBeginClose(TimeSpan, AsyncCallback, Object) | (Inherited from ClientEntity) |
OnBeginOpen(TimeSpan, AsyncCallback, Object) | (Inherited from ClientEntity) |
OnClose(TimeSpan) | (Inherited from ClientEntity) |
OnClosed() | (Inherited from ClientEntity) |
OnEndClose(IAsyncResult) | (Inherited from ClientEntity) |
OnEndOpen(IAsyncResult) | (Inherited from ClientEntity) |
OnFaulted() | (Inherited from ClientEntity) |
OnOpen(TimeSpan) | (Inherited from ClientEntity) |
OnOpened() | (Inherited from ClientEntity) |
RegisterProcessor<T>(Lease, ICheckpointManager, EventProcessorOptions) |
Registers an implementation of IEventProcessor in order to start consuming events from Event Hubs for the specified PartitionId starting from Offset. Use this overload to create an event processor that checkpoints the message offset using a custom implementation of ICheckpointManager. |
RegisterProcessor<T>(Lease, ICheckpointManager) |
Registers an implementation of IEventProcessor in order to start consuming events from Event Hubs for the specified PartitionId starting from Offset. Use this overload to create an event processor that checkpoints the message offset using a custom implementation of ICheckpointManager. |
RegisterProcessorAsync<T>(Lease, ICheckpointManager, EventProcessorOptions) |
Asynchronous version of RegisterProcessor<T>(Lease, ICheckpointManager, EventProcessorOptions). |
RegisterProcessorAsync<T>(Lease, ICheckpointManager) |
Asynchronous version of RegisterProcessor<T>(Lease, ICheckpointManager). |
RegisterProcessorFactory(Lease, ICheckpointManager, IEventProcessorFactory, EventProcessorOptions) |
Registers the IEventProcessorFactory object used to create an instance of IEventProcessor in order to start consuming events for the partition specified by PartitionId, starting from Offset. Use this overload to create an event processor that checkpoints the message offset using a custom implementation of ICheckpointManager. |
RegisterProcessorFactory(Lease, ICheckpointManager, IEventProcessorFactory) |
Registers the IEventProcessorFactory object used to create an instance of IEventProcessor in order to start consuming events for the partition specified by PartitionId, starting from Offset. Use this overload to create an event processor that checkpoints the message offset using a custom implementation of ICheckpointManager. |
RegisterProcessorFactoryAsync(Lease, ICheckpointManager, IEventProcessorFactory, EventProcessorOptions) |
Asynchronous version of RegisterProcessorFactory(Lease, ICheckpointManager, IEventProcessorFactory, EventProcessorOptions). |
RegisterProcessorFactoryAsync(Lease, ICheckpointManager, IEventProcessorFactory) |
Asynchronous version of RegisterProcessorFactory(Lease, ICheckpointManager, IEventProcessorFactory). |
ThrowIfClosed() | (Inherited from ClientEntity) |
ThrowIfDisposed() | (Inherited from ClientEntity) |
ThrowIfDisposedOrImmutable() | (Inherited from ClientEntity) |
ThrowIfDisposedOrNotOpen() | (Inherited from ClientEntity) |
ThrowIfFaulted() | (Inherited from ClientEntity) |
UnregisterProcessor(Lease, CloseReason) |
Unregisters IEventProcessor for the partition specified by PartitionId. This results in CloseAsync(PartitionContext, CloseReason) being called on the underlying event processor. |
UnregisterProcessorAsync(Lease, CloseReason) |
Asynchronous version of UnregisterProcessor(Lease, CloseReason). |
Events
EventProcessorLifeCycleManagerFaulted |
Applies to
Azure SDK for .NET