Infinispan Distribution 5.2.6.Final-redhat-2

Uses of Interface
org.infinispan.Cache

Packages that use Cache
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.cdi This is the Infinispan CDI module. 
org.infinispan.cdi.interceptor This package provides the partial support of JCACHE (JSR-107). 
org.infinispan.cli.interpreter.session   
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.loaders.jdbc.binary This JDBC CacheStore implementation is optimized for storing binary (non-String) keys in the cache. 
org.infinispan.loaders.jdbc.mixed This is a delegating CacheStore implementation that delegates either to a binary or String based JDBC cache store depending on the key used. 
org.infinispan.loaders.jdbc.stringbased This JDBC CacheStore implementation is optimized for storing String keys in the cache. 
org.infinispan.loaders.remote   
org.infinispan.lucene Lucene Directory implementation which stores the index in Infinispan. 
org.infinispan.lucene.cachestore   
org.infinispan.lucene.locking Lucene's IndexWriter instances are threadsafe but you can have only one open on the index, so when opening an IndexWriter an index-wide lock needs to be acquired. 
org.infinispan.lucene.readlocks Several implementations for a SegmentReadLocker, pick one depending on your use case. 
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.query   
org.infinispan.query.clustered   
org.infinispan.query.clustered.commandworkers   
org.infinispan.query.impl   
org.infinispan.query.impl.massindex   
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.server.hotrod.util   
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.upgrade.hotrod   
org.infinispan.xsite   
 

Uses of Cache in org.infinispan
 

Subinterfaces of Cache in org.infinispan
 interface AdvancedCache<K,V>
          An advanced interface that exposes additional methods not available on Cache.
 

Classes in org.infinispan that implement Cache
 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 Flags.
 

Methods in org.infinispan that return Cache
 Cache<K,V> AbstractDelegatingCache.getDelegate()
           
 

Constructors in org.infinispan with parameters of type Cache
AbstractDelegatingCache(Cache<K,V> cache)
           
 

Uses of Cache in org.infinispan.affinity
 

Methods in org.infinispan.affinity with parameters of type Cache
static
<K,V> KeyAffinityService<K>
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache, Collection<Address> filter, KeyGenerator<K> keyGenerator, Executor ex, int keyBufferSize)
          Same as KeyAffinityServiceFactory.newKeyAffinityService(org.infinispan.Cache, java.util.Collection, KeyGenerator, java.util.concurrent.Executor, int, boolean) with start == true.
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)
          Same as KeyAffinityServiceFactory.newKeyAffinityService(org.infinispan.Cache, java.util.concurrent.Executor, KeyGenerator, int, boolean) with start == true;
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)
          Same as KeyAffinityServiceFactory.newLocalKeyAffinityService(org.infinispan.Cache, KeyGenerator, java.util.concurrent.Executor, int, boolean) with start == true.
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.
 

Constructors in org.infinispan.affinity with parameters of type Cache
KeyAffinityServiceImpl(Executor executor, Cache<? extends K,?> cache, KeyGenerator<? extends K> keyGenerator, int bufferSize, Collection<Address> filter, boolean start)
           
 

Uses of Cache in org.infinispan.atomic
 

Methods in org.infinispan.atomic with parameters of type Cache
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. use AtomicMapLookup.getAtomicMap(org.infinispan.Cache, Object)
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.
 

Uses of Cache in org.infinispan.cdi
 

Methods in org.infinispan.cdi that return Cache
static
<K,V> Cache<K,V>
ContextInputCache.get()
           
 

Methods in org.infinispan.cdi with parameters of type Cache
<T,K,V> void
CDIDistributedTaskLifecycle.onPreExecute(Callable<T> task, Cache<K,V> inputCache)
           
<KIn,VIn,KOut,VOut>
void
CDIMapReduceTaskLifecycle.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper, Cache<KIn,VIn> inputCache)
           
<KOut,VOut>
void
CDIMapReduceTaskLifecycle.onPreExecute(Reducer<KOut,VOut> reducer, Cache<?,?> cache)
           
static
<K,V> void
ContextInputCache.set(Cache<K,V> input)
           
 

Uses of Cache in org.infinispan.cdi.interceptor
 

Methods in org.infinispan.cdi.interceptor that return Cache
<K,V> Cache<K,V>
DefaultCacheResolver.resolveCache(javax.cache.annotation.CacheInvocationContext<? extends Annotation> cacheInvocationContext)
           
