Package | Description |
---|---|
org.infinispan.cache.impl | |
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.commands.remote |
Meta-commands that wrap other commands for remote execution.
|
org.infinispan.distexec |
Distribute Executor APIs
|
org.infinispan.distribution.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.distribution | |
org.infinispan.interceptors.locking | |
org.infinispan.interceptors.xsite | |
org.infinispan.iteration.impl |
Provides Infinispan-specific implementation details iterating over entries in the cache, specifically optimized for
distributed caches.
|
org.infinispan.partitionhandling.impl | |
org.infinispan.remoting |
Remote communication between cache instances.
|
org.infinispan.remoting.rpc |
Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances.
|
org.infinispan.statetransfer |
Transfer of state to new caches in a cluster.
|
org.infinispan.stream.impl | |
org.infinispan.transaction.impl | |
org.infinispan.transaction.synchronization | |
org.infinispan.transaction.xa |
XA transaction support.
|
org.infinispan.transaction.xa.recovery | |
org.infinispan.xsite | |
org.infinispan.xsite.statetransfer |
Modifier and Type | Field and Description |
---|---|
protected CommandsFactory |
CacheImpl.commandsFactory |
Modifier and Type | Method and Description |
---|---|
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 | Class and Description |
---|---|
class |
CommandsFactoryImpl |
Modifier and Type | Method and Description |
---|---|
void |
ClusteredGetAllCommand.init(InvocationContextFactory icf,
CommandsFactory commandsFactory,
InternalEntryFactory entryFactory,
InterceptorChain interceptorChain,
TransactionTable txTable,
Equivalence<? super K> keyEquivalence) |
void |
ClusteredGetCommand.initialize(InvocationContextFactory icf,
CommandsFactory commandsFactory,
InternalEntryFactory entryFactory,
InterceptorChain interceptorChain,
DistributionManager distributionManager,
TransactionTable txTable,
Equivalence keyEquivalence) |
Modifier and Type | Field and Description |
---|---|
protected CommandsFactory |
DefaultExecutorService.factory |
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 |
---|---|
CommandsFactory |
ComponentRegistry.getCommandsFactory()
Caching shortcut for #getLocalComponent(CommandsFactory.class);
|
Modifier and Type | Field and Description |
---|---|
protected CommandsFactory |
ClusteringInterceptor.cf
Deprecated.
|
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.
|
void |
TxInterceptor.init(TransactionTable txTable,
Configuration configuration,
RpcManager rpcManager,
RecoveryManager recoveryManager,
CommandsFactory commandsFactory,
Cache<K,V> cache,
PartitionHandlingManager partitionHandlingManager)
Deprecated.
|
void |
InvalidationInterceptor.injectDependencies(CommandsFactory commandsFactory)
Deprecated.
|
void |
ClusteringInterceptor.injectDependencies(CommandsFactory cf,
EntryFactory entryFactory,
LockManager lockManager,
DataContainer dataContainer,
StateTransferManager stateTransferManager)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected CommandsFactory |
L1NonTxInterceptor.commandsFactory
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
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 |
PessimisticLockingInterceptor.init(CommandsFactory factory,
StateTransferManager stateTransferManager)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
NonTransactionalBackupInterceptor.injectDependencies(CommandsFactory commandsFactory,
ClusteringDependentLogic clusteringDependentLogic) |
Modifier and Type | Method and Description |
---|---|
void |
DistributedEntryRetriever.initialize(DistributionManager distributionManager,
PersistenceManager persistenceManager,
CommandsFactory commandsFactory,
RpcManager rpcManager,
ExecutorService remoteExecutorService) |
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 |
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.
|
static LocalInvocation |
LocalInvocation.newInstance(ResponseGenerator responseGenerator,
CacheRpcCommand command,
CommandsFactory commandsFactory,
Address self) |
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 |
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) |
Constructor and Description |
---|
InboundTransferTask(Set<Integer> segments,
Address source,
int topologyId,
StateConsumerImpl stateConsumer,
RpcManager rpcManager,
CommandsFactory commandsFactory,
long timeout,
String cacheName) |
OutboundTransferTask(Address destination,
Set<Integer> segments,
int stateTransferChunkSize,
int topologyId,
ConsistentHash readCh,
StateProviderImpl stateProvider,
DataContainer dataContainer,
PersistenceManager persistenceManager,
RpcManager rpcManager,
CommandsFactory commandsFactory,
InternalEntryFactory ef,
long timeout,
String cacheName) |
Modifier and Type | Field and Description |
---|---|
protected CommandsFactory |
ClusterStreamManagerImpl.factory |
Modifier and Type | Method and Description |
---|---|
void |
LocalStreamManagerImpl.inject(Cache<K,V> cache,
ComponentRegistry registry,
StateTransferManager stm,
RpcManager rpc,
Configuration configuration,
CommandsFactory factory) |
void |
ClusterStreamManagerImpl.inject(RpcManager rpc,
CommandsFactory factory) |
Modifier and Type | Field and Description |
---|---|
protected CommandsFactory |
TransactionTable.commandsFactory |
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) |
Constructor and Description |
---|
SynchronizationAdapter(LocalTransaction localTransaction,
TransactionCoordinator txCoordinator,
CommandsFactory commandsFactory,
RpcManager rpcManager,
TransactionTable transactionTable,
ClusteringDependentLogic clusteringLogic,
Configuration configuration,
PartitionHandlingManager partitionHandlingManager) |
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 | Method and Description |
---|---|
void |
RecoveryManagerImpl.init(RpcManager rpcManager,
CommandsFactory commandsFactory,
TransactionTable txTable,
TransactionCoordinator txCoordinator,
TransactionFactory txFactory) |
Modifier and Type | Method and Description |
---|---|
void |
BackupSenderImpl.init(Cache cache,
Transport transport,
TransactionTable txTable,
GlobalConfiguration gc,
TimeService timeService,
CommandsFactory commandsFactory) |
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 © 2016 JBoss, a division of Red Hat. All rights reserved.