Edit

Share via


EventHubAdapterFactory Class

Definition

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

public class EventHubAdapterFactory : Orleans.Streams.IQueueAdapter, Orleans.Streams.IQueueAdapterCache, Orleans.Streams.IQueueAdapterFactory
type EventHubAdapterFactory = class
    interface IQueueAdapterFactory
    interface IQueueAdapter
    interface IQueueAdapterCache
Public Class EventHubAdapterFactory
Implements IQueueAdapter, IQueueAdapterCache, IQueueAdapterFactory
Inheritance
EventHubAdapterFactory
Derived
Implements

Constructors

EventHubAdapterFactory()
EventHubAdapterFactory(String, EventHubOptions, EventHubReceiverOptions, EventHubStreamCachePressureOptions, StreamCacheEvictionOptions, StreamStatisticOptions, IEventHubDataAdapter, IServiceProvider, SerializationManager, ITelemetryProducer, ILoggerFactory)
EventHubAdapterFactory(String, EventHubOptions, EventHubReceiverOptions, EventHubStreamCachePressureOptions, StreamCacheEvictionOptions, StreamStatisticOptions, IServiceProvider, SerializationManager, ITelemetryProducer, ILoggerFactory)

Fields

adapterSettings

Stream provider settings

checkpointerSettings

Checkpointer settings

dataAdapter

Data adapter

EventHubReceiverFactory

Factory to create a IEventHubReceiver

hubSettings

Event Hub settings

logger

Orleans logging

providerConfig

Provider configuration

serviceProvider

Framework service provider

Properties

CacheFactory

Creates a message cache for an eventhub partition.

CheckpointerFactory

Creates a parition checkpointer.

Direction

Direction of this queue adapter: Read, Write or ReadWrite.

IsRewindable

Determines whether this is a rewindable stream adapter - supports subscribing from previous point in time.

Name

Name of the adapter. Primarily for logging purposes

QueueMapperFactory

Create a queue mapper to map EventHub partitions to queues

ReceiverMonitorFactory

Create a receiver monitor to report performance metrics. Factory funciton should return an IEventHubReceiverMonitor.

SerializationManager

Gets the serialization manager.

StreamFailureHandlerFactory

Creates a failure handler for a partition.

Methods

Create(IServiceProvider, String)
CreateAdapter()

Create queue adapter.

CreateCacheFactory(EventHubStreamCachePressureOptions)

Create a IEventHubQueueCacheFactory. It will create a EventHubQueueCacheFactory by default. User can override this function to return their own implementation of IEventHubQueueCacheFactory, and other customization of IEventHubQueueCacheFactory if they may.

CreateCacheFactory(EventHubStreamProviderSettings)

Create a IEventHubQueueCacheFactory. It will create a EventHubQueueCacheFactory by default. User can override this function to return their own implementation of IEventHubQueueCacheFactory, and other customization of IEventHubQueueCacheFactory if they may.

CreateQueueCache(QueueId)

Create a cache for a given queue id

CreateReceiver(QueueId)

Creates a quere receiver for the specificed queueId

GetDeliveryFailureHandler(QueueId)

Aquire delivery failure handler for a queue

GetPartitionIdsAsync()

Get partition Ids from eventhub

GetQueueAdapterCache()

Create queue message cache adapter

GetStreamQueueMapper()

Create queue mapper

Init()
Init(IProviderConfiguration, String, Logger, IServiceProvider)

Factory initialization. Provider config must contain the event hub settings type or the settings themselves. EventHubSettingsType is recommended for consumers that do not want to include secure information in the cluster configuration.

InitEventHubClient()
QueueMessageBatchAsync<T>(Guid, String, IEnumerable<T>, StreamSequenceToken, Dictionary<String,Object>)

Writes a set of events to the queue as a single batch associated with the provided streamId.

Extension Methods

QueueMessageAsync<T>(IQueueAdapter, StreamId, T, StreamSequenceToken, Dictionary<String,Object>)

Writes a set of events to the queue as a single batch associated with the provided streamId.

QueueMessageAsync<T>(IQueueAdapter, Guid, String, T, StreamSequenceToken, Dictionary<String,Object>)

Writes a set of events to the queue as a single batch associated with the provided streamId.

Applies to