Edit

Share via


EventHubQueueCacheFactory Constructors

Definition

Overloads

EventHubQueueCacheFactory(EventHubStreamProviderSettings, SerializationManager, EventHubMonitorAggregationDimensions, Func<EventHubCacheMonitorDimensions, Logger,ICacheMonitor>, Func<EventHubBlockPoolMonitorDimensions, Logger,IBlockPoolMonitor>)

Constructor for EventHubQueueCacheFactory

EventHubQueueCacheFactory(EventHubStreamCachePressureOptions, StreamCacheEvictionOptions, StreamStatisticOptions, SerializationManager, EventHubMonitorAggregationDimensions, Func<EventHubCacheMonitorDimensions, ILoggerFactory,ITelemetryProducer,ICacheMonitor>, Func<EventHubBlockPoolMonitorDimensions, ILoggerFactory,ITelemetryProducer,IBlockPoolMonitor>)

Constructor for EventHubQueueCacheFactory

EventHubQueueCacheFactory(EventHubStreamCachePressureOptions, StreamCacheEvictionOptions, StreamStatisticOptions, IEventHubDataAdapter, SerializationManager, EventHubMonitorAggregationDimensions, Func<EventHubCacheMonitorDimensions, ILoggerFactory,ITelemetryProducer,ICacheMonitor>, Func<EventHubBlockPoolMonitorDimensions, ILoggerFactory,ITelemetryProducer,IBlockPoolMonitor>)

Constructor for EventHubQueueCacheFactory

EventHubQueueCacheFactory(EventHubStreamProviderSettings, SerializationManager, EventHubMonitorAggregationDimensions, Func<EventHubCacheMonitorDimensions, Logger,ICacheMonitor>, Func<EventHubBlockPoolMonitorDimensions, Logger,IBlockPoolMonitor>)

Constructor for EventHubQueueCacheFactory

public EventHubQueueCacheFactory (Orleans.ServiceBus.Providers.EventHubStreamProviderSettings providerSettings, Orleans.Serialization.SerializationManager serializationManager, Orleans.ServiceBus.Providers.EventHubMonitorAggregationDimensions sharedDimensions, Func<Orleans.ServiceBus.Providers.EventHubCacheMonitorDimensions,Orleans.Runtime.Logger,Orleans.Providers.Streams.Common.ICacheMonitor> cacheMonitorFactory = default, Func<Orleans.ServiceBus.Providers.EventHubBlockPoolMonitorDimensions,Orleans.Runtime.Logger,Orleans.Providers.Streams.Common.IBlockPoolMonitor> blockPoolMonitorFactory = default);
new Orleans.ServiceBus.Providers.EventHubQueueCacheFactory : Orleans.ServiceBus.Providers.EventHubStreamProviderSettings * Orleans.Serialization.SerializationManager * Orleans.ServiceBus.Providers.EventHubMonitorAggregationDimensions * Func<Orleans.ServiceBus.Providers.EventHubCacheMonitorDimensions, Orleans.Runtime.Logger, Orleans.Providers.Streams.Common.ICacheMonitor> * Func<Orleans.ServiceBus.Providers.EventHubBlockPoolMonitorDimensions, Orleans.Runtime.Logger, Orleans.Providers.Streams.Common.IBlockPoolMonitor> -> Orleans.ServiceBus.Providers.EventHubQueueCacheFactory
Public Sub New (providerSettings As EventHubStreamProviderSettings, serializationManager As SerializationManager, sharedDimensions As EventHubMonitorAggregationDimensions, Optional cacheMonitorFactory As Func(Of EventHubCacheMonitorDimensions, Logger, ICacheMonitor) = Nothing, Optional blockPoolMonitorFactory As Func(Of EventHubBlockPoolMonitorDimensions, Logger, IBlockPoolMonitor) = Nothing)

Parameters

serializationManager
SerializationManager
sharedDimensions
EventHubMonitorAggregationDimensions

shared dimensions between cache monitor and block pool monitor

Applies to

EventHubQueueCacheFactory(EventHubStreamCachePressureOptions, StreamCacheEvictionOptions, StreamStatisticOptions, SerializationManager, EventHubMonitorAggregationDimensions, Func<EventHubCacheMonitorDimensions, ILoggerFactory,ITelemetryProducer,ICacheMonitor>, Func<EventHubBlockPoolMonitorDimensions, ILoggerFactory,ITelemetryProducer,IBlockPoolMonitor>)

Constructor for EventHubQueueCacheFactory

