Orleans.Streaming.EventHubs Namespace

Classes

AggregatedCachePressureMonitor

Aggregated cache pressure monitor

AveragingCachePressureMonitor

Cache pressure monitor whose back pressure algorithm is based on averaging pressure value over all pressure contribution

AzureStorageOperationOptions
AzureStorageOperationOptionsValidator<TOptions>
AzureStoragePolicyOptions
AzureStorageUtils

General utility functions related to Azure storage.

AzureTableDataManager<T>

Utility class to encapsulate row-based access to Azure table storage.

DefaultEventHubReceiverMonitor

Default EventHub receiver monitor that tracks metrics using loggers PKI support.

EventDataExtensions

Extends EventData to support streaming

EventHubAdapterFactory

Queue adapter factory which allows the PersistentStreamProvider to use EventHub as its backend persistent event queue.

EventHubBatchContainer

Batch container that is delivers payload and stream position information for a set of events in an EventHub EventData.

EventHubBlockPoolMonitorDimensions

Aggregation dimensions for block pool monitor used in Eventhub stream provider ecosystem

EventHubCacheMonitorDimensions

Aggregation dimensions for cache monitor used in Eventhub stream provider ecosystem

EventHubCheckpointer

This class stores EventHub partition checkpointer information (a partition offset) in azure table storage.

EventHubCheckpointerFactory
EventHubDataAdapter

Default event hub data adapter. Users may subclass to override event data to stream mapping.

EventHubMessage

Replication of EventHub EventData class, reconstructed from cached data CachedEventHubMessage

EventHubMonitorAggregationDimensions

Base class for monitor aggregation dimensions, which is an information bag for the monitoring target. Monitors can use this information bag to build its aggregation dimensions.

EventHubPartitionSettings

Event Hub Partition settings

EventHubQueueCache

EventHub queue cache

EventHubQueueCacheFactory

Factory class to configure and create IEventHubQueueCache

EventHubReceiverMonitorDimensions

Aggregation dimensions for EventHubReceiverMonitor

EventHubSequenceToken

Event Hub messages consist of a batch of application layer events, so EventHub tokens contain three pieces of information. EventHubOffset - this is a unique value per partition that is used to start reading from this message in the partition. SequenceNumber - EventHub sequence numbers are unique ordered message IDs for messages within a partition.
The SequenceNumber is required for uniqueness and ordering of EventHub messages within a partition. event Index - Since each EventHub message may contain more than one application layer event, this value indicates which application layer event this token is for, within an EventHub message. It is required for uniqueness and ordering of application layer events within an EventHub message.

EventHubSequenceTokenV2

Event Hub messages consist of a batch of application layer events, so EventHub tokens contain three pieces of information. EventHubOffset - this is a unique value per partition that is used to start reading from this message in the partition. SequenceNumber - EventHub sequence numbers are unique ordered message IDs for messages within a partition.
The SequenceNumber is required for uniqueness and ordering of EventHub messages within a partition. event Index - Since each EventHub message may contain more than one application layer event, this value indicates which application layer event this token is for, within an EventHub message. It is required for uniqueness and ordering of application layer events within an EventHub message.

SlowConsumingPressureMonitor

Pressure monitor which is in favor of the slow consumer in the cache

Interfaces

ICachePressureMonitor

Cache pressure monitor records pressure contribution to the cache, and determine if the cache is under pressure based on its back pressure algorithm

IEventHubDataAdapter
IEventHubPartitionLocation

Location of a message within an EventHub partition

IEventHubQueueCache

Interface for a stream message cache that stores EventHub EventData

IEventHubQueueCacheFactory

Factory responsible for creating a message cache for an EventHub partition.

IEventHubReceiver

Abstraction on EventhubReceiver class, used to configure EventHubReceiver class in EventhubAdapterReceiver, also used to configure EHGeneratorReceiver in EventHubAdapterReceiver for testing purpose