Package | Description |
---|---|
org.infinispan |
This is the core of Infinispan, a distributed, transactional, highly scalable data grid
platform.
|
org.infinispan.affinity | |
org.infinispan.atomic |
This package contains the
AtomicMap interfaces and API that Infinispan exposes as building
blocks in creating other public interfaces such as the Tree API. |
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.commands.read | |
org.infinispan.container.versioning | |
org.infinispan.distexec | |
org.infinispan.distexec.mapreduce | |
org.infinispan.distexec.mapreduce.spi | |
org.infinispan.distexec.spi | |
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.base |
Base interceptors containing common, reusable behavior.
|
org.infinispan.io |
Provides Infinispan-specific input and output streams, buffers and related utilities.
|
org.infinispan.jmx |
Helpers that allow easy exposure of attributes and operations via JMX.
|
org.infinispan.loaders |
This package contains loaders and stores, which are used for overflow or persistence.
|
org.infinispan.loaders.cluster |
A
CacheLoader (not CacheStore ) that polls other nodes in the cluster for state. |
org.infinispan.loaders.decorators |
This package contains loaders and stores, which are used for overflow or persistence.
|
org.infinispan.loaders.file |
Simple filesystem-based
CacheStore implementation. |
org.infinispan.manager |
Cache manager package
|
org.infinispan.marshall |
Infinispan makes use of custom marshalling to serialize and deserialize state wherever
possible, rather than falling back to the JDK to do this.
|
org.infinispan.notifications.cachelistener.event | |
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.xa |
XA transaction support.
|
org.infinispan.upgrade | |
org.infinispan.xsite |
Modifier and Type | Interface and Description |
---|---|
interface |
AdvancedCache<K,V>
An advanced interface that exposes additional methods not available on
Cache . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDelegatingAdvancedCache<K,V>
Similar to
AbstractDelegatingCache , but for AdvancedCache . |
class |
AbstractDelegatingCache<K,V>
This is a convenient base class for implementing a cache delegate.
|
class |
CacheImpl<K,V> |
class |
DecoratedCache<K,V>
A decorator to a cache, which can be built with a specific
ClassLoader and a set of Flag s. |
Modifier and Type | Method and Description |
---|---|
Cache<K,V> |
AbstractDelegatingCache.getDelegate() |
Constructor and Description |
---|
AbstractDelegatingCache(Cache<K,V> cache) |
Modifier and Type | Method and Description |
---|---|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache,
Collection<Address> filter,
KeyGenerator<K> keyGenerator,
Executor ex,
int keyBufferSize)
|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache,
Collection<Address> filter,
KeyGenerator<K> keyGenerator,
Executor ex,
int keyBufferSize,
boolean start)
Creates a service that would only generate keys for addresses specified in filter.
|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache,
Executor ex,
KeyGenerator<K> keyGenerator,
int keyBufferSize)
|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache,
Executor ex,
KeyGenerator<K> keyGenerator,
int keyBufferSize,
boolean start)
Creates an
KeyAffinityService instance that generates keys mapped to all addresses
in the cluster. |
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newLocalKeyAffinityService(Cache<K,V> cache,
KeyGenerator<K> keyGenerator,
Executor ex,
int keyBufferSize)
|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newLocalKeyAffinityService(Cache<K,V> cache,
KeyGenerator<K> keyGenerator,
Executor ex,
int keyBufferSize,
boolean start)
Created an service that only generates keys for the local address.
|
Constructor and Description |
---|
KeyAffinityServiceImpl(Executor executor,
Cache<? extends K,?> cache,
KeyGenerator<? extends K> keyGenerator,
int bufferSize,
Collection<Address> filter,
boolean start) |
Modifier and Type | Method and Description |
---|---|
static <MK,K,V> AtomicMap<K,V> |
AtomicMapLookup.getAtomicMap(Cache<MK,?> cache,
MK key)
Retrieves an atomic map from a given cache, stored under a given key.
|
static <MK,K,V> AtomicMap<K,V> |
AtomicMapLookup.getAtomicMap(Cache<MK,?> cache,
MK key,
boolean createIfAbsent)
Retrieves an atomic map from a given cache, stored under a given key.
|
static <MK,K,V> AtomicMap<K,V> |
AtomicMapLookup.getAtomicMap(Cache<MK,?> cache,
MK key,
FlagContainer flagContainer)
Deprecated.
|
static <MK,K,V> FineGrainedAtomicMap<K,V> |
AtomicMapLookup.getFineGrainedAtomicMap(Cache<MK,?> cache,
MK key)
Retrieves a fine grained atomic map from a given cache, stored under a given key.
|
static <MK,K,V> FineGrainedAtomicMap<K,V> |
AtomicMapLookup.getFineGrainedAtomicMap(Cache<MK,?> cache,
MK key,
boolean createIfAbsent)
Retrieves an atomic map from a given cache, stored under a given key.
|
static <MK,K,V> Map<K,V> |
AtomicMapLookup.getReadOnlyAtomicMap(Cache<MK,?> cache,
MK key)
Retrieves an atomic map from a given cache, stored under a given key, for reading only.
|
static <K,V> AtomicHashMap<K,V> |
AtomicHashMap.newInstance(Cache<Object,Object> cache,
Object cacheKey)
Construction only allowed through this factory method.
|
static <MK> void |
AtomicMapLookup.removeAtomicMap(Cache<MK,?> cache,
MK key)
Removes the atomic map associated with the given key from the underlying cache.
|
Modifier and Type | Method and Description |
---|---|
void |
CommandsFactoryImpl.setupDependencies(DataContainer container,
CacheNotifier notifier,
Cache<Object,Object> cache,
InterceptorChain interceptorChain,
DistributionManager distributionManager,
InvocationContextContainer icc,
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) |
Modifier and Type | Method and Description |
---|---|
void |
DistributedExecuteCommand.init(Cache<Object,Object> cache) |
Modifier and Type | Method and Description |
---|---|
void |
SimpleClusteredVersionGenerator.init(Cache<?,?> cache) |
Modifier and Type | Method and Description |
---|---|
void |
DistributedCallable.setEnvironment(Cache<K,V> cache,
Set<K> inputKeys)
Invoked by execution environment after DistributedCallable has been migrated for execution to
a specific Infinispan node.
|
Constructor and Description |
---|
DefaultExecutorService(Cache<?,?> masterCacheNode)
Creates a new DefaultExecutorService given a master cache node for local task execution.
|
DefaultExecutorService(Cache<?,?> masterCacheNode,
ExecutorService localExecutorService)
Creates a new DefaultExecutorService given a master cache node and an ExecutorService for
parallel execution of tasks ran on this node.
|
DefaultExecutorService(Cache<?,?> masterCacheNode,
ExecutorService localExecutorService,
boolean takeExecutorOwnership)
Creates a new DefaultExecutorService given a master cache node and an ExecutorService for
parallel execution of task ran on this node.
|
Constructor and Description |
---|
MapReduceTask(Cache<KIn,VIn> masterCacheNode)
Create a new MapReduceTask given a master cache node.
|
MapReduceTask(Cache<KIn,VIn> masterCacheNode,
boolean distributeReducePhase)
Create a new MapReduceTask given a master cache node.
|
MapReduceTask(Cache<KIn,VIn> masterCacheNode,
boolean distributeReducePhase,
boolean useIntermediateSharedCache)
Create a new MapReduceTask given a master cache node.
|
Modifier and Type | Method and Description |
---|---|
<KIn,VIn,KOut,VOut> |
DefaultMapReduceTaskLifecycle.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper,
Cache<KIn,VIn> inputCache) |
<KIn,VIn,KOut,VOut> |
MapReduceTaskLifecycleService.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper,
Cache<KIn,VIn> inputCache) |
<KIn,VIn,KOut,VOut> |
MapReduceTaskLifecycle.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper,
Cache<KIn,VIn> inputCache) |
<KOut,VOut> |
DefaultMapReduceTaskLifecycle.onPreExecute(Reducer<KOut,VOut> reducer,
Cache<?,?> inputCache) |
<KOut,VOut> |
MapReduceTaskLifecycleService.onPreExecute(Reducer<KOut,VOut> reducer,
Cache<?,?> inputCache) |
<KOut,VOut> |
MapReduceTaskLifecycle.onPreExecute(Reducer<KOut,VOut> reducer,
Cache<?,?> inputCache) |
Modifier and Type | Method and Description |
---|---|
<T,K,V> void |
DistributedTaskLifecycleService.onPreExecute(Callable<T> task,
Cache<K,V> inputCache) |
<T,K,V> void |
DefaultDistributedTaskLifecycle.onPreExecute(Callable<T> task,
Cache<K,V> inputCache) |
<T,K,V> void |
DistributedTaskLifecycle.onPreExecute(Callable<T> task,
Cache<K,V> inputDataCache) |
Modifier and Type | Method and Description |
---|---|
void |
EvictionManagerImpl.initialize(ScheduledExecutorService executor,
Cache cache,
Configuration cfg,
DataContainer dataContainer,
CacheLoaderManager cacheLoaderManager,
CacheNotifier cacheNotifier) |
Modifier and Type | Method and Description |
---|---|
Cache<K,V> |
InternalCacheFactory.createCache(Configuration configuration,
GlobalComponentRegistry globalComponentRegistry,
String cacheName)
This implementation clones the configuration passed in before using it.
|
Modifier and Type | Field and Description |
---|---|
protected Cache<?,?> |
BaseCustomInterceptor.cache |
Modifier and Type | Field and Description |
---|---|
protected Cache<String,byte[]> |
GridFilesystem.data |
protected Cache<String,GridFile.Metadata> |
GridFilesystem.metadata |
Constructor and Description |
---|
GridFilesystem(Cache<String,byte[]> data,
Cache<String,GridFile.Metadata> metadata) |
GridFilesystem(Cache<String,byte[]> data,
Cache<String,GridFile.Metadata> metadata) |
GridFilesystem(Cache<String,byte[]> data,
Cache<String,GridFile.Metadata> metadata,
int defaultChunkSize)
Creates an instance.
|
GridFilesystem(Cache<String,byte[]> data,
Cache<String,GridFile.Metadata> metadata,
int defaultChunkSize)
Creates an instance.
|
Modifier and Type | Method and Description |
---|---|
void |
CacheJmxRegistration.initialize(Cache<?,?> cache,
GlobalConfiguration globalConfig) |
Modifier and Type | Field and Description |
---|---|
protected Cache<Object,Object> |
AbstractCacheLoader.cache |
Modifier and Type | Method and Description |
---|---|
void |
AbstractCacheStore.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m) |
void |
LockSupportCacheStore.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m) |
void |
CacheLoader.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m)
Used to initialize a cache loader.
|
void |
AbstractCacheLoader.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m) |
Modifier and Type | Method and Description |
---|---|
void |
ClusterCacheLoader.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m) |
Modifier and Type | Method and Description |
---|---|
void |
AsyncStore.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m) |
void |
ChainingCacheStore.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m) |
void |
AbstractDelegatingStore.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m) |
protected void |
SingletonStore.pushState(Cache<Object,Object> cache)
Pushes the state of a specific cache by reading the cache's data and putting in the cache store.
|
Constructor and Description |
---|
SingletonStore(CacheStore delegate,
Cache<Object,Object> cache,
SingletonStoreConfig config) |
Modifier and Type | Method and Description |
---|---|
void |
FileCacheStore.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m) |
Modifier and Type | Method and Description |
---|---|
<K,V> Cache<K,V> |
CacheContainer.getCache()
This method overrides the underlying
CacheContainer.getCache() ,
to return a Cache instead of a BasicCache |
<K,V> Cache<K,V> |
DefaultCacheManager.getCache()
Retrieves the default cache associated with this cache manager.
|
<K,V> Cache<K,V> |
AbstractDelegatingEmbeddedCacheManager.getCache() |
<K,V> Cache<K,V> |
CacheContainer.getCache(String cacheName)
This method overrides the underlying
CacheContainer.getCache(String) ,
to return a Cache instead of a BasicCache |
<K,V> Cache<K,V> |
DefaultCacheManager.getCache(String cacheName)
Retrieves a named cache from the system.
|
<K,V> Cache<K,V> |
AbstractDelegatingEmbeddedCacheManager.getCache(String cacheName) |
<K,V> Cache<K,V> |
EmbeddedCacheManager.getCache(String cacheName,
boolean createIfAbsent)
Retrieves a named cache from the system in the same way that
CacheContainer.getCache(String) does except that if offers the possibility for the
named cache not to be retrieved if it has not yet been started, or if
it's been removed after being started. |
<K,V> Cache<K,V> |
DefaultCacheManager.getCache(String cacheName,
boolean createIfAbsent) |
<K,V> Cache<K,V> |
AbstractDelegatingEmbeddedCacheManager.getCache(String cacheName,
boolean createIfAbsent) |
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) |
Modifier and Type | Method and Description |
---|---|
Cache<K,V> |
Event.getCache() |
Cache<K,V> |
EventImpl.getCache() |
Modifier and Type | Method and Description |
---|---|
static <K,V> EventImpl<K,V> |
EventImpl.createEvent(Cache<K,V> cache,
Event.Type type) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationQueueImpl.injectDependencies(ScheduledExecutorService executor,
RpcManager rpcManager,
Configuration configuration,
CommandsFactory commandsFactory,
Cache cache) |
Modifier and Type | Method and Description |
---|---|
void |
RpcManagerImpl.injectDependencies(Transport t,
Cache cache,
Configuration cfg,
GlobalConfiguration globalConfiguration,
ReplicationQueue replicationQueue,
CommandsFactory cf,
ExecutorService e,
LocalTopologyManager localTopologyManager,
StateTransferManager stateTransferManager) |
Modifier and Type | Method and Description |
---|---|
void |
StateProviderImpl.init(Cache cache,
ExecutorService executorService,
Configuration configuration,
RpcManager rpcManager,
CommandsFactory commandsFactory,
CacheNotifier cacheNotifier,
CacheLoaderManager cacheLoaderManager,
DataContainer dataContainer,
TransactionTable transactionTable,
StateTransferLock stateTransferLock,
StateConsumer stateConsumer) |
void |
StateConsumerImpl.init(Cache cache,
ExecutorService executorService,
StateTransferManager stateTransferManager,
InterceptorChain interceptorChain,
InvocationContextContainer icc,
Configuration configuration,
RpcManager rpcManager,
TransactionManager transactionManager,
CommandsFactory commandsFactory,
CacheLoaderManager cacheLoaderManager,
DataContainer dataContainer,
TransactionTable transactionTable,
StateTransferLock stateTransferLock,
CacheNotifier cacheNotifier) |
void |
StateTransferManagerImpl.init(StateConsumer stateConsumer,
StateProvider stateProvider,
Cache cache,
CacheNotifier cacheNotifier,
Configuration configuration,
GlobalConfiguration globalConfiguration,
RpcManager rpcManager,
GroupManager groupManager,
LocalTopologyManager localTopologyManager) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionTable.initialize(RpcManager rpcManager,
Configuration configuration,
InvocationContextContainer icc,
InterceptorChain invoker,
CacheNotifier notifier,
TransactionFactory gtf,
TransactionCoordinator txCoordinator,
TransactionSynchronizationRegistry transactionSynchronizationRegistry,
CommandsFactory commandsFactory,
ClusteringDependentLogic clusteringDependentLogic,
Cache cache) |
Modifier and Type | Method and Description |
---|---|
void |
XaTransactionTable.init(RecoveryManager recoveryManager,
Cache cache) |
Modifier and Type | Method and Description |
---|---|
void |
TargetMigrator.disconnectSource(Cache<Object,Object> cache)
Disconnects the target from the source.
|
void |
RollingUpgradeManager.initialize(Cache<Object,Object> cache) |
long |
TargetMigrator.synchronizeData(Cache<Object,Object> cache)
Performs the synchronization of data between source and target by retrieving the set of known keys and fetching each key in turn
|
Modifier and Type | Field and Description |
---|---|
protected Cache<K,V> |
AbstractCustomFailurePolicy.cache |
Modifier and Type | Method and Description |
---|---|
Cache |
BackupReceiver.getCache() |
Cache |
BackupReceiverImpl.getCache() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractCustomFailurePolicy.init(Cache cache) |
void |
CustomFailurePolicy.init(Cache<K,V> cache)
Invoked during the initialization phase.
|
void |
BackupSenderImpl.init(Cache cache,
Transport transport,
TransactionTable txTable,
GlobalConfiguration gc) |
void |
XSiteAdminOperations.init(RpcManager rpcManager,
BackupSender backupSender,
Cache cache) |
Constructor and Description |
---|
BackupReceiverImpl(Cache cache) |
Copyright © 2015 JBoss, a division of Red Hat. All Rights Reserved.