EventHubQueueCacheFactory Constructeurs
Définition
Important
Certaines informations portent sur la préversion du produit qui est susceptible d’être en grande partie modifiée avant sa publication. Microsoft exclut toute garantie, expresse ou implicite, concernant les informations fournies ici.
Surcharges
EventHubQueueCacheFactory(EventHubStreamProviderSettings, SerializationManager, EventHubMonitorAggregationDimensions, Func<EventHubCacheMonitorDimensions, Logger,ICacheMonitor>, Func<EventHubBlockPoolMonitorDimensions, Logger,IBlockPoolMonitor>)
Constructeur pour 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)
Paramètres
- providerSettings
- EventHubStreamProviderSettings
- serializationManager
- SerializationManager
- sharedDimensions
- EventHubMonitorAggregationDimensions
dimensions partagées entre le moniteur de cache et le moniteur de pool de blocs
- cacheMonitorFactory
- Func<EventHubCacheMonitorDimensions,Logger,ICacheMonitor>
- blockPoolMonitorFactory
- Func<EventHubBlockPoolMonitorDimensions,Logger,IBlockPoolMonitor>
S’applique à
EventHubQueueCacheFactory(EventHubStreamCachePressureOptions, StreamCacheEvictionOptions, StreamStatisticOptions, SerializationManager, EventHubMonitorAggregationDimensions, Func<EventHubCacheMonitorDimensions, ILoggerFactory,ITelemetryProducer,ICacheMonitor>, Func<EventHubBlockPoolMonitorDimensions, ILoggerFactory,ITelemetryProducer,IBlockPoolMonitor>)
Constructeur pour 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)
Paramètres
- cacheOptions
- EventHubStreamCachePressureOptions
- evictionOptions
- StreamCacheEvictionOptions
- statisticOptions
- StreamStatisticOptions
- serializationManager
- SerializationManager
- sharedDimensions
- EventHubMonitorAggregationDimensions
dimensions partagées entre le moniteur de cache et le moniteur de pool de blocs
- cacheMonitorFactory
- Func<EventHubCacheMonitorDimensions,ILoggerFactory,ITelemetryProducer,ICacheMonitor>
- blockPoolMonitorFactory
- Func<EventHubBlockPoolMonitorDimensions,ILoggerFactory,ITelemetryProducer,IBlockPoolMonitor>
S’applique à
EventHubQueueCacheFactory(EventHubStreamCachePressureOptions, StreamCacheEvictionOptions, StreamStatisticOptions, IEventHubDataAdapter, SerializationManager, EventHubMonitorAggregationDimensions, Func<EventHubCacheMonitorDimensions, ILoggerFactory,ITelemetryProducer,ICacheMonitor>, Func<EventHubBlockPoolMonitorDimensions, ILoggerFactory,ITelemetryProducer,IBlockPoolMonitor>)
- Source:
- EventHubQueueCacheFactory.cs
Constructeur pour 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)
Paramètres
- cacheOptions
- EventHubStreamCachePressureOptions
- evictionOptions
- StreamCacheEvictionOptions
- statisticOptions
- StreamStatisticOptions
- dataAdater
- IEventHubDataAdapter
- serializationManager
- SerializationManager
- sharedDimensions
- EventHubMonitorAggregationDimensions
- cacheMonitorFactory
- Func<EventHubCacheMonitorDimensions,ILoggerFactory,ITelemetryProducer,ICacheMonitor>
- blockPoolMonitorFactory
- Func<EventHubBlockPoolMonitorDimensions,ILoggerFactory,ITelemetryProducer,IBlockPoolMonitor>