public EventHubQueueCacheFactory (Orleans.Configuration.EventHubStreamCachePressureOptions cacheOptions, Orleans.Configuration.StreamCacheEvictionOptions evictionOptions, Orleans.Configuration.StreamStatisticOptions statisticOptions, Orleans.Serialization.SerializationManager serializationManager, Orleans.ServiceBus.Providers.EventHubMonitorAggregationDimensions sharedDimensions, Func<Orleans.ServiceBus.Providers.EventHubCacheMonitorDimensions,Microsoft.Extensions.Logging.ILoggerFactory,Orleans.Runtime.ITelemetryProducer,Orleans.Providers.Streams.Common.ICacheMonitor> cacheMonitorFactory = default, Func<Orleans.ServiceBus.Providers.EventHubBlockPoolMonitorDimensions,Microsoft.Extensions.Logging.ILoggerFactory,Orleans.Runtime.ITelemetryProducer,Orleans.Providers.Streams.Common.IBlockPoolMonitor> blockPoolMonitorFactory = default);
new Orleans.ServiceBus.Providers.EventHubQueueCacheFactory : Orleans.Configuration.EventHubStreamCachePressureOptions * Orleans.Configuration.StreamCacheEvictionOptions * Orleans.Configuration.StreamStatisticOptions * Orleans.Serialization.SerializationManager * Orleans.ServiceBus.Providers.EventHubMonitorAggregationDimensions * Func<Orleans.ServiceBus.Providers.EventHubCacheMonitorDimensions, Microsoft.Extensions.Logging.ILoggerFactory, Orleans.Runtime.ITelemetryProducer, Orleans.Providers.Streams.Common.ICacheMonitor> * Func<Orleans.ServiceBus.Providers.EventHubBlockPoolMonitorDimensions, Microsoft.Extensions.Logging.ILoggerFactory, Orleans.Runtime.ITelemetryProducer, Orleans.Providers.Streams.Common.IBlockPoolMonitor> -> Orleans.ServiceBus.Providers.EventHubQueueCacheFactory
Public Sub New (cacheOptions As EventHubStreamCachePressureOptions, evictionOptions As StreamCacheEvictionOptions, statisticOptions As StreamStatisticOptions, serializationManager As SerializationManager, sharedDimensions As EventHubMonitorAggregationDimensions, Optional cacheMonitorFactory As Func(Of EventHubCacheMonitorDimensions, ILoggerFactory, ITelemetryProducer, ICacheMonitor) = Nothing, Optional blockPoolMonitorFactory As Func(Of EventHubBlockPoolMonitorDimensions, ILoggerFactory, ITelemetryProducer, IBlockPoolMonitor) = Nothing)

Parameters

evictionOptions
StreamCacheEvictionOptions
statisticOptions
StreamStatisticOptions
serializationManager
SerializationManager
sharedDimensions
EventHubMonitorAggregationDimensions

shared dimensions between cache monitor and block pool monitor

Applies to

EventHubQueueCacheFactory(EventHubStreamCachePressureOptions, StreamCacheEvictionOptions, StreamStatisticOptions, IEventHubDataAdapter, SerializationManager, EventHubMonitorAggregationDimensions, Func<EventHubCacheMonitorDimensions, ILoggerFactory,ITelemetryProducer,ICacheMonitor>, Func<EventHubBlockPoolMonitorDimensions, ILoggerFactory,ITelemetryProducer,IBlockPoolMonitor>)

Source:
EventHubQueueCacheFactory.cs

Constructor for EventHubQueueCacheFactory

public EventHubQueueCacheFactory (Orleans.Configuration.EventHubStreamCachePressureOptions cacheOptions, Orleans.Configuration.StreamCacheEvictionOptions evictionOptions, Orleans.Configuration.StreamStatisticOptions statisticOptions, Orleans.ServiceBus.Providers.IEventHubDataAdapter dataAdater, Orleans.Serialization.SerializationManager serializationManager, Orleans.ServiceBus.Providers.EventHubMonitorAggregationDimensions sharedDimensions, Func<Orleans.ServiceBus.Providers.EventHubCacheMonitorDimensions,Microsoft.Extensions.Logging.ILoggerFactory,Orleans.Runtime.ITelemetryProducer,Orleans.Providers.Streams.Common.ICacheMonitor> cacheMonitorFactory = default, Func<Orleans.ServiceBus.Providers.EventHubBlockPoolMonitorDimensions,Microsoft.Extensions.Logging.ILoggerFactory,Orleans.Runtime.ITelemetryProducer,Orleans.Providers.Streams.Common.IBlockPoolMonitor> blockPoolMonitorFactory = default);
new Orleans.ServiceBus.Providers.EventHubQueueCacheFactory : Orleans.Configuration.EventHubStreamCachePressureOptions * Orleans.Configuration.StreamCacheEvictionOptions * Orleans.Configuration.StreamStatisticOptions * Orleans.ServiceBus.Providers.IEventHubDataAdapter * Orleans.Serialization.SerializationManager * Orleans.ServiceBus.Providers.EventHubMonitorAggregationDimensions * Func<Orleans.ServiceBus.Providers.EventHubCacheMonitorDimensions, Microsoft.Extensions.Logging.ILoggerFactory, Orleans.Runtime.ITelemetryProducer, Orleans.Providers.Streams.Common.ICacheMonitor> * Func<Orleans.ServiceBus.Providers.EventHubBlockPoolMonitorDimensions, Microsoft.Extensions.Logging.ILoggerFactory, Orleans.Runtime.ITelemetryProducer, Orleans.Providers.Streams.Common.IBlockPoolMonitor> -> Orleans.ServiceBus.Providers.EventHubQueueCacheFactory
Public Sub New (cacheOptions As EventHubStreamCachePressureOptions, evictionOptions As StreamCacheEvictionOptions, statisticOptions As StreamStatisticOptions, dataAdater As IEventHubDataAdapter, serializationManager As SerializationManager, sharedDimensions As EventHubMonitorAggregationDimensions, Optional cacheMonitorFactory As Func(Of EventHubCacheMonitorDimensions, ILoggerFactory, ITelemetryProducer, ICacheMonitor) = Nothing, Optional blockPoolMonitorFactory As Func(Of EventHubBlockPoolMonitorDimensions, ILoggerFactory, ITelemetryProducer, IBlockPoolMonitor) = Nothing)

Parameters

evictionOptions
StreamCacheEvictionOptions
statisticOptions
StreamStatisticOptions
serializationManager
SerializationManager

Applies to