Package | Description |
---|---|
org.infinispan |
This is the core of Infinispan, a distributed, transactional, highly scalable data grid
platform.
|
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.container |
Data containers which store cache entries.
|
org.infinispan.container.versioning | |
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 | |
org.infinispan.distribution |
Classes relating to the distributed cache mode.
|
org.infinispan.eviction |
Classes related to eviction.
|
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.compat | |
org.infinispan.interceptors.distribution | |
org.infinispan.interceptors.locking | |
org.infinispan.interceptors.totalorder | |
org.infinispan.jmx |
Helpers that allow easy exposure of attributes and operations via JMX.
|
org.infinispan.marshall.core | |
org.infinispan.notifications.cachemanagerlistener |
CacheManager -specific notifications and eventing. |
org.infinispan.persistence.manager | |
org.infinispan.query.backend | |
org.infinispan.registry | |
org.infinispan.remoting |
Remote communication between cache instances.
|
org.infinispan.remoting.responses |
Abstractions of the different response types allowed during RPC.
|
org.infinispan.remoting.rpc |
Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances.
|
org.infinispan.remoting.transport |
Transports handle the low-level networking, used by the remoting components.
|
org.infinispan.remoting.transport.jgroups |
A transport implementation based on JGroups.
|
org.infinispan.statetransfer |
Transfer of state to new caches in a cluster.
|
org.infinispan.topology | |
org.infinispan.transaction |
JTA transaction support.
|
org.infinispan.transaction.lookup |
Interfaces and implementations of lookup classes to locate and/or instantiate JTA
TransactionManager s. |
org.infinispan.transaction.totalorder | |
org.infinispan.transaction.xa |
XA transaction support.
|
org.infinispan.transaction.xa.recovery | |
org.infinispan.upgrade | |
org.infinispan.util.concurrent.locks |
Lock and synchronization related classes, tools and utilities.
|
org.infinispan.xsite |
Modifier and Type | Method and Description |
---|---|
void |
CacheImpl.injectDependencies(EvictionManager evictionManager,
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,
GlobalConfiguration globalCfg) |
Modifier and Type | Method and Description |
---|---|
void |
RemoteCommandsFactory.inject(EmbeddedCacheManager cacheManager,
GlobalComponentRegistry registry,
Map<Byte,ModuleCommandFactory> commandFactories) |
void |
CommandsFactoryImpl.setupDependencies(DataContainer container,
CacheNotifier 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) |
Modifier and Type | Method and Description |
---|---|
void |
DefaultDataContainer.initialize(EvictionManager evictionManager,
PassivationManager passivator,
InternalEntryFactory entryFactory,
ActivationManager activator,
PersistenceManager clm,
TimeService timeService) |
void |
EntryFactoryImpl.injectDependencies(DataContainer dataContainer,
Configuration configuration,
CacheNotifier notifier,
DistributionManager distributionManager) |
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(Configuration configuration,
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 |
L1ManagerImpl.init(Configuration configuration,
RpcManager rpcManager,
CommandsFactory commandsFactory,
ExecutorService asyncTransportExecutor,
ScheduledExecutorService scheduledExecutor,
TimeService timeService) |
void |
DistributionManagerImpl.init(RpcManager rpcManager,
StateTransferManager stateTransferManager) |
Modifier and Type | Method and Description |
---|---|
void |
EvictionManagerImpl.initialize(ScheduledExecutorService executor,
Cache cache,
Configuration cfg,
DataContainer dataContainer,
PersistenceManager persistenceManager,
CacheNotifier cacheNotifier,
TimeService timeService) |
void |
PassivationManagerImpl.inject(PersistenceManager persistenceManager,
CacheNotifier notifier,
Configuration cfg,
DataContainer container,
TimeService timeService,
MarshalledEntryFactory marshalledEntryFactory) |
void |
ActivationManagerImpl.inject(PersistenceManager clm,
Configuration cfg) |
Modifier and Type | Method and Description |
---|---|
void |
TestDelayFactory.inject(TestDelayFactory.Control control) |
void |
ComponentRegistry.setCacheManagerNotifier(CacheManagerNotifier cacheManagerNotifier) |
Modifier and Type | Method and Description |
---|---|
void |
EntryWrappingInterceptor.init(EntryFactory entryFactory,
DataContainer dataContainer,
ClusteringDependentLogic cdl,
CommandsFactory commandFactory,
StateConsumer stateConsumer,
StateTransferLock stateTransferLock) |
protected void |
CacheWriterInterceptor.init(PersistenceManager pm,
InternalEntryFactory entryFactory,
TransactionManager transactionManager,
StreamingMarshaller marshaller) |
void |
InvocationContextInterceptor.init(TransactionManager tm,
ComponentRegistry componentRegistry,
TransactionTable txTable,
InvocationContextContainer invocationContextContainer) |
void |
TxInterceptor.init(TransactionTable txTable,
Configuration c,
TransactionCoordinator txCoordinator,
RpcManager rpcManager,
RecoveryManager recoveryManager) |
void |
VersionedEntryWrappingInterceptor.initialize(VersionGenerator versionGenerator) |
void |
CallInterceptor.inject(CacheNotifier notifier) |
void |
ActivationInterceptor.inject(Configuration cfg,
ActivationManager activationManager,
ClusteringDependentLogic cdl,
DataContainer dataContainer) |
void |
DistCacheWriterInterceptor.inject(DistributionManager dm,
Transport transport,
ClusteringDependentLogic cdl) |
void |
NotificationInterceptor.injectDependencies(CacheNotifier notifier) |
void |
InvalidationInterceptor.injectDependencies(CommandsFactory commandsFactory) |
void |
ClusteringInterceptor.injectDependencies(CommandsFactory cf,
EntryFactory entryFactory,
LockManager lockManager,
DataContainer dataContainer,
StateTransferManager stateTransferManager) |
protected void |
CacheLoaderInterceptor.injectDependencies(PersistenceManager clm,
EntryFactory entryFactory,
CacheNotifier notifier,
TimeService timeService,
InternalEntryFactory iceFactory) |
protected void |
IsMarshallableInterceptor.injectMarshaller(StreamingMarshaller marshaller,
DistributionManager distManager) |
protected void |
MarshalledValueInterceptor.injectMarshaller(StreamingMarshaller marshaller,
InternalEntryFactory entryFactory) |
void |
CacheMgmtInterceptor.setDependencies(DataContainer dataContainer,
TimeService timeService) |
void |
PassivationInterceptor.setDependencies(PassivationManager passivator,
DataContainer dataContainer) |
Modifier and Type | Method and Description |
---|---|
void |
BaseRpcInterceptor.inject(RpcManager rpcManager,
StateConsumer stateConsumer) |
void |
CommandInterceptor.injectConfiguration(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
protected void |
BaseTypeConverterInterceptor.init(InternalEntryFactory entryFactory,
VersionGenerator versionGenerator,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
L1LastChanceInterceptor.init(L1Manager l1Manager,
ClusteringDependentLogic cdl,
Configuration configuration) |
void |
L1NonTxInterceptor.init(L1Manager l1Manager,
ClusteringDependentLogic cdl,
EntryFactory entryFactory,
DataContainer dataContainer,
Configuration config,
StateTransferLock stateTransferLock,
CommandsFactory commandsFactory) |
void |
BaseDistributionInterceptor.injectDependencies(DistributionManager distributionManager,
ClusteringDependentLogic cdl,
RemoteValueRetrievedListener rvrl) |
Modifier and Type | Method and Description |
---|---|
void |
PessimisticLockingInterceptor.init(CommandsFactory factory) |
void |
ClusteringDependentLogic.AbstractClusteringDependentLogic.init(DataContainer dataContainer,
CacheNotifier notifier,
Configuration configuration) |
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 dataContainer,
EntryFactory entryFactory,
ClusteringDependentLogic cdl,
Configuration configuration) |
void |
AbstractTxLockingInterceptor.setDependencies(TransactionTable txTable,
RpcManager rpcManager,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
TotalOrderStateTransferInterceptor.inject(StateTransferManager stateTransferManager) |
void |
TotalOrderInterceptor.inject(TransactionTable transactionTable,
TotalOrderManager totalOrderManager,
ClusteringDependentLogic clusteringDependentLogic,
BlockingTaskAwareExecutorService executorService) |
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 |
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 |
CacheManagerNotifierImpl.injectCacheManager(EmbeddedCacheManager cacheManager) |
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) |
Modifier and Type | Method and Description |
---|---|
protected void |
QueryInterceptor.injectDependencies(TransactionManager transactionManager,
TransactionSynchronizationRegistry transactionSynchronizationRegistry,
Cache cache,
ClusterRegistry<String,Class<?>,Boolean> clusterRegistry,
DataContainer dataContainer,
ExecutorService e) |
Modifier and Type | Method and Description |
---|---|
void |
ClusterRegistryImpl.init(EmbeddedCacheManager cacheManager) |
Modifier and Type | Method and Description |
---|---|
void |
InboundInvocationHandlerImpl.inject(GlobalComponentRegistry gcr,
Transport transport,
BlockingTaskAwareExecutorService remoteCommandsExecutor,
BlockingTaskAwareExecutorService totalOrderExecutorService,
CancellationService cancelService) |
void |
ReplicationQueueImpl.injectDependencies(ScheduledExecutorService executor,
RpcManager rpcManager,
Configuration configuration,
CommandsFactory commandsFactory,
Cache cache) |
Modifier and Type | Method and Description |
---|---|
void |
DistributionResponseGenerator.inject(DistributionManager distributionManager) |
Modifier and Type | Method and Description |
---|---|
void |
RpcManagerImpl.injectDependencies(Transport t,
Cache cache,
Configuration cfg,
ReplicationQueue replicationQueue,
CommandsFactory cf,
ExecutorService e,
LocalTopologyManager localTopologyManager,
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,
ExecutorService asyncExecutor,
ExecutorService remoteCommandsExecutor,
InboundInvocationHandler inboundInvocationHandler,
CacheManagerNotifier notifier,
GlobalComponentRegistry gcr,
BackupReceiverRepository backupReceiverRepository,
TimeService timeService)
Initializes the transport with global cache configuration and transport-specific properties.
|
Modifier and Type | Method and Description |
---|---|
void |
StateProviderImpl.init(Cache cache,
ExecutorService executorService,
Configuration configuration,
RpcManager rpcManager,
CommandsFactory commandsFactory,
CacheNotifier cacheNotifier,
PersistenceManager persistenceManager,
DataContainer dataContainer,
TransactionTable transactionTable,
StateTransferLock stateTransferLock,
StateConsumer stateConsumer,
InternalEntryFactory entryFactory) |
void |
StateConsumerImpl.init(Cache cache,
ExecutorService executorService,
StateTransferManager stateTransferManager,
InterceptorChain interceptorChain,
InvocationContextFactory icf,
Configuration configuration,
RpcManager rpcManager,
TransactionManager transactionManager,
CommandsFactory commandsFactory,
PersistenceManager persistenceManager,
DataContainer dataContainer,
TransactionTable transactionTable,
StateTransferLock stateTransferLock,
CacheNotifier cacheNotifier,
TotalOrderManager totalOrderManager,
BlockingTaskAwareExecutorService remoteCommandsExecutor,
L1Manager l1Manager) |
void |
StateTransferManagerImpl.init(StateConsumer stateConsumer,
StateProvider stateProvider,
Cache cache,
CacheNotifier cacheNotifier,
Configuration configuration,
GlobalConfiguration globalConfiguration,
RpcManager rpcManager,
GroupManager groupManager,
LocalTopologyManager localTopologyManager) |
void |
StateTransferInterceptor.init(StateTransferLock stateTransferLock,
Configuration configuration,
CommandsFactory commandFactory,
StateTransferManager stateTransferManager) |
Modifier and Type | Method and Description |
---|---|
void |
CacheTopologyControlCommand.init(LocalTopologyManager localTopologyManager,
ClusterTopologyManager clusterTopologyManager,
RebalancePolicy rebalancePolicy) |
void |
DefaultRebalancePolicy.inject(ClusterTopologyManager clusterTopologyManager) |
void |
LocalTopologyManagerImpl.inject(Transport transport,
ExecutorService asyncTransportExecutor,
GlobalComponentRegistry gcr,
TimeService timeService) |
void |
ClusterTopologyManagerImpl.inject(Transport transport,
RebalancePolicy rebalancePolicy,
ExecutorService asyncTransportExecutor,
GlobalConfiguration globalConfiguration,
GlobalComponentRegistry gcr,
CacheManagerNotifier cacheManagerNotifier) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionCoordinator.init(CommandsFactory commandsFactory,
InvocationContextFactory icf,
InterceptorChain invoker,
TransactionTable txTable,
Configuration configuration) |
void |
TransactionTable.initialize(RpcManager rpcManager,
Configuration configuration,
InvocationContextFactory icf,
InterceptorChain invoker,
CacheNotifier notifier,
TransactionFactory gtf,
TransactionCoordinator txCoordinator,
TransactionSynchronizationRegistry transactionSynchronizationRegistry,
CommandsFactory commandsFactory,
ClusteringDependentLogic clusteringDependentLogic,
Cache cache,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
JBossStandaloneJTAManagerLookup.init(Configuration configuration) |
void |
GenericTransactionManagerLookup.setConfiguration(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
void |
TotalOrderManager.inject(BlockingTaskAwareExecutorService totalOrderExecutor) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionFactory.init(Configuration configuration,
VersionGenerator clusterIdGenerator) |
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 |
LockManagerImpl.injectDependencies(Configuration configuration,
LockContainer<?> lockContainer) |
void |
DeadlockDetectingLockManager.injectTimeService(TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
BackupSenderImpl.init(Cache cache,
Transport transport,
TransactionTable txTable,
GlobalConfiguration gc,
TimeService timeService) |
void |
XSiteAdminOperations.init(RpcManager rpcManager,
BackupSender backupSender,
Cache cache) |
void |
BackupReceiverRepositoryImpl.setup(EmbeddedCacheManager cacheManager) |
Copyright © 2016 JBoss, a division of Red Hat. All rights reserved.