Microsoft.Azure.EventHubs Namespace

Classes

AzureActiveDirectoryTokenProvider

Represents the Azure Active Directory token provider for the Event Hubs.

BatchOptions

Options to define partiton key and maximum message size while creating an EventDataBatch.

ClientEntity

Contract for all client entities with Open-Close/Abort state m/c main-purpose: closeAll related entities

EventData

The data structure encapsulating the Event being sent-to and received-from EventHubs. Each EventHubs partition can be visualized as a Stream of EventData.

EventData.SystemPropertiesCollection

A collection used to store properties which are set by the Event Hubs service.

EventDataBatch

A helper class for creating an IEnumerable<EventData> taking into account the max size limit, so that the IEnumerable<EventData> can be passed to the Send or SendAsync method of an EventHubClient to send the EventData objects as a batch.

EventDataDiagnosticExtensions

Diagnostic extension methods for EventData.

EventHubClient

Anchor class - all EventHub client operations start here. See CreateFromConnectionString(String)

EventHubPartitionRuntimeInformation

Contains information regarding an event hub partition.

EventHubRuntimeInformation

Contains information regarding Event Hubs.

EventHubsCommunicationException

Exception for signaling general communication errors related to messaging operations.

EventHubsConnectionStringBuilder

EventHubsConnectionStringBuilder can be used to construct a connection string which can establish communication with Event Hubs entities. It can also be used to perform basic validation on an existing connection string.

A connection string is basically a string consisted of key-value pair separated by ";". Basic format is "<key>=<value>[;<key>=<value>]" where supported key name are as follow:

Endpoint - the URL that contains the Event Hubs namespace

EntityPath - the path to the Event Hub entity

SharedAccessKeyName - the key name to the corresponding shared access policy rule for the namespace, or entity.

SharedAccessKey - the key for the corresponding shared access policy rule of the namespace or entity.
EventHubsException

Base Exception for various Event Hubs errors.

EventHubsTimeoutException

The exception that is thrown when a time out is encountered. Callers retry the operation.

EventPosition

Represents options can be set during the creation of a event hub receiver.

JsonSecurityToken

Extends SecurityToken for JWT specific properties

ManagedIdentityTokenProvider

Represents the Azure Active Directory token provider for Azure Managed Identity integration.

MessageSizeExceededException

The exception is thrown when the message size exceeds what AMQP allows on the link.

MessagingEntityNotFoundException

The exception that is thrown when the Event Hub is not found on the namespace.

PartitionReceiver

This is a logical representation of receiving from a EventHub partition.

A PartitionReceiver is tied to a ConsumerGroup + Partition combination. If you are creating an epoch based PartitionReceiver (i.e. PartitionReceiver.Epoch != 0) you cannot have more than one active receiver per ConsumerGroup + Partition combo. You can have multiple receivers per ConsumerGroup + Partition combination with non-epoch receivers.

PartitionSender

This sender class is a logical representation of sending events to a specific EventHub partition. Do not use this class if you do not care about sending events to specific partitions, instead use SendAsync(EventData).

PublisherRevokedException

Exception for signaling revoked publisher errors.

QuotaExceededException

Provides an Event Hubs quota exceeded exception.

ReceiverDisconnectedException

This exception is thrown if two or more PartitionReceiver instances connect to the same partition with different epoch values.

ReceiverOptions

Represents options can be set during the creation of a event hub receiver.

ReceiverRuntimeInformation

Represents the approximate receiver runtime information for a logical partition of an Event Hub.

RetryExponential

RetryPolicy implementation where the delay between retries will grow in a staggered exponential manner. RetryPolicy can be set on the client using EventHubClient. RetryIntervals will be computed using a retryFactor which is a function of deltaBackOff (MaximumBackoff - MinimumBackoff) and MaximumRetryCount

RetryPolicy

Represents an abstraction for retrying messaging operations. Users should not implement this class, and instead should use one of the provided implementations.

SecurityToken

Provides information about a security token such as audience, expiry time, and the string token value.

ServerBusyException

The exception that is thrown when a server is busy. Callers should wait a while and retry the operation.

SharedAccessSignatureToken

A SecurityToken that wraps a Shared Access Signature

SharedAccessSignatureTokenProvider

The SharedAccessSignatureTokenProvider generates tokens using a shared access key or existing signature.

TokenProvider

This abstract base class can be extended to implement additional token providers.

Interfaces

IPartitionReceiveHandler

A handler interface for the receive operation. Use any implementation of this interface to specify user action when using SetReceiveHandler(IPartitionReceiveHandler, Boolean).

ITokenProvider

Provides interface definition of a token provider.

Enums

EventHubsException.ErrorSourceType

Enumerates the types of error sources for the messaging communication.

TokenScope

A enum representing the scope of the SecurityToken.

TransportType

Supported transport types

Delegates

AzureActiveDirectoryTokenProvider.AuthenticationCallback

The authentication delegate to provide access token.