<K,V> Cache<K,V>
CacheResolver.resolveCache(javax.cache.annotation.CacheInvocationContext<? extends Annotation> cacheInvocationContext)
          Resolve the Cache to use for this CacheInvocationContext.
 

Uses of Cache in org.infinispan.cli.interpreter.session
 

Methods in org.infinispan.cli.interpreter.session that return Cache
<K,V> Cache<K,V>
SessionImpl.getCache(String cacheName)
           
<K,V> Cache<K,V>
Session.getCache(String cacheName)
          Returns a named cache.
<K,V> Cache<K,V>
SessionImpl.getCurrentCache()
           
<K,V> Cache<K,V>
Session.getCurrentCache()
          Obtains the currently selected cache.
 

Uses of Cache in org.infinispan.commands
 

Methods in org.infinispan.commands with parameters of type Cache
 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)
           
 

Uses of Cache in org.infinispan.commands.read
 

Methods in org.infinispan.commands.read with parameters of type Cache
 void DistributedExecuteCommand.init(Cache<Object,Object> cache)
           
 

Uses of Cache in org.infinispan.container.versioning
 

Methods in org.infinispan.container.versioning with parameters of type Cache
 void SimpleClusteredVersionGenerator.init(Cache<?,?> cache)
           
 

Uses of Cache in org.infinispan.distexec
 

Methods in org.infinispan.distexec with parameters of type Cache
 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.
 

Constructors in org.infinispan.distexec with parameters of type Cache
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.
 

Uses of Cache in org.infinispan.distexec.mapreduce
 

Constructors in org.infinispan.distexec.mapreduce with parameters of type Cache
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.
 

Uses of Cache in org.infinispan.distexec.mapreduce.spi
 

Methods in org.infinispan.distexec.mapreduce.spi with parameters of type Cache
<KIn,VIn,KOut,VOut>
void
MapReduceTaskLifecycleService.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper, Cache<KIn,VIn> inputCache)
           
<KIn,VIn,KOut,VOut>
void
DefaultMapReduceTaskLifecycle.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper, Cache<KIn,VIn> inputCache)
           
<KIn,VIn,KOut,VOut>
void
MapReduceTaskLifecycle.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper, Cache<KIn,VIn> inputCache)
           
<KOut,VOut>
void
MapReduceTaskLifecycleService.onPreExecute(Reducer<KOut,VOut> reducer, Cache<?,?> inputCache)
           
<KOut,VOut>
void
DefaultMapReduceTaskLifecycle.onPreExecute(Reducer<KOut,VOut> reducer, Cache<?,?> inputCache)
           
<KOut,VOut>
void
MapReduceTaskLifecycle.onPreExecute(Reducer<KOut,VOut> reducer, Cache<?,?> inputCache)
           
 

Uses of Cache in org.infinispan.distexec.spi
 

Methods in org.infinispan.distexec.spi with parameters of type Cache
<T,K,V> void
DistributedTaskLifecycleService.onPreExecute(Callable<T> task, Cache<K,V> inputCache)
           
<T,K,V> void
DistributedTaskLifecycle.onPreExecute(Callable<T> task, Cache<K,V> inputDataCache)
           
<T,K,V> void
DefaultDistributedTaskLifecycle.onPreExecute(Callable<T> task, Cache<K,V> inputCache)
           
 

Uses of Cache in org.infinispan.eviction
 

Methods in org.infinispan.eviction with parameters of type Cache
 void EvictionManagerImpl.initialize(ScheduledExecutorService executor, Cache cache, Configuration cfg, DataContainer dataContainer, CacheLoaderManager cacheLoaderManager, CacheNotifier cacheNotifier)
           
 

Uses of Cache in org.infinispan.factories
 

Methods in org.infinispan.factories that return Cache
 Cache<K,V> InternalCacheFactory.createCache(Configuration configuration, GlobalComponentRegistry globalComponentRegistry, String cacheName)
          This implementation clones the configuration passed in before using it.
 

Uses of Cache in org.infinispan.interceptors.base
 

Fields in org.infinispan.interceptors.base declared as Cache
protected  Cache<?,?> BaseCustomInterceptor.cache
           
 

Uses of Cache in org.infinispan.io
 

Fields in org.infinispan.io declared as Cache
protected  Cache<String,byte[]> GridFilesystem.data
           
protected  Cache<String,GridFile.Metadata> GridFilesystem.metadata
           
 

Constructors in org.infinispan.io with parameters of type Cache
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.
 

Uses of Cache in org.infinispan.jmx
 

Methods in org.infinispan.jmx with parameters of type Cache
 void CacheJmxRegistration.initialize(Cache<?,?> cache, GlobalConfiguration globalConfig)
           
 

Uses of Cache in org.infinispan.loaders
 

Fields in org.infinispan.loaders declared as Cache
protected  Cache<Object,Object> AbstractCacheLoader.cache
           
 

Methods in org.infinispan.loaders with parameters of type Cache
 void LockSupportCacheStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 void AbstractCacheLoader.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 void AbstractCacheStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 void CacheLoader.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
          Used to initialize a cache loader.
 

Uses of Cache in org.infinispan.loaders.cluster
 

Methods in org.infinispan.loaders.cluster with parameters of type Cache
 void ClusterCacheLoader.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 

Uses of Cache in org.infinispan.loaders.decorators
 

Methods in org.infinispan.loaders.decorators with parameters of type Cache
 void AbstractDelegatingStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 void AsyncStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 void ChainingCacheStore.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.
 

Constructors in org.infinispan.loaders.decorators with parameters of type Cache
SingletonStore(CacheStore delegate, Cache<Object,Object> cache, SingletonStoreConfig config)
           
 

Uses of Cache in org.infinispan.loaders.file
 

Methods in org.infinispan.loaders.file with parameters of type Cache
 void FileCacheStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 

Uses of Cache in org.infinispan.loaders.jdbc.binary
 

Methods in org.infinispan.loaders.jdbc.binary with parameters of type Cache
 void JdbcBinaryCacheStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 

Uses of Cache in org.infinispan.loaders.jdbc.mixed
 

Methods in org.infinispan.loaders.jdbc.mixed with parameters of type Cache
 void JdbcMixedCacheStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 

Uses of Cache in org.infinispan.loaders.jdbc.stringbased
 

Methods in org.infinispan.loaders.jdbc.stringbased with parameters of type Cache
 void JdbcStringBasedCacheStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 

Uses of Cache in org.infinispan.loaders.remote
 

Methods in org.infinispan.loaders.remote with parameters of type Cache
 void RemoteCacheStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 

Uses of Cache in org.infinispan.lucene
 

Constructors in org.infinispan.lucene with parameters of type Cache
InfinispanDirectory(Cache<?,?> cache)
           
InfinispanDirectory(Cache<?,?> metadataCache, Cache<?,?> chunksCache, Cache<?,?> distLocksCache, String indexName, int chunkSize)
          This constructor assumes that three different caches are being used with specialized configurations for each cache usage
InfinispanDirectory(Cache<?,?> metadataCache, Cache<?,?> chunksCache, Cache<?,?> distLocksCache, String indexName, int chunkSize)
          This constructor assumes that three different caches are being used with specialized configurations for each cache usage
InfinispanDirectory(Cache<?,?> metadataCache, Cache<?,?> chunksCache, Cache<?,?> distLocksCache, String indexName, int chunkSize)
          This constructor assumes that three different caches are being used with specialized configurations for each cache usage
InfinispanDirectory(Cache<?,?> metadataCache, Cache<?,?> chunksCache, String indexName, org.apache.lucene.store.LockFactory lf, int chunkSize, SegmentReadLocker readLocker)
           
InfinispanDirectory(Cache<?,?> metadataCache, Cache<?,?> chunksCache, String indexName, org.apache.lucene.store.LockFactory lf, int chunkSize, SegmentReadLocker readLocker)
           
InfinispanDirectory(Cache<?,?> cache, String indexName)
           
InfinispanDirectory(Cache<?,?> cache, String indexName, int chunkSize, SegmentReadLocker readLocker)
           
 

Uses of Cache in org.infinispan.lucene.cachestore
 

Methods in org.infinispan.lucene.cachestore with parameters of type Cache
 void LuceneCacheLoader.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 

Uses of Cache in org.infinispan.lucene.locking
 

Constructors in org.infinispan.lucene.locking with parameters of type Cache
BaseLockFactory(Cache<?,?> cache, String indexName)
           
TransactionalLockFactory(Cache<?,?> cache, String indexName)
           
 

Uses of Cache in org.infinispan.lucene.readlocks
 

Constructors in org.infinispan.lucene.readlocks with parameters of type Cache
DistributedSegmentReadLocker(Cache<?,?> cache, String indexName)
           
DistributedSegmentReadLocker(Cache<Object,Integer> locksCache, Cache<?,?> chunksCache, Cache<?,?> metadataCache, String indexName)
           
DistributedSegmentReadLocker(Cache<Object,Integer> locksCache, Cache<?,?> chunksCache, Cache<?,?> metadataCache, String indexName)
           
DistributedSegmentReadLocker(Cache<Object,Integer> locksCache, Cache<?,?> chunksCache, Cache<?,?> metadataCache, String indexName)
           
LocalLockMergingSegmentReadLocker(Cache<?,?> locksCache, Cache<?,?> chunksCache, Cache<?,?> metadataCache, String indexName)
          Create a new LocalLockMergingSegmentReadLocker with special purpose caches
LocalLockMergingSegmentReadLocker(Cache<?,?> locksCache, Cache<?,?> chunksCache, Cache<?,?> metadataCache, String indexName)
          Create a new LocalLockMergingSegmentReadLocker with special purpose caches
LocalLockMergingSegmentReadLocker(Cache<?,?> locksCache, Cache<?,?> chunksCache, Cache<?,?> metadataCache, String indexName)
          Create a new LocalLockMergingSegmentReadLocker with special purpose caches
LocalLockMergingSegmentReadLocker(Cache<?,?> cache, String indexName)
          Create a new LocalLockMergingSegmentReadLocker for specified cache and index name.
 

Uses of Cache in org.infinispan.manager
 

Methods in org.infinispan.manager that return Cache
<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)
           
 

Uses of Cache in org.infinispan.marshall
 

Methods in org.infinispan.marshall with parameters of type Cache
 void CacheMarshaller.inject(Cache cache, Configuration cfg, InvocationContextContainer icc, ExternalizerTable extTable, GlobalConfiguration globalCfg)
           
 void VersionAwareMarshaller.inject(Cache cache, Configuration cfg, InvocationContextContainer icc, ExternalizerTable extTable, GlobalConfiguration globalCfg)
           
 

Uses of Cache in org.infinispan.notifications.cachelistener.event
 

Methods in org.infinispan.notifications.cachelistener.event that return Cache
 Cache<K,V> EventImpl.getCache()
           
 Cache<K,V> Event.getCache()
           
 

Methods in org.infinispan.notifications.cachelistener.event with parameters of type Cache
static
<K,V> EventImpl<K,V>
EventImpl.createEvent(Cache<K,V> cache, Event.Type type)
           
 

Uses of Cache in org.infinispan.query
 

Methods in org.infinispan.query that return Cache
 Cache<?,?> CommandInitializer.getCache()
           
 

Methods in org.infinispan.query with parameters of type Cache
static SearchManager Search.getSearchManager(Cache<?,?> cache)
           
 void CommandInitializer.setCache(Cache<?,?> cache)
           
 

Uses of Cache in org.infinispan.query.clustered
 

Methods in org.infinispan.query.clustered with parameters of type Cache
static ClusteredQueryCommand ClusteredQueryCommand.createEagerIterator(org.hibernate.search.query.engine.spi.HSQuery query, Cache<?,?> cache)
           
static ClusteredQueryCommand ClusteredQueryCommand.createLazyIterator(org.hibernate.search.query.engine.spi.HSQuery query, Cache<?,?> cache, UUID id)
           
static ClusteredQueryCommand ClusteredQueryCommand.destroyLazyQuery(Cache<?,?> cache, UUID id)
           
 ClusteredQueryCommandWorker ClusteredQueryCommandType.getCommand(Cache<?,?> cache, org.hibernate.search.query.engine.spi.HSQuery query, UUID lazyQueryId, int docIndex)
           
static ClusteredQueryCommand ClusteredQueryCommand.getResultSize(org.hibernate.search.query.engine.spi.HSQuery query, Cache<?,?> cache)
           
 void ClusteredQueryCommand.initialize(Cache<?,?> localInstance)
           
 QueryResponse ClusteredQueryCommand.perform(Cache<?,?> cache)
           
static ClusteredQueryCommand ClusteredQueryCommand.retrieveKeyFromLazyQuery(Cache<?,?> cache, UUID id, int docIndex)
           
 void ClusteredQueryCommand.setCache(Cache<?,?> cache)
           
 

Uses of Cache in org.infinispan.query.clustered.commandworkers
 

Fields in org.infinispan.query.clustered.commandworkers declared as Cache
protected  Cache<?,?> ClusteredQueryCommandWorker.cache
           
 

Methods in org.infinispan.query.clustered.commandworkers with parameters of type Cache
static Object QueryExtractorUtil.extractKey(org.hibernate.search.query.engine.spi.DocumentExtractor extractor, Cache<?,?> cache, KeyTransformationHandler keyTransformationHandler, int docIndex)
           
 void ClusteredQueryCommandWorker.init(Cache<?,?> cache, org.hibernate.search.query.engine.spi.HSQuery query, UUID lazyQueryId, int docIndex)
           
 

Uses of Cache in org.infinispan.query.impl
 

Methods in org.infinispan.query.impl with parameters of type Cache
static
<T> T
ComponentRegistryUtils.getComponent(Cache<?,?> cache, Class<T> class1)
           
static
<T> T
ComponentRegistryUtils.getComponent(Cache<?,?> cache, Class<T> class1, String name)
           
static QueryInterceptor ComponentRegistryUtils.getQueryInterceptor(Cache<?,?> cache)
           
 

Uses of Cache in org.infinispan.query.impl.massindex
 

Methods in org.infinispan.query.impl.massindex with parameters of type Cache
 void IndexingMapper.initialize(Cache inputCache)
           
 void IndexingReducer.initialize(Cache<?,?> inputCache)
           
<KIn,VIn,KOut,VOut>
void
MapReduceInitializer.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper, Cache<KIn,VIn> inputCache)
           
<KOut,VOut>
void
MapReduceInitializer.onPreExecute(Reducer<KOut,VOut> reducer, Cache<?,?> inputCache)
           
 

Uses of Cache in org.infinispan.remoting
 

Methods in org.infinispan.remoting with parameters of type Cache
 void ReplicationQueueImpl.injectDependencies(ScheduledExecutorService executor, RpcManager rpcManager, Configuration configuration, CommandsFactory commandsFactory, Cache cache)
           
 

Uses of Cache in org.infinispan.remoting.rpc
 

Methods in org.infinispan.remoting.rpc with parameters of type Cache
 void RpcManagerImpl.injectDependencies(Transport t, Cache cache, Configuration cfg, ReplicationQueue replicationQueue, CommandsFactory cf, ExecutorService e, LocalTopologyManager localTopologyManager, StateTransferManager stateTransferManager, GlobalConfiguration globalCfg)
           
 

Uses of Cache in org.infinispan.server.hotrod.util
 

Methods in org.infinispan.server.hotrod.util with parameters of type Cache
static Set<ByteArrayKey> BulkUtil.getAllKeys(Cache<ByteArrayKey,org.infinispan.server.core.CacheValue> cache, int scope)
           
 

Uses of Cache in org.infinispan.statetransfer
 

Methods in org.infinispan.statetransfer with parameters of type Cache
 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)
           
 

Uses of Cache in org.infinispan.transaction
 

Methods in org.infinispan.transaction with parameters of type Cache
 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)
           
 

Uses of Cache in org.infinispan.transaction.xa
 

Methods in org.infinispan.transaction.xa with parameters of type Cache
 void XaTransactionTable.init(RecoveryManager recoveryManager, Cache cache)
           
 

Uses of Cache in org.infinispan.upgrade
 

Methods in org.infinispan.upgrade with parameters of type Cache
 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
 

Uses of Cache in org.infinispan.upgrade.hotrod
 

Methods in org.infinispan.upgrade.hotrod with parameters of type Cache
 void HotRodTargetMigrator.disconnectSource(Cache<Object,Object> cache)
           
 long HotRodTargetMigrator.synchronizeData(Cache<Object,Object> cache)
           
 

Uses of Cache in org.infinispan.xsite
 

Fields in org.infinispan.xsite declared as Cache
protected  Cache<K,V> AbstractCustomFailurePolicy.cache
           
 

Methods in org.infinispan.xsite that return Cache
 Cache BackupReceiver.getCache()
           
 Cache BackupReceiverImpl.getCache()
           
 

Methods in org.infinispan.xsite with parameters of type Cache
 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)
           
 

Constructors in org.infinispan.xsite with parameters of type Cache
BackupReceiverImpl(Cache cache)
           
 


Infinispan Distribution 5.2.6.Final-redhat-2

Copyright © 2013 JBoss, a division of Red Hat. All Rights Reserved.