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.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.cache | |
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 | |
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.distribution | |
org.infinispan.interceptors.locking | |
org.infinispan.lifecycle |
Component lifecycle.
|
org.infinispan.manager |
Cache manager package
|
org.infinispan.marshall.core | |
org.infinispan.persistence.manager | |
org.infinispan.query.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.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.synchronization | |
org.infinispan.transaction.xa |
XA transaction support.
|
org.infinispan.util.concurrent.locks |
Lock and synchronization related classes, tools and utilities.
|
Modifier and Type | Field and Description |
---|---|
protected Configuration |
CacheImpl.config |
Modifier and Type | Method and Description |
---|---|
Configuration |
Cache.getCacheConfiguration() |
Configuration |
AbstractDelegatingCache.getCacheConfiguration() |
Configuration |
CacheImpl.getCacheConfiguration() |
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 |
---|---|
protected static void |
AutoBatchSupport.assertBatchingSupported(Configuration c) |
Modifier and Type | Method and Description |
---|---|
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 |
RemoveCommand.init(CacheNotifier notifier,
Configuration configuration) |
void |
PutKeyValueCommand.init(CacheNotifier notifier,
Configuration cfg) |
void |
ReplaceCommand.init(CacheNotifier notifier,
Configuration cfg) |
void |
InvalidateL1Command.init(Configuration config,
DistributionManager dm,
CacheNotifier n,
DataContainer dc) |
Constructor and Description |
---|
InvalidateL1Command(Address writeOrigin,
boolean forRehash,
DataContainer dc,
Configuration config,
DistributionManager dm,
CacheNotifier notifier,
Set<Flag> flags,
Collection<Object> keys) |
InvalidateL1Command(boolean forRehash,
DataContainer dc,
Configuration config,
DistributionManager dm,
CacheNotifier notifier,
Set<Flag> flags,
Collection<Object> keys) |
InvalidateL1Command(boolean forRehash,
DataContainer dc,
Configuration config,
DistributionManager dm,
CacheNotifier notifier,
Set<Flag> flags,
Object... keys) |
Modifier and Type | Method and Description |
---|---|
Configuration |
ConfigurationChildBuilder.build() |
Configuration |
ConfigurationBuilder.build() |
Configuration |
ConfigurationBuilder.build(boolean validate) |
Modifier and Type | Method and Description |
---|---|
static ClassLoader |
Configurations.getClassLoader(Configuration configuration,
GlobalConfiguration globalConfiguration) |
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,
CacheNotifier notifier,
DistributionManager distributionManager) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
AbstractInvocationContextFactory.config |
Modifier and Type | Method and Description |
---|---|
void |
AbstractInvocationContextFactory.init(Configuration config) |
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) |
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 | 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 c,
TransactionCoordinator txCoordinator,
RpcManager rpcManager,
RecoveryManager recoveryManager) |
void |
ActivationInterceptor.inject(Configuration cfg,
ActivationManager activationManager,
ClusteringDependentLogic cdl,
DataContainer dataContainer) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
CommandInterceptor.cacheConfiguration |
Modifier and Type | Method and Description |
---|---|
void |
CommandInterceptor.injectConfiguration(Configuration configuration) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
L1NonTxInterceptor.config |
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) |
Modifier and Type | Method and Description |
---|---|
void |
ClusteringDependentLogic.AbstractClusteringDependentLogic.init(DataContainer dataContainer,
CacheNotifier notifier,
Configuration configuration) |
void |
ClusteringDependentLogic.DistributionLogic.init(DistributionManager dm,
Configuration configuration,
RpcManager rpcManager,
StateTransferLock stateTransferLock) |
void |
AbstractLockingInterceptor.setDependencies(LockManager lockManager,
DataContainer dataContainer,
EntryFactory entryFactory,
ClusteringDependentLogic cdl,
Configuration configuration) |
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 | Field and Description |
---|---|
protected Configuration |
DefaultCacheManager.defaultConfiguration |
Modifier and Type | Method and Description |
---|---|
Configuration |
AbstractDelegatingEmbeddedCacheManager.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,
Configuration configuration) |
Configuration |
AbstractDelegatingEmbeddedCacheManager.defineConfiguration(String cacheName,
String templateCacheName,
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.defineConfiguration(String cacheName,
String templateName,
Configuration configurationOverride) |
Configuration |
AbstractDelegatingEmbeddedCacheManager.getCacheConfiguration(String name) |
Configuration |
EmbeddedCacheManager.getCacheConfiguration(String name)
Returns the configuration for the given cache.
|
Configuration |
DefaultCacheManager.getCacheConfiguration(String name) |
Configuration |
AbstractDelegatingEmbeddedCacheManager.getDefaultCacheConfiguration() |
Configuration |
EmbeddedCacheManager.getDefaultCacheConfiguration()
Returns default configuration for this CacheManager
|
Configuration |
DefaultCacheManager.getDefaultCacheConfiguration() |
Modifier and Type | Method and Description |
---|---|
Configuration |
AbstractDelegatingEmbeddedCacheManager.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,
Configuration configuration) |
Configuration |
AbstractDelegatingEmbeddedCacheManager.defineConfiguration(String cacheName,
String templateCacheName,
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.defineConfiguration(String cacheName,
String templateName,
Configuration configurationOverride) |
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 |
---|---|
void |
VersionAwareMarshaller.inject(Cache cache,
Configuration cfg,
InvocationContextContainer icc,
ExternalizerTable extTable,
GlobalConfiguration globalCfg) |
void |
CacheMarshaller.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 |
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 |
---|---|
void |
LifecycleManager.cacheStarting(ComponentRegistry cr,
Configuration cfg,
String cacheName)
Registers the Search interceptor in the cache before it gets started
|
Modifier and Type | Method and Description |
---|---|
protected Configuration |
ReplicationQueueImpl.getConfiguration() |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationQueueImpl.injectDependencies(ScheduledExecutorService executor,
RpcManager rpcManager,
Configuration configuration,
CommandsFactory commandsFactory,
Cache cache) |
void |
ReplicationQueueImpl.injectDependencies(ScheduledExecutorService executor,
RpcManager rpcManager,
Configuration configuration,
CommandsFactory commandsFactory,
String cacheName) |
Modifier and Type | Method and Description |
---|---|
static ResponseMode |
ResponseMode.getAsyncResponseMode(Configuration c) |
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 |
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 | Field and Description |
---|---|
protected Configuration |
TransactionTable.configuration |
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) |
Constructor and Description |
---|
AbstractEnlistmentAdapter(CacheTransaction cacheTransaction,
CommandsFactory commandsFactory,
RpcManager rpcManager,
TransactionTable txTable,
ClusteringDependentLogic clusteringLogic,
Configuration configuration,
TransactionCoordinator txCoordinator) |
AbstractEnlistmentAdapter(CommandsFactory commandsFactory,
RpcManager rpcManager,
TransactionTable txTable,
ClusteringDependentLogic clusteringLogic,
Configuration configuration,
TransactionCoordinator txCoordinator) |
Modifier and Type | Method and Description |
---|---|
void |
JBossStandaloneJTAManagerLookup.init(Configuration configuration) |
void |
GenericTransactionManagerLookup.setConfiguration(Configuration configuration) |
Constructor and Description |
---|
SynchronizationAdapter(LocalTransaction localTransaction,
TransactionCoordinator txCoordinator,
CommandsFactory commandsFactory,
RpcManager rpcManager,
TransactionTable transactionTable,
ClusteringDependentLogic clusteringLogic,
Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionFactory.init(Configuration configuration,
VersionGenerator clusterIdGenerator) |
Constructor and Description |
---|
TransactionXaAdapter(LocalXaTransaction localTransaction,
TransactionTable txTable,
RecoveryManager rm,
TransactionCoordinator txCoordinator,
CommandsFactory commandsFactory,
RpcManager rpcManager,
ClusteringDependentLogic clusteringDependentLogic,
Configuration configuration,
String cacheName) |
TransactionXaAdapter(TransactionTable txTable,
RecoveryManager rm,
TransactionCoordinator txCoordinator,
CommandsFactory commandsFactory,
RpcManager rpcManager,
ClusteringDependentLogic clusteringDependentLogic,
Configuration configuration,
String cacheName) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
LockManagerImpl.configuration |
Modifier and Type | Method and Description |
---|---|
void |
LockManagerImpl.injectDependencies(Configuration configuration,
LockContainer<?> lockContainer) |
Copyright © 2016 JBoss, a division of Red Hat. All rights reserved.