Package | Description |
---|---|
org.infinispan |
This is the core of Infinispan, a distributed, transactional, highly scalable data grid
platform.
|
org.infinispan.affinity |
This package contains the
KeyAffinityService interfaces which allow user code to determine mapping of keys onto nodes |
org.infinispan.affinity.impl | |
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.atomic.impl | |
org.infinispan.cache.impl | |
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.commands.read | |
org.infinispan.container.versioning | |
org.infinispan.distexec |
Distribute Executor APIs
|
org.infinispan.distexec.mapreduce |
Map/Reduce APIs
|
org.infinispan.distexec.mapreduce.spi | |
org.infinispan.distexec.spi | |
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.compat | |
org.infinispan.interceptors.distribution | |
org.infinispan.io |
Provides Infinispan-specific input and output streams, buffers and related utilities.
|
org.infinispan.iteration.impl |
Provides Infinispan-specific implementation details iterating over entries in the cache, specifically optimized for
distributed caches.
|
org.infinispan.jmx |
Helpers that allow easy exposure of attributes and operations via JMX.
|
org.infinispan.manager |
Cache manager package
|
org.infinispan.manager.impl | |
org.infinispan.marshall.core | |
org.infinispan.notifications.cachelistener.cluster | |
org.infinispan.notifications.cachelistener.cluster.impl | |
org.infinispan.notifications.cachelistener.event |
Cache -specific listener events |
org.infinispan.notifications.cachelistener.event.impl | |
org.infinispan.partitionhandling.impl | |
org.infinispan.persistence |
This package contains stores, which are used for overflow or persistence.
|
org.infinispan.persistence.spi |
The Persistence SPI
|
org.infinispan.persistence.support | |
org.infinispan.remoting |
Remote communication between cache instances.
|
org.infinispan.security |
The Security API
|
org.infinispan.security.actions | |
org.infinispan.security.impl | |
org.infinispan.statetransfer |
Transfer of state to new caches in a cluster.
|
org.infinispan.stats.impl | |
org.infinispan.stream |
This package contains various helper classes when using the
CacheStream or its various
classes. |
org.infinispan.stream.impl | |
org.infinispan.stream.impl.interceptor | |
org.infinispan.stream.impl.local | |
org.infinispan.transaction.impl | |
org.infinispan.transaction.xa |
XA transaction support.
|
org.infinispan.upgrade | |
org.infinispan.util |
General utilities that are not specific to Infinispan, including string parsing helpers, reflection tools and
collections and containers designed to supplement the JDK-provided containers.
|
org.infinispan.util.logging.events | |
org.infinispan.xsite |
Modifier and Type | Interface and Description |
---|---|
interface |
AdvancedCache<K,V>
An advanced interface that exposes additional methods not available on
Cache . |
Constructor and Description |
---|
AbstractDelegatingCache(Cache<K,V> cache)
Deprecated.
|
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)
Deprecated.
|
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> 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 <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 |
---|---|
static <K,V> AtomicHashMap<K,V> |
AtomicHashMap.newInstance(Cache<Object,Object> cache,
Object cacheKey,
AtomicHashMap.ProxyMode proxyMode)
Construction only allowed through this factory method.
|
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. |
class |
SimpleCacheImpl<K,V>
Simple local cache without interceptor stack.
|
class |
StatsCollectingCache<K,V>
Wraps existing
AdvancedCache to collect statistics |
Modifier and Type | Method and Description |
---|---|
Cache<K,V> |
AbstractDelegatingCache.getDelegate() |
Modifier and Type | Method and Description |
---|---|
void |
CacheConfigurationMBean.injectDependencies(Cache<?,?> cache,
Configuration configuration) |
Constructor and Description |
---|
AbstractDelegatingCache(Cache<K,V> cache) |
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 | Field and Description |
---|---|
protected Cache<K,V> |
AbstractCloseableIteratorCollection.cache |
Modifier and Type | Method and Description |
---|---|
void |
DistributedExecuteCommand.init(Cache<Object,Object> cache) |
Constructor and Description |
---|
AbstractCloseableIteratorCollection(Cache<K,V> cache) |
EntrySetCommand(Cache<K,V> cache,
Set<Flag> flags) |
KeySetCommand(Cache<K,V> cache,
Set<Flag> flags) |
SizeCommand(Cache<Object,?> cache,
Set<Flag> flags) |
Modifier and Type | Method and Description |
---|---|
void |
SimpleClusteredVersionGenerator.init(Cache<?,?> cache) |
void |
NumericVersionGenerator.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.
|
Modifier and Type | Method and Description |
---|---|
void |
MapReduceTask.execute(Cache<KOut,VOut> resultsCache)
Deprecated.
Executes this task and stores results in the provided results cache.
|
Constructor and Description |
---|
MapReduceTask(Cache<KIn,VIn> masterCacheNode)
Deprecated.
Create a new MapReduceTask given a master cache node.
|
MapReduceTask(Cache<KIn,VIn> masterCacheNode,
boolean distributeReducePhase)
Deprecated.
Create a new MapReduceTask given a master cache node.
|
MapReduceTask(Cache<KIn,VIn> masterCacheNode,
boolean distributeReducePhase,
boolean useIntermediateSharedCache)
Deprecated.
Create a new MapReduceTask given a master cache node.
|
Modifier and Type | Method and Description |
---|---|
<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) |
<KIn,VIn,KOut,VOut> |
DefaultMapReduceTaskLifecycle.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper,
Cache<KIn,VIn> inputCache) |
<KOut,VOut> |
MapReduceTaskLifecycleService.onPreExecute(Reducer<KOut,VOut> reducer,
Cache<?,?> inputCache) |
<KOut,VOut> |
MapReduceTaskLifecycle.onPreExecute(Reducer<KOut,VOut> reducer,
Cache<?,?> inputCache) |
<KOut,VOut> |
DefaultMapReduceTaskLifecycle.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 |
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 | 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 | Method and Description |
---|---|
void |
TxInterceptor.init(TransactionTable txTable,
Configuration configuration,
RpcManager rpcManager,
RecoveryManager recoveryManager,
CommandsFactory commandsFactory,
Cache<K,V> cache,
PartitionHandlingManager partitionHandlingManager)
Deprecated.
|
protected void |
MarshalledValueInterceptor.inject(org.infinispan.commons.marshall.StreamingMarshaller marshaller,
InternalEntryFactory entryFactory,
Cache<K,V> cache)
Deprecated.
|
protected void |
CacheLoaderInterceptor.injectDependencies(PersistenceManager clm,
EntryFactory entryFactory,
CacheNotifier notifier,
TimeService timeService,
InternalEntryFactory iceFactory,
DataContainer<K,V> dataContainer,
GroupManager groupManager,
ExecutorService persistenceExecutor,
Cache<K,V> cache)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected Cache<?,?> |
BaseCustomInterceptor.cache |
Modifier and Type | Method and Description |
---|---|
protected <K,V> Cache<K,V> |
CommandInterceptor.getCacheWithFlags(Cache<K,V> cache,
LocalFlagAffectedCommand command) |
Modifier and Type | Method and Description |
---|---|
protected <K,V> Cache<K,V> |
CommandInterceptor.getCacheWithFlags(Cache<K,V> cache,
LocalFlagAffectedCommand command) |
Modifier and Type | Method and Description |
---|---|
protected void |
BaseTypeConverterInterceptor.init(InternalEntryFactory entryFactory,
VersionGenerator versionGenerator,
Cache<K,V> cache)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
DistributionBulkInterceptor.inject(Cache<K,V> cache)
Deprecated.
|
Constructor and Description |
---|
BackingKeySet(Cache<K,V> cache,
CacheSet<CacheEntry<K,V>> entrySet,
LocalFlagAffectedCommand command) |
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 | Field and Description |
---|---|
protected Cache<K,V> |
LocalEntryRetriever.cache |
protected Cache<K,?> |
TransactionAwareCloseableIterable.cache |
protected Cache<K,V> |
RemovableEntryIterator.cache |
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) |
Constructor and Description |
---|
EntryIterableFromStreamImpl(KeyValueFilter<? super K,? super V> filter,
EnumSet<Flag> flags,
Cache<K,V> cache) |
RemovableEntryIterator(org.infinispan.commons.util.CloseableIterator<CacheEntry<K,V>> realIterator,
Cache<K,V> cache,
boolean initIterator) |
TrackingEntryIterableFromStream(KeyValueFilter<? super K,? super V> filter,
Converter<? super K,? super V,C> converter,
EnumSet<Flag> flags,
Cache<K,V> cache) |
TransactionAwareCloseableIterable(org.infinispan.commons.util.CloseableIterable<CacheEntry<K,C>> iterable,
KeyValueFilter<? super K,? super V> filter,
Converter<? super K,? super V,? extends C> converter,
TxInvocationContext<LocalTransaction> ctx,
Cache<K,?> cache) |
TransactionAwareCloseableIterator(org.infinispan.commons.util.CloseableIterator<CacheEntry<K,V>> realIterator,
KeyValueFilter<? super K,? super V> filter,
Converter<? super K,? super V,? extends C> converter,
TxInvocationContext<LocalTransaction> ctx,
Cache<K,V> cache) |
TransactionAwareEntryIterable(EntryIterable<K,V> entryIterable,
KeyValueFilter<? super K,? super V> filter,
TxInvocationContext<LocalTransaction> ctx,
Cache<K,V> cache) |
Modifier and Type | Method and Description |
---|---|
void |
CacheJmxRegistration.initialize(Cache<?,?> cache,
GlobalConfiguration globalConfig) |
Modifier and Type | Method and Description |
---|---|
<K,V> Cache<K,V> |
DefaultCacheManager.getCache()
Retrieves the default cache associated with this cache manager.
|
<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(String cacheName)
Retrieves a named cache from the system.
|
<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,
boolean createIfAbsent) |
<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,
String configurationName) |
<K,V> Cache<K,V> |
EmbeddedCacheManager.getCache(String cacheName,
String configurationName)
Retrieves a named cache from the system in the same way that
CacheContainer.getCache(String) does except that if offers the possibility to specify
a specific configuration template. |
<K,V> Cache<K,V> |
DefaultCacheManager.getCache(String cacheName,
String configurationTemplate,
boolean createIfAbsent) |
<K,V> Cache<K,V> |
EmbeddedCacheManager.getCache(String cacheName,
String configurationTemplate,
boolean createIfAbsent)
Retrieves a named cache from the system in the same way that
CacheContainer.getCache(String) does except that if offers the possibility to specify
a specific configuration template. |
Modifier and Type | Method and Description |
---|---|
<K,V> Cache<K,V> |
AbstractDelegatingEmbeddedCacheManager.getCache() |
<K,V> Cache<K,V> |
AbstractDelegatingEmbeddedCacheManager.getCache(String cacheName) |
<K,V> Cache<K,V> |
AbstractDelegatingEmbeddedCacheManager.getCache(String cacheName,
boolean createIfAbsent) |
<K,V> Cache<K,V> |
AbstractDelegatingEmbeddedCacheManager.getCache(String cacheName,
String configurationName) |
<K,V> Cache<K,V> |
AbstractDelegatingEmbeddedCacheManager.getCache(String cacheName,
String configurationTemplate,
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 | Field and Description |
---|---|
Cache<?,?> |
ClusterEventManagerFactory.cache |
Modifier and Type | Method and Description |
---|---|
Cache<K,V> |
ClusterEvent.getCache() |
Modifier and Type | Method and Description |
---|---|
void |
ClusterEventManagerFactory.injectCache(Cache<?,?> cache) |
void |
MultiClusterEventCallable.setEnvironment(Cache<K,V> cache,
Set<K> inputKeys) |
void |
ClusterListenerRemoveCallable.setEnvironment(Cache<K,V> cache,
Set<K> inputKeys) |
void |
ClusterListenerReplicateCallable.setEnvironment(Cache<K,V> cache,
Set<K> inputKeys) |
void |
ClusterEventCallable.setEnvironment(Cache<K,V> cache,
Set<K> inputKeys) |
Constructor and Description |
---|
BatchingClusterEventManagerImpl(Cache<K,V> cache) |
Modifier and Type | Method and Description |
---|---|
Cache<K,V> |
Event.getCache() |
Modifier and Type | Method and Description |
---|---|
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 |
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 |
---|---|
Cache |
InitializationContextImpl.getCache() |
Constructor and Description |
---|
InitializationContextImpl(StoreConfiguration configuration,
Cache cache,
org.infinispan.commons.marshall.StreamingMarshaller marshaller,
TimeService timeService,
org.infinispan.commons.io.ByteBufferFactory byteBufferFactory,
MarshalledEntryFactory mef) |
Modifier and Type | Method and Description |
---|---|
Cache |
InitializationContext.getCache() |
Modifier and Type | Method and Description |
---|---|
protected void |
SingletonCacheWriter.pushState(Cache cache)
Pushes the state of a specific cache by reading the cache's data and putting in the cache store.
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationQueueImpl.injectDependencies(ScheduledExecutorService executor,
RpcManager rpcManager,
Configuration configuration,
CommandsFactory commandsFactory,
Cache cache)
Deprecated.
|
static LocalInvocation |
LocalInvocation.newInstanceFromCache(Cache<?,?> cache,
CacheRpcCommand command) |
Modifier and Type | Interface and Description |
---|---|
interface |
SecureCache<K,V>
SecureCache.
|
Modifier and Type | Method and Description |
---|---|
Cache<?,?> |
GlobalSecurityManager.globalACLCache()
Returns the global ACL cache
|
Modifier and Type | Method and Description |
---|---|
Cache<?,?> |
GetCacheAction.run() |
Constructor and Description |
---|
GetDefaultExecutorServiceAction(Cache<?,?> cache) |
Modifier and Type | Class and Description |
---|---|
class |
SecureCacheImpl<K,V>
SecureCacheImpl.
|
Modifier and Type | Method and Description |
---|---|
Cache<?,?> |
GlobalSecurityManagerImpl.globalACLCache() |
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) |
Modifier and Type | Method and Description |
---|---|
void |
ClusterCacheStatsImpl.injectDependencies(Cache<?,?> cache,
TimeService ts,
Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
void |
CacheAware.injectCache(Cache<K,V> cache)
Method that is invoked when a cache is to be injected.
|
Modifier and Type | Field and Description |
---|---|
protected Cache<K,?> |
RemovableIterator.cache |
protected Cache<?,?> |
PartitionAwareClusterStreamManager.cache |
Modifier and Type | Method and Description |
---|---|
void |
PartitionAwareClusterStreamManager.inject(Cache<?,?> cache) |
void |
LocalStreamManagerImpl.inject(Cache<K,V> cache,
ComponentRegistry registry,
StateTransferManager stm,
RpcManager rpc,
Configuration configuration,
CommandsFactory factory) |
Constructor and Description |
---|
RemovableCloseableIterator(org.infinispan.commons.util.CloseableIterator<C> realIterator,
Cache<K,?> cache,
Function<? super C,K> removeFunction) |
RemovableIterator(Iterator<C> realIterator,
Cache<K,?> cache,
Function<? super C,K> removeFunction) |
Constructor and Description |
---|
AbstractDelegatingEntryCacheSet(Cache<K,V> cache,
CacheSet<CacheEntry<K,V>> set) |
AbstractDelegatingKeyCacheSet(Cache<K,V> cache,
CacheSet<K> set) |
Constructor and Description |
---|
EntryStreamSupplier(Cache<K,V> cache,
ConsistentHash hash,
Supplier<Stream<CacheEntry<K,V>>> supplier) |
KeyStreamSupplier(Cache<K,V> cache,
ConsistentHash hash,
Supplier<Stream<K>> supplier) |
ValueCacheCollection(Cache<K,V> cache,
CacheSet<CacheEntry<K,V>> cacheSet) |
Modifier and Type | Method and Description |
---|---|
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) |
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,
TimeService timeService) |
long |
TargetMigrator.synchronizeData(Cache<Object,Object> cache)
Performs the synchronization of data between source and target
|
long |
TargetMigrator.synchronizeData(Cache<Object,Object> cache,
int readBatch,
int threads)
Performs the synchronization of data between source and target
|
Constructor and Description |
---|
DataContainerRemoveIterator(Cache<K,V> cache) |
DataContainerRemoveIterator(Cache<K,V> cache,
DataContainer<K,V> dataContainer) |
Modifier and Type | Method and Description |
---|---|
default EventLogger |
EventLogger.context(Cache<?,?> cache)
Sets a cache as context of this event log.
|
Modifier and Type | Field and Description |
---|---|
protected Cache<Object,Object> |
BaseBackupReceiver.cache |
protected Cache<K,V> |
AbstractCustomFailurePolicy.cache |
Modifier and Type | Method and Description |
---|---|
Cache |
BaseBackupReceiver.getCache() |
Cache |
BackupReceiver.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,
TimeService timeService,
CommandsFactory commandsFactory) |
void |
XSiteAdminOperations.init(RpcManager rpcManager,
BackupSender backupSender,
Cache cache,
XSiteStateTransferManager stateTransferManager) |
protected static XSiteStatePushCommand |
BaseBackupReceiver.newStatePushCommand(Cache<?,?> cache,
List<XSiteState> stateList) |
Constructor and Description |
---|
BaseBackupReceiver(Cache<Object,Object> cache) |
ClusteredCacheBackupReceiver(Cache<Object,Object> cache) |
LocalCacheBackupReceiver(Cache<Object,Object> cache) |
Copyright © 2018 JBoss, a division of Red Hat. All rights reserved.