Modifier and Type | Method and Description |
---|---|
void |
CacheConfigurationMBean.injectDependencies(Cache<?,?> cache,
Configuration configuration) |
void |
SimpleCacheImpl.injectDependencies(ComponentRegistry componentRegistry,
Configuration configuration,
EmbeddedCacheManager cacheManager,
DataContainer dataContainer,
CacheNotifier cacheNotifier,
TimeService timeService,
InternalEntryFactory entryFactory) |
void |
CacheImpl.injectDependencies(EvictionManager evictionManager,
ExpirationManager expirationManager,
InvocationContextFactory invocationContextFactory,
InvocationContextContainer icc,
CommandsFactory commandsFactory,
InterceptorChain interceptorChain,
Configuration configuration,
CacheNotifier notifier,
ComponentRegistry componentRegistry,
TransactionManager transactionManager,
BatchContainer batchContainer,
RpcManager rpcManager,
DataContainer dataContainer,
StreamingMarshaller marshaller,
DistributionManager distributionManager,
EmbeddedCacheManager cacheManager,
ExecutorService asyncExecutor,
TransactionTable txTable,
RecoveryManager recoveryManager,
TransactionCoordinator txCoordinator,
LockManager lockManager,
AuthorizationManager authorizationManager,
GlobalConfiguration globalCfg,
PartitionHandlingManager partitionHandlingManager,
LocalTopologyManager localTopologyManager) |
void |
StatsCollectingCache.injectDependencies(StatsCollector statsCollector,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
Interpreter.initialize(EmbeddedCacheManager cacheManager,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
RemoteCommandsFactory.inject(EmbeddedCacheManager cacheManager,
GlobalComponentRegistry registry,
Map<Byte,ModuleCommandFactory> commandFactories) |
void |
CommandsFactoryImpl.setupDependencies(DataContainer container,
CacheNotifier<Object,Object> notifier,
Cache<Object,Object> cache,
InterceptorChain interceptorChain,
DistributionManager distributionManager,
InvocationContextFactory icf,
TransactionTable txTable,
Configuration configuration,
Map<Byte,ModuleCommandInitializer> moduleCommandInitializers,
RecoveryManager recoveryManager,
StateProvider stateProvider,
StateConsumer stateConsumer,
LockManager lockManager,
InternalEntryFactory entryFactory,
MapReduceManager mapReduceManager,
StateTransferManager stm,
BackupSender backupSender,
CancellationService cancellationService,
TimeService timeService,
XSiteStateProvider xSiteStateProvider,
XSiteStateConsumer xSiteStateConsumer,
XSiteStateTransferManager xSiteStateTransferManager,
EntryRetriever entryRetriever,
GroupManager groupManager,
PartitionHandlingManager partitionHandlingManager,
LocalStreamManager localStreamManager,
ClusterStreamManager clusterStreamManager,
ClusteringDependentLogic clusteringDependentLogic,
ExternalizerTable externalizerTable) |
Modifier and Type | Method and Description |
---|---|
void |
DefaultDataContainer.initialize(EvictionManager evictionManager,
PassivationManager passivator,
InternalEntryFactory entryFactory,
ActivationManager activator,
PersistenceManager clm,
TimeService timeService,
CacheNotifier cacheNotifier,
ExpirationManager<K,V> expirationManager) |
void |
EntryFactoryImpl.injectDependencies(DataContainer dataContainer,
Configuration configuration,
DistributionManager distributionManager,
TimeService timeService) |
void |
InternalEntryFactoryImpl.injectTimeService(TimeService timeService) |
void |
IncrementalVersionableEntryFactoryImpl.injectVersionGenerator(VersionGenerator versionGenerator) |
Modifier and Type | Method and Description |
---|---|
void |
NumericVersionGenerator.init(Cache<?,?> cache) |
void |
SimpleClusteredVersionGenerator.init(Cache<?,?> cache) |
Modifier and Type | Method and Description |
---|---|
void |
NonTransactionalInvocationContextFactory.init(Configuration config) |
void |
InvocationContextContainerImpl.init(GlobalConfiguration globalConfiguration) |
void |
TransactionalInvocationContextFactory.init(TransactionManager tm,
TransactionTable transactionTable,
Configuration config,
BatchContainer batchContainer) |
Modifier and Type | Method and Description |
---|---|
void |
MapReduceManagerImpl.init(EmbeddedCacheManager cacheManager,
PersistenceManager persistenceManager,
ExecutorService asyncTransportExecutor,
ClusteringDependentLogic cdl,
TimeService timeService,
Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
void |
KeyPartitionerFactory.inject(GroupManager groupManager) |
Modifier and Type | Method and Description |
---|---|
void |
GroupManagerImpl.injectDependencies(ClusteringDependentLogic clusteringDependentLogic) |
Modifier and Type | Method and Description |
---|---|
void |
L1ManagerImpl.init(Configuration configuration,
RpcManager rpcManager,
CommandsFactory commandsFactory,
ScheduledExecutorService scheduledExecutor,
TimeService timeService) |
void |
DistributionManagerImpl.init(RpcManager rpcManager,
StateTransferManager stateTransferManager) |
Modifier and Type | Method and Description |
---|---|
void |
EvictionManagerImpl.initialize(CacheNotifier<K,V> cacheNotifier,
Configuration cfg,
InterceptorChain chain) |
void |
PassivationManagerImpl.inject(PersistenceManager persistenceManager,
CacheNotifier notifier,
Configuration cfg,
DataContainer container,
TimeService timeService,
MarshalledEntryFactory marshalledEntryFactory,
DistributionManager distributionManager) |
void |
ActivationManagerImpl.inject(PersistenceManager clm,
Configuration cfg,
ClusteringDependentLogic cdl) |
Modifier and Type | Method and Description |
---|---|
void |
ExpirationManagerImpl.initialize(ScheduledExecutorService executor,
Cache<K,V> cache,
Configuration cfg,
DataContainer<K,V> dataContainer,
PersistenceManager persistenceManager,
CacheNotifier<K,V> cacheNotifier,
TimeService timeService) |
void |
ClusterExpirationManager.inject(AdvancedCache<K,V> cache,
ExecutorService asyncExecutor) |
Modifier and Type | Method and Description |
---|---|
void |
TestDelayFactory.inject(TestDelayFactory.Control control) |
void |
ComponentRegistry.setCacheManagerNotifier(CacheManagerNotifier cacheManagerNotifier) |
Modifier and Type | Method and Description |
---|---|
protected void |
CompositeKeyFilter.injectDependencies(ComponentRegistry cr) |
protected void |
KeyValueFilterAsKeyFilter.injectDependencies(ComponentRegistry cr) |
protected void |
CompositeKeyValueFilter.injectDependencies(ComponentRegistry cr) |
protected void |
KeyFilterAsKeyValueFilter.injectDependencies(ComponentRegistry cr) |
Modifier and Type | Method and Description |
---|---|
void |
GlobalStateManagerImpl.inject(GlobalConfiguration globalConfiguration,
TimeService timeService,
EmbeddedCacheManager cacheManager) |
Modifier and Type | Method and Description |
---|---|
void |
EntryWrappingInterceptor.init(EntryFactory entryFactory,
DataContainer<Object,Object> dataContainer,
ClusteringDependentLogic cdl,
CommandsFactory commandFactory,
StateConsumer stateConsumer,
StateTransferLock stateTransferLock,
XSiteStateConsumer xSiteStateConsumer,
GroupManager groupManager)
Deprecated.
|
protected void |
CacheWriterInterceptor.init(PersistenceManager pm,
InternalEntryFactory entryFactory,
TransactionManager transactionManager,
StreamingMarshaller marshaller)
Deprecated.
|
void |
InvocationContextInterceptor.init(TransactionManager tm,
ComponentRegistry componentRegistry,
TransactionTable txTable,
InvocationContextContainer invocationContextContainer)
Deprecated.
|
void |
TxInterceptor.init(TransactionTable txTable,
Configuration configuration,
RpcManager rpcManager,
RecoveryManager recoveryManager,
CommandsFactory commandsFactory,
Cache<K,V> cache,
PartitionHandlingManager partitionHandlingManager)
Deprecated.
|
void |
VersionedEntryWrappingInterceptor.initialize(VersionGenerator versionGenerator)
Deprecated.
|
void |
CallInterceptor.inject(CacheNotifier notifier)
Deprecated.
|
void |
DistCacheWriterInterceptor.inject(DistributionManager dm,
Transport transport,
ClusteringDependentLogic cdl)
Deprecated.
|
protected void |
MarshalledValueInterceptor.inject(StreamingMarshaller marshaller,
InternalEntryFactory entryFactory,
Cache<K,V> cache)
Deprecated.
|
void |
NotificationInterceptor.injectDependencies(CacheNotifier notifier)
Deprecated.
|
void |
GroupingInterceptor.injectDependencies(CacheNotifier<?,?> cacheNotifier,
GroupManager groupManager,
InternalEntryFactory factory,
Configuration configuration)
Deprecated.
|
void |
InvalidationInterceptor.injectDependencies(CommandsFactory commandsFactory)
Deprecated.
|
void |
ClusteringInterceptor.injectDependencies(CommandsFactory cf,
EntryFactory entryFactory,
LockManager lockManager,
DataContainer dataContainer,
StateTransferManager stateTransferManager)
Deprecated.
|
protected void |
CacheLoaderInterceptor.injectDependencies(PersistenceManager clm,
EntryFactory entryFactory,
CacheNotifier notifier,
TimeService timeService,
InternalEntryFactory iceFactory,
DataContainer<K,V> dataContainer,
GroupManager groupManager,
ExecutorService persistenceExecutor,
Cache<K,V> cache)
Deprecated.
|
protected void |
IsMarshallableInterceptor.injectMarshaller(StreamingMarshaller marshaller,
DistributionManager distManager)
Deprecated.
|
void |
CacheMgmtInterceptor.setDependencies(DataContainer dataContainer,
TimeService timeService)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
BaseStateTransferInterceptor.init(StateTransferLock stateTransferLock,
Configuration configuration,
StateTransferManager stateTransferManager,
GroupManager groupManager)
Deprecated.
|
void |
BaseRpcInterceptor.inject(RpcManager rpcManager,
StateConsumer stateConsumer)
Deprecated.
|
void |
CommandInterceptor.injectConfiguration(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
protected void |
BaseTypeConverterInterceptor.init(InternalEntryFactory entryFactory,
VersionGenerator versionGenerator,
Cache<K,V> cache)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
L1LastChanceInterceptor.init(L1Manager l1Manager,
ClusteringDependentLogic cdl,
Configuration configuration)
Deprecated.
|
void |
L1NonTxInterceptor.init(L1Manager l1Manager,
ClusteringDependentLogic cdl,
EntryFactory entryFactory,
DataContainer dataContainer,
Configuration config,
StateTransferLock stateTransferLock,
CommandsFactory commandsFactory)
Deprecated.
|
void |
DistributionBulkInterceptor.inject(Cache<K,V> cache)
Deprecated.
|
void |
TxDistributionInterceptor.inject(PartitionHandlingManager partitionHandlingManager)
Deprecated.
|
void |
BaseDistributionInterceptor.injectDependencies(DistributionManager distributionManager,
ClusteringDependentLogic cdl,
RemoteValueRetrievedListener rvrl,
GroupManager groupManager)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
PessimisticLockingInterceptor.init(CommandsFactory factory,
StateTransferManager stateTransferManager)
Deprecated.
|
void |
ClusteringDependentLogic.AbstractClusteringDependentLogic.init(DataContainer<Object,Object> dataContainer,
CacheNotifier<Object,Object> notifier,
Configuration configuration,
CommitManager commitManager,
PersistenceManager persistenceManager,
TimeService timeService,
FunctionalNotifier<Object,Object> functionalNotifier) |
void |
ClusteringDependentLogic.DistributionLogic.init(DistributionManager dm,
Configuration configuration,
RpcManager rpcManager,
StateTransferLock stateTransferLock) |
void |
ClusteringDependentLogic.LocalLogic.init(EmbeddedCacheManager cacheManager) |
void |
ClusteringDependentLogic.InvalidationLogic.init(RpcManager rpcManager,
StateTransferManager stateTransferManager) |
void |
ClusteringDependentLogic.ReplicationLogic.init(StateTransferLock stateTransferLock) |
void |
AbstractLockingInterceptor.setDependencies(LockManager lockManager,
DataContainer<Object,Object> dataContainer,
ClusteringDependentLogic cdl)
Deprecated.
|
void |
AbstractTxLockingInterceptor.setDependencies(RpcManager rpcManager,
PartitionHandlingManager partitionHandlingManager,
PendingLockManager pendingLockManager)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
TotalOrderInterceptor.inject(TransactionTable transactionTable,
TotalOrderManager totalOrderManager,
ClusteringDependentLogic clusteringDependentLogic,
BlockingTaskAwareExecutorService executorService)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
NonTransactionalBackupInterceptor.injectDependencies(CommandsFactory commandsFactory,
ClusteringDependentLogic clusteringDependentLogic) |
Modifier and Type | Method and Description |
---|---|
void |
EntryResponseCommand.init(EntryRetriever<K,?> entryRetrieverManager) |
void |
EntryRequestCommand.init(EntryRetriever<K,V> entryRetrieverManager) |
void |
DistributedEntryRetriever.initialize(DistributionManager distributionManager,
PersistenceManager persistenceManager,
CommandsFactory commandsFactory,
RpcManager rpcManager,
ExecutorService remoteExecutorService) |
void |
LocalEntryRetriever.inject(DataContainer<K,V> dataContainer,
PersistenceManager persistenceManager,
ExecutorService executorService,
TimeService timeService,
InternalEntryFactory entryFactory,
Cache<K,V> cache,
Configuration config,
ComponentRegistry componentRegistry) |
Modifier and Type | Method and Description |
---|---|
void |
CacheManagerJmxRegistration.init(GlobalComponentRegistry registry,
GlobalConfiguration configuration) |
void |
CacheJmxRegistration.initialize(Cache<?,?> cache,
GlobalConfiguration globalConfig) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicableCommandManagerFunction.inject(EmbeddedCacheManager manager) |
Modifier and Type | Method and Description |
---|---|
void |
MarshalledEntryFactoryImpl.init(StreamingMarshaller marshaller) |
void |
CacheMarshaller.inject(Cache cache,
Configuration cfg,
InvocationContextContainer icc,
ExternalizerTable extTable,
GlobalConfiguration globalCfg) |
void |
GlobalMarshaller.inject(ExternalizerTable extTable,
GlobalConfiguration globalCfg) |
void |
ExternalizerTable.inject(RemoteCommandsFactory cmdFactory,
GlobalComponentRegistry gcr,
StreamingMarshaller globalMarshaller) |
Modifier and Type | Method and Description |
---|---|
void |
ClusterEventManagerFactory.injectCache(Cache<?,?> cache) |
Modifier and Type | Method and Description |
---|---|
protected void |
CacheEventFilterConverterAsKeyValueFilterConverter.injectDependencies(ComponentRegistry cr) |
protected void |
KeyValueFilterAsCacheEventFilter.injectDependencies(ComponentRegistry cr) |
protected void |
CompositeCacheEventFilter.injectDependencies(ComponentRegistry cr) |
protected void |
ConverterAsCacheEventConverter.injectDependencies(ComponentRegistry cr) |
protected void |
KeyFilterAsCacheEventFilter.injectDependencies(ComponentRegistry cr) |
protected void |
CacheEventConverterAsConverter.injectDependencies(ComponentRegistry cr) |
protected void |
CacheEventFilterAsKeyValueFilter.injectDependencies(ComponentRegistry cr) |
Modifier and Type | Method and Description |
---|---|
void |
CacheManagerNotifierImpl.injectCacheManager(EmbeddedCacheManager cacheManager) |
Modifier and Type | Method and Description |
---|---|
void |
PartitionHandlingManagerImpl.init(DistributionManager distributionManager,
LocalTopologyManager localTopologyManager,
StateTransferManager stateTransferManager,
Cache cache,
CacheNotifier notifier,
CommandsFactory commandsFactory,
Configuration configuration,
RpcManager rpcManager,
LockManager lockManager) |
Modifier and Type | Method and Description |
---|---|
void |
PersistenceManagerImpl.inject(AdvancedCache<Object,Object> cache,
StreamingMarshaller marshaller,
Configuration configuration,
TransactionManager transactionManager,
TimeService timeService,
ExecutorService persistenceExecutor,
ByteBufferFactory byteBufferFactory,
MarshalledEntryFactory marshalledEntryFactory,
CacheStoreFactoryRegistry cacheStoreFactoryRegistry,
ExpirationManager expirationManager) |
Modifier and Type | Method and Description |
---|---|
void |
InternalCacheRegistryImpl.init(EmbeddedCacheManager cacheManager) |
void |
ClusterRegistryImpl.init(EmbeddedCacheManager cacheManager,
InternalCacheRegistry internalCacheRegistry)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationQueueImpl.injectDependencies(ScheduledExecutorService executor,
RpcManager rpcManager,
Configuration configuration,
CommandsFactory commandsFactory,
Cache cache)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
NonTotalOrderPerCacheInboundInvocationHandler.inject(LockManager lockManager,
ClusteringDependentLogic clusteringDependentLogic,
Configuration configuration) |
void |
NonTotalOrderTxPerCacheInboundInvocationHandler.inject(LockManager lockManager,
ClusteringDependentLogic clusteringDependentLogic,
Configuration configuration,
PendingLockManager pendingLockManager) |
void |
BasePerCacheInboundInvocationHandler.injectDependencies(BlockingTaskAwareExecutorService remoteCommandsExecutor,
ResponseGenerator responseGenerator,
CancellationService cancellationService,
StateTransferLock stateTransferLock,
StateTransferManager stateTransferManager) |
void |
GlobalInboundInvocationHandler.injectDependencies(ExecutorService remoteCommandsExecutor,
GlobalComponentRegistry globalComponentRegistry,
BackupReceiverRepository backupReceiverRepository) |
void |
TotalOrderTxPerCacheInboundInvocationHandler.injectTotalOrderManager(TotalOrderManager totalOrderManager) |
Modifier and Type | Method and Description |
---|---|
void |
RpcManagerImpl.injectDependencies(Transport t,
Configuration cfg,
ReplicationQueue replicationQueue,
CommandsFactory cf,
StateTransferManager stateTransferManager,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractTransport.setConfiguration(GlobalConfiguration globalConfiguration) |
Modifier and Type | Method and Description |
---|---|
void |
JGroupsTransport.initialize(StreamingMarshaller marshaller,
CacheManagerNotifier notifier,
GlobalComponentRegistry gcr,
TimeService timeService,
InboundInvocationHandler globalHandler,
ScheduledExecutorService timeoutExecutor)
Initializes the transport with global cache configuration and transport-specific properties.
|
Modifier and Type | Method and Description |
---|---|
void |
AuthorizationManagerImpl.init(Cache<?,?> cache,
GlobalConfiguration globalConfiguration,
Configuration configuration,
GlobalSecurityManager globalSecurityManager,
EmbeddedCacheManager cacheManager) |
void |
GlobalSecurityManagerImpl.init(EmbeddedCacheManager cacheManager,
GlobalConfiguration globalConfiguration,
InternalCacheRegistry internalCacheRegistry) |
Modifier and Type | Method and Description |
---|---|
void |
StateProviderImpl.init(Cache cache,
ExecutorService executorService,
Configuration configuration,
RpcManager rpcManager,
CommandsFactory commandsFactory,
ClusterCacheNotifier clusterCacheNotifier,
PersistenceManager persistenceManager,
DataContainer dataContainer,
TransactionTable transactionTable,
StateTransferLock stateTransferLock,
StateConsumer stateConsumer,
InternalEntryFactory entryFactory) |
void |
StateConsumerImpl.init(Cache cache,
ExecutorService stateTransferExecutor,
StateTransferManager stateTransferManager,
InterceptorChain interceptorChain,
InvocationContextFactory icf,
Configuration configuration,
RpcManager rpcManager,
TransactionManager transactionManager,
CommandsFactory commandsFactory,
PersistenceManager persistenceManager,
DataContainer<Object,Object> dataContainer,
TransactionTable transactionTable,
StateTransferLock stateTransferLock,
CacheNotifier cacheNotifier,
TotalOrderManager totalOrderManager,
BlockingTaskAwareExecutorService remoteCommandsExecutor,
CommitManager commitManager) |
void |
StateTransferManagerImpl.init(StateConsumer stateConsumer,
StateProvider stateProvider,
Cache cache,
CacheNotifier cacheNotifier,
Configuration configuration,
GlobalConfiguration globalConfiguration,
RpcManager rpcManager,
KeyPartitioner keyPartitioner,
LocalTopologyManager localTopologyManager,
PartitionHandlingManager partitionHandlingManager) |
void |
StateTransferInterceptor.init(StateTransferManager stateTransferManager)
Deprecated.
|
void |
CommitManager.inject(DataContainer dataContainer) |
Modifier and Type | Method and Description |
---|---|
void |
ClusterCacheStatsImpl.injectDependencies(Cache<?,?> cache,
TimeService ts,
Configuration configuration) |
void |
StatsCollector.injectDependencies(TimeService timeService,
DataContainer dataContainer,
Configuration configuration) |
void |
CacheContainerStatsImpl.setDependencies(TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
PartitionAwareClusterStreamManager.inject(Cache<?,?> cache) |
void |
LocalStreamManagerImpl.inject(Cache<K,V> cache,
ComponentRegistry registry,
StateTransferManager stm,
RpcManager rpc,
Configuration configuration,
CommandsFactory factory) |
void |
StreamResponseCommand.inject(ClusterStreamManager csm) |
void |
StreamRequestCommand.inject(LocalStreamManager lsm) |
void |
ClusterStreamManagerImpl.inject(RpcManager rpc,
CommandsFactory factory) |
Modifier and Type | Method and Description |
---|---|
void |
CacheTopologyControlCommand.init(LocalTopologyManager localTopologyManager,
ClusterTopologyManager clusterTopologyManager) |
void |
LocalTopologyManagerImpl.inject(Transport transport,
ExecutorService asyncTransportExecutor,
GlobalComponentRegistry gcr,
TimeService timeService,
GlobalStateManager globalStateManager) |
void |
ClusterTopologyManagerImpl.inject(Transport transport,
ExecutorService asyncTransportExecutor,
GlobalConfiguration globalConfiguration,
GlobalComponentRegistry gcr,
CacheManagerNotifier cacheManagerNotifier,
EmbeddedCacheManager cacheManager,
EventLogManager eventLogManager) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionCoordinator.init(CommandsFactory commandsFactory,
InvocationContextFactory icf,
InterceptorChain invoker,
TransactionTable txTable,
RecoveryManager recoveryManager,
Configuration configuration) |
void |
TransactionTable.initialize(RpcManager rpcManager,
Configuration configuration,
InvocationContextFactory icf,
CacheNotifier notifier,
TransactionFactory gtf,
TransactionCoordinator txCoordinator,
TransactionSynchronizationRegistry transactionSynchronizationRegistry,
CommandsFactory commandsFactory,
ClusteringDependentLogic clusteringDependentLogic,
Cache cache,
TimeService timeService,
CacheManagerNotifier cacheManagerNotifier,
PartitionHandlingManager partitionHandlingManager,
ScheduledExecutorService timeoutExecutor) |
Modifier and Type | Method and Description |
---|---|
void |
JBossStandaloneJTAManagerLookup.init(GlobalConfiguration globalCfg) |
void |
GenericTransactionManagerLookup.init(GlobalConfiguration globalCfg) |
Modifier and Type | Method and Description |
---|---|
void |
TotalOrderManager.inject(BlockingTaskAwareExecutorService totalOrderExecutor) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionFactory.init(Configuration configuration,
VersionGenerator clusterIdGenerator,
TimeService timeService) |
void |
XaTransactionTable.init(RecoveryManager recoveryManager,
Cache cache) |
Modifier and Type | Method and Description |
---|---|
void |
RecoveryAdminOperations.init(RecoveryManager recoveryManager) |
void |
RecoveryManagerImpl.init(RpcManager rpcManager,
CommandsFactory commandsFactory,
TransactionTable txTable,
TransactionCoordinator txCoordinator,
TransactionFactory txFactory) |
void |
RecoveryAwareTransactionTable.initialize(RecoveryManager recoveryManager) |
Modifier and Type | Method and Description |
---|---|
void |
RollingUpgradeManager.initialize(Cache<Object,Object> cache,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
DefaultLockManager.inject(LockContainer container,
Configuration configuration,
ScheduledExecutorService executorService) |
void |
PerKeyLockContainer.inject(TimeService timeService) |
void |
StripedLockContainer.inject(TimeService timeService) |
void |
DefaultPendingLockManager.inject(TransactionTable transactionTable,
TimeService timeService,
ScheduledExecutorService timeoutExecutor,
StateTransferManager stateTransferManager) |
Modifier and Type | Method and Description |
---|---|
void |
BackupSenderImpl.init(Cache cache,
Transport transport,
TransactionTable txTable,
GlobalConfiguration gc,
TimeService timeService,
CommandsFactory commandsFactory) |
void |
XSiteAdminOperations.init(RpcManager rpcManager,
BackupSender backupSender,
Cache cache,
XSiteStateTransferManager stateTransferManager) |
void |
GlobalXSiteAdminOperations.inject(EmbeddedCacheManager cacheManager) |
void |
BackupReceiverRepositoryImpl.setup(EmbeddedCacheManager cacheManager) |
Modifier and Type | Method and Description |
---|---|
void |
XSiteStateProviderImpl.inject(DataContainer dataContainer,
PersistenceManager persistenceManager,
RpcManager rpcManager,
ClusteringDependentLogic clusteringDependentLogic,
CommandsFactory commandsFactory,
ExecutorService executorService,
Configuration configuration,
XSiteStateTransferManager xSiteStateTransferManager,
StateTransferLock stateTransferLock) |
void |
XSiteStateTransferManagerImpl.inject(RpcManager rpcManager,
Configuration configuration,
CommandsFactory commandsFactory,
ResponseGenerator responseGenerator,
StateTransferManager stateTransferManager,
CacheNotifier cacheNotifier,
XSiteStateConsumer consumer,
XSiteStateProvider provider,
ExecutorService asyncExecutor) |
void |
XSiteStateConsumerImpl.inject(TransactionManager transactionManager,
InvocationContextFactory invocationContextFactory,
CommandsFactory commandsFactory,
InterceptorChain interceptorChain,
CommitManager commitManager) |
Copyright © 2017 JBoss, a division of Red Hat. All rights reserved.