Package | Description |
---|---|
org.infinispan |
This is the core of Infinispan, a distributed, transactional, highly scalable data grid
platform.
|
org.infinispan.batch |
Support for batching calls using the
BatchingCache.startBatch() and BatchingCache.endBatch(boolean)
API. |
org.infinispan.cache.impl | |
org.infinispan.cdi |
This is the Infinispan CDI module.
|
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.commands.write |
Commands that alter the state of the cache.
|
org.infinispan.configuration | |
org.infinispan.configuration.cache |
Cache configuration |
org.infinispan.configuration.format | |
org.infinispan.container |
Data containers which store cache entries.
|
org.infinispan.context |
Contexts contain information of a specific invocation on the cache, such as its origins, scope
(transactional or non-transactional), as well as invocation-specific flags.
|
org.infinispan.distexec.mapreduce |
Map/Reduce APIs
|
org.infinispan.distribution.impl | |
org.infinispan.eviction.impl | |
org.infinispan.expiration.impl | |
org.infinispan.factories |
Factories are internal components used to create other components based on a cache's
configuration.
|
org.infinispan.interceptors |
Infinispan is designed around a set of interceptors around a data container.
|
org.infinispan.interceptors.base |
Base interceptors containing common, reusable behavior.
|
org.infinispan.interceptors.distribution | |
org.infinispan.interceptors.locking | |
org.infinispan.iteration.impl |
Provides Infinispan-specific implementation details iterating over entries in the cache, specifically optimized for
distributed caches.
|
org.infinispan.jcache.embedded | |
org.infinispan.lifecycle |
Component lifecycle.
|
org.infinispan.manager |
Cache manager package
|
org.infinispan.manager.impl | |
org.infinispan.marshall.core | |
org.infinispan.partitionhandling.impl | |
org.infinispan.persistence.manager | |
org.infinispan.registry |
The internal cache registry API
|
org.infinispan.registry.impl | |
org.infinispan.remoting |
Remote communication between cache instances.
|
org.infinispan.remoting.inboundhandler | |
org.infinispan.remoting.rpc |
Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances.
|
org.infinispan.security.actions | |
org.infinispan.security.impl | |
org.infinispan.statetransfer |
Transfer of state to new caches in a cluster.
|
org.infinispan.stats |
Cache statistics.
|
org.infinispan.stats.impl | |
org.infinispan.stream.impl | |
org.infinispan.transaction.impl | |
org.infinispan.transaction.lookup |
Interfaces and implementations of lookup classes to locate and/or instantiate JTA
TransactionManager s. |
org.infinispan.transaction.synchronization | |
org.infinispan.transaction.xa |
XA transaction support.
|
org.infinispan.util.concurrent.locks.impl | |
org.infinispan.xsite.statetransfer |
Modifier and Type | Method and Description |
---|---|
Configuration |
Cache.getCacheConfiguration() |
Modifier and Type | Method and Description |
---|---|
protected static void |
AutoBatchSupport.assertBatchingSupported(Configuration c) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
CacheImpl.config |
Modifier and Type | Method and Description |
---|---|
Configuration |
CacheImpl.getCacheConfiguration() |
Configuration |
AbstractDelegatingCache.getCacheConfiguration() |
Configuration |
SimpleCacheImpl.getCacheConfiguration() |
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) |
Modifier and Type | Method and Description |
---|---|
Configuration |
DefaultEmbeddedCacheConfigurationProducer.getDefaultEmbeddedCacheConfiguration()
Produces the default embedded cache configuration.
|
Modifier and Type | Method and Description |
---|---|
EmbeddedCacheManager |
DefaultEmbeddedCacheManagerProducer.getDefaultEmbeddedCacheManager(Configuration defaultConfiguration)
Produces the default embedded cache manager.
|
Modifier and Type | Method and Description |
---|---|
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) |
protected void |
CreateCacheCommand.waitForCacheToStabilize(Cache<Object,Object> cache,
Configuration cacheConfig) |
Modifier and Type | Method and Description |
---|---|
void |
ReplaceCommand.init(CacheNotifier notifier,
Configuration cfg) |
void |
PutKeyValueCommand.init(CacheNotifier notifier,
Configuration cfg) |
void |
RemoveCommand.init(CacheNotifier notifier,
Configuration configuration) |
void |
RemoveExpiredCommand.init(CacheNotifier notifier,
Configuration configuration,
TimeService timeService) |
void |
InvalidateL1Command.init(Configuration config,
DistributionManager dm,
CacheNotifier n,
DataContainer dc) |
Modifier and Type | Method and Description |
---|---|
Configuration |
ConfigurationManager.getConfiguration(String cacheName) |
Configuration |
ConfigurationManager.getConfigurationOrDefault(String cacheName) |
Configuration |
ConfigurationManager.getDefaultConfiguration() |
Configuration |
ConfigurationManager.putConfiguration(String cacheName,
ConfigurationBuilder builder) |
Constructor and Description |
---|
ConfigurationManager(GlobalConfiguration globalConfiguration,
Configuration defaultConfiguration) |
Modifier and Type | Method and Description |
---|---|
Configuration |
ConfigurationBuilder.build() |
Configuration |
ConfigurationChildBuilder.build() |
Configuration |
ConfigurationBuilder.build(boolean validate) |
Configuration |
ConfigurationBuilder.build(GlobalConfiguration globalConfiguration) |
Modifier and Type | Method and Description |
---|---|
static boolean |
Configurations.hasSharedCacheLoaderOrWriter(Configuration configuration) |
static boolean |
Configurations.isOnePhaseCommit(Configuration cfg) |
static boolean |
Configurations.isOnePhaseTotalOrderCommit(Configuration cfg) |
static boolean |
Configurations.isSecondPhaseAsync(Configuration cfg) |
static boolean |
Configurations.isVersioningEnabled(Configuration cfg) |
static boolean |
Configurations.noDataLossOnJoiner(Configuration configuration) |
ConfigurationBuilder |
ConfigurationBuilder.read(Configuration template) |
Modifier and Type | Method and Description |
---|---|
Properties |
PropertyFormatter.format(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
void |
EntryFactoryImpl.injectDependencies(DataContainer dataContainer,
Configuration configuration,
DistributionManager distributionManager,
TimeService timeService) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
AbstractInvocationContextFactory.config |
Modifier and Type | Method and Description |
---|---|
void |
NonTransactionalInvocationContextFactory.init(Configuration config) |
void |
AbstractInvocationContextFactory.init(Configuration config) |
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 |
L1ManagerImpl.init(Configuration configuration,
RpcManager rpcManager,
CommandsFactory commandsFactory,
ScheduledExecutorService scheduledExecutor,
TimeService timeService) |
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 | Field and Description |
---|---|
protected Configuration |
ExpirationManagerImpl.configuration |
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) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
AbstractNamedCacheComponentFactory.configuration |
Modifier and Type | Method and Description |
---|---|
protected Configuration |
AbstractComponentRegistry.getConfiguration()
Retrieves the configuration component.
|
Modifier and Type | Method and Description |
---|---|
protected AdvancedCache<K,V> |
InternalCacheFactory.createAndWire(Configuration configuration,
GlobalComponentRegistry globalComponentRegistry,
String cacheName) |
Cache<K,V> |
InternalCacheFactory.createCache(Configuration configuration,
GlobalComponentRegistry globalComponentRegistry,
String cacheName)
This implementation clones the configuration passed in before using it.
|
static InterceptorChainFactory |
InterceptorChainFactory.getInstance(ComponentRegistry componentRegistry,
Configuration configuration) |
Constructor and Description |
---|
BootstrapFactory(AdvancedCache<?,?> advancedCache,
Configuration configuration,
ComponentRegistry componentRegistry) |
ComponentRegistry(String cacheName,
Configuration configuration,
AdvancedCache<?,?> cache,
GlobalComponentRegistry globalComponents,
ClassLoader defaultClassLoader)
Creates an instance of the component registry.
|
Modifier and Type | Method and Description |
---|---|
void |
TxInterceptor.init(TransactionTable txTable,
Configuration configuration,
RpcManager rpcManager,
RecoveryManager recoveryManager,
CommandsFactory commandsFactory,
Cache<K,V> cache,
PartitionHandlingManager partitionHandlingManager)
Deprecated.
|
void |
GroupingInterceptor.injectDependencies(CacheNotifier<?,?> cacheNotifier,
GroupManager groupManager,
InternalEntryFactory factory,
Configuration configuration)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected Configuration |
CommandInterceptor.cacheConfiguration |
Modifier and Type | Method and Description |
---|---|
void |
BaseStateTransferInterceptor.init(StateTransferLock stateTransferLock,
Configuration configuration,
StateTransferManager stateTransferManager,
GroupManager groupManager)
Deprecated.
|
void |
CommandInterceptor.injectConfiguration(Configuration configuration) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
L1NonTxInterceptor.config
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.
|
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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 |
---|---|
Configuration |
ConfigurationAdapter.build() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractModuleLifecycle.cacheStarting(ComponentRegistry cr,
Configuration configuration,
String cacheName) |
void |
ModuleLifecycle.cacheStarting(ComponentRegistry cr,
Configuration configuration,
String cacheName) |
Modifier and Type | Method and Description |
---|---|
Configuration |
DefaultCacheManager.defineConfiguration(String cacheName,
Configuration configuration) |
Configuration |
EmbeddedCacheManager.defineConfiguration(String cacheName,
Configuration configurationOverride)
Defines a named cache's configuration using the following algorithm:
Unlike previous versions of Infinispan, this method does not build on an existing configuration (default or named).
|
Configuration |
DefaultCacheManager.defineConfiguration(String cacheName,
String templateName,
Configuration configurationOverride) |
Configuration |
EmbeddedCacheManager.defineConfiguration(String cacheName,
String templateCacheName,
Configuration configurationOverride)
Defines a named cache's configuration using the following algorithm:
Regardless of whether the cache name has been defined or not, this method creates a clone of the configuration of
the cache whose name matches the given template cache name, then applies a clone of the configuration overrides
passed in and finally returns this configuration instance.
|
Configuration |
DefaultCacheManager.getCacheConfiguration(String name) |
Configuration |
EmbeddedCacheManager.getCacheConfiguration(String name)
Returns the configuration for the given cache.
|
Configuration |
DefaultCacheManager.getDefaultCacheConfiguration() |
Configuration |
EmbeddedCacheManager.getDefaultCacheConfiguration()
Returns default configuration for this CacheManager
|
Modifier and Type | Method and Description |
---|---|
Configuration |
DefaultCacheManager.defineConfiguration(String cacheName,
Configuration configuration) |
Configuration |
EmbeddedCacheManager.defineConfiguration(String cacheName,
Configuration configurationOverride)
Defines a named cache's configuration using the following algorithm:
Unlike previous versions of Infinispan, this method does not build on an existing configuration (default or named).
|
Configuration |
DefaultCacheManager.defineConfiguration(String cacheName,
String templateName,
Configuration configurationOverride) |
Configuration |
EmbeddedCacheManager.defineConfiguration(String cacheName,
String templateCacheName,
Configuration configurationOverride)
Defines a named cache's configuration using the following algorithm:
Regardless of whether the cache name has been defined or not, this method creates a clone of the configuration of
the cache whose name matches the given template cache name, then applies a clone of the configuration overrides
passed in and finally returns this configuration instance.
|
Constructor and Description |
---|
DefaultCacheManager(Configuration defaultConfiguration)
Constructs and starts a new instance of the CacheManager, using the default configuration passed in.
|
DefaultCacheManager(Configuration defaultConfiguration,
boolean start)
Constructs a new instance of the CacheManager, using the default configuration passed in.
|
DefaultCacheManager(GlobalConfiguration globalConfiguration,
Configuration defaultConfiguration)
Constructs and starts a new instance of the CacheManager, using the global and default configurations passed in.
|
DefaultCacheManager(GlobalConfiguration globalConfiguration,
Configuration defaultConfiguration,
boolean start)
Constructs a new instance of the CacheManager, using the global and default configurations passed in.
|
Modifier and Type | Method and Description |
---|---|
Configuration |
AbstractDelegatingEmbeddedCacheManager.defineConfiguration(String cacheName,
Configuration configuration) |
Configuration |
AbstractDelegatingEmbeddedCacheManager.defineConfiguration(String cacheName,
String templateCacheName,
Configuration configurationOverride) |
Configuration |
AbstractDelegatingEmbeddedCacheManager.getCacheConfiguration(String name) |
Configuration |
AbstractDelegatingEmbeddedCacheManager.getDefaultCacheConfiguration() |
Modifier and Type | Method and Description |
---|---|
Configuration |
AbstractDelegatingEmbeddedCacheManager.defineConfiguration(String cacheName,
Configuration configuration) |
Configuration |
AbstractDelegatingEmbeddedCacheManager.defineConfiguration(String cacheName,
String templateCacheName,
Configuration configurationOverride) |
Modifier and Type | Method and Description |
---|---|
void |
CacheMarshaller.inject(Cache cache,
Configuration cfg,
InvocationContextContainer icc,
ExternalizerTable extTable,
GlobalConfiguration globalCfg) |
void |
VersionAwareMarshaller.inject(Cache cache,
Configuration cfg,
InvocationContextContainer icc,
ExternalizerTable extTable,
GlobalConfiguration globalCfg) |
Constructor and Description |
---|
JBossMarshaller(ExternalizerTable externalizerTable,
Configuration cfg,
InvocationContextContainer icc,
GlobalConfiguration globalCfg) |
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 |
InternalCacheRegistry.registerInternalCache(String name,
Configuration configuration)
Registers an internal cache.
|
void |
InternalCacheRegistry.registerInternalCache(String name,
Configuration configuration,
EnumSet<InternalCacheRegistry.Flag> flags)
Registers an internal cache with the specified flags.
|
Modifier and Type | Method and Description |
---|---|
void |
InternalCacheRegistryImpl.registerInternalCache(String name,
Configuration configuration) |
void |
InternalCacheRegistryImpl.registerInternalCache(String name,
Configuration configuration,
EnumSet<InternalCacheRegistry.Flag> flags) |
Modifier and Type | Method and Description |
---|---|
protected Configuration |
ReplicationQueueImpl.getConfiguration()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationQueueImpl.injectDependencies(ScheduledExecutorService executor,
RpcManager rpcManager,
Configuration configuration,
CommandsFactory commandsFactory,
Cache cache)
Deprecated.
|
void |
ReplicationQueueImpl.injectDependencies(ScheduledExecutorService executor,
RpcManager rpcManager,
Configuration configuration,
CommandsFactory commandsFactory,
String cacheName)
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) |
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 |
---|---|
Configuration |
GetCacheConfigurationAction.run() |
Constructor and Description |
---|
DefineConfigurationAction(EmbeddedCacheManager cacheManager,
String cacheName,
Configuration configurationOverride) |
Modifier and Type | Method and Description |
---|---|
Configuration |
SecureCacheImpl.getCacheConfiguration() |
Modifier and Type | Method and Description |
---|---|
void |
AuthorizationManagerImpl.init(Cache<?,?> cache,
GlobalConfiguration globalConfiguration,
Configuration configuration,
GlobalSecurityManager globalSecurityManager,
EmbeddedCacheManager cacheManager) |
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) |
Constructor and Description |
---|
CacheStatisticManager(Configuration configuration,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
ClusterCacheStatsImpl.injectDependencies(Cache<?,?> cache,
TimeService ts,
Configuration configuration) |
void |
StatsCollector.injectDependencies(TimeService timeService,
DataContainer dataContainer,
Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
void |
LocalStreamManagerImpl.inject(Cache<K,V> cache,
ComponentRegistry registry,
StateTransferManager stm,
RpcManager rpc,
Configuration configuration,
CommandsFactory factory) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
TransactionTable.configuration |
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) |
Constructor and Description |
---|
AbstractEnlistmentAdapter(CacheTransaction cacheTransaction,
CommandsFactory commandsFactory,
RpcManager rpcManager,
TransactionTable txTable,
ClusteringDependentLogic clusteringLogic,
Configuration configuration,
TransactionCoordinator txCoordinator,
PartitionHandlingManager partitionHandlingManager) |
AbstractEnlistmentAdapter(CommandsFactory commandsFactory,
RpcManager rpcManager,
TransactionTable txTable,
ClusteringDependentLogic clusteringLogic,
Configuration configuration,
TransactionCoordinator txCoordinator,
PartitionHandlingManager partitionHandlingManager) |
Modifier and Type | Method and Description |
---|---|
void |
JBossStandaloneJTAManagerLookup.init(Configuration configuration)
Deprecated.
Use
JBossStandaloneJTAManagerLookup.init(org.infinispan.configuration.global.GlobalConfiguration)
instead since Configuration has no
access to classloader any more. |
Constructor and Description |
---|
SynchronizationAdapter(LocalTransaction localTransaction,
TransactionCoordinator txCoordinator,
CommandsFactory commandsFactory,
RpcManager rpcManager,
TransactionTable transactionTable,
ClusteringDependentLogic clusteringLogic,
Configuration configuration,
PartitionHandlingManager partitionHandlingManager) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionFactory.init(Configuration configuration,
VersionGenerator clusterIdGenerator,
TimeService timeService) |
Constructor and Description |
---|
TransactionXaAdapter(LocalXaTransaction localTransaction,
TransactionTable txTable,
RecoveryManager rm,
TransactionCoordinator txCoordinator,
CommandsFactory commandsFactory,
RpcManager rpcManager,
ClusteringDependentLogic clusteringDependentLogic,
Configuration configuration,
String cacheName,
PartitionHandlingManager partitionHandlingManager) |
TransactionXaAdapter(TransactionTable txTable,
RecoveryManager rm,
TransactionCoordinator txCoordinator,
CommandsFactory commandsFactory,
RpcManager rpcManager,
ClusteringDependentLogic clusteringDependentLogic,
Configuration configuration,
String cacheName,
PartitionHandlingManager partitionHandlingManager) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
DefaultLockManager.configuration |
Modifier and Type | Method and Description |
---|---|
void |
DefaultLockManager.inject(LockContainer container,
Configuration configuration,
ScheduledExecutorService executorService) |
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) |
Copyright © 2024 JBoss, a division of Red Hat. All rights reserved.