|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
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.interceptor | This package provides the partial support of JCACHE (JSR-107). |
org.infinispan.commands | Commands that operate on the cache, either locally or remotely. |
org.infinispan.commands.read | Commands that read data from the cache. |
org.infinispan.container.versioning | |
org.infinispan.demo | Classes, programs and applications that help demonstrate how Infinispan can be used. |
org.infinispan.distexec | |
org.infinispan.distexec.mapreduce | |
org.infinispan.ec2demo | |
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.bdbje | This package contains a CacheStore implementation based on
Oracle's BDBJE storage engine. |
org.infinispan.loaders.cassandra | This package contains a CacheStore implementation based on
persisting to Apache Cassandra |
org.infinispan.loaders.cloud | This package contains a CacheStore implementation based on
JClouds, which in turn is an abstraction layer to store data on cloud infrastructure providers
such as Amazon's S3,
RackspaceCloud's CloudFiles,
Microsoft's Windows Azure Blob Storage API, and others. |
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.jdbm | This package contains a CacheStore implementation based on
persisting to JDBM. |
org.infinispan.loaders.remote | |
org.infinispan.lucene | Lucene Directory implementation which stores the index in Infinispan. |
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.lucenedemo | |
org.infinispan.manager | Cache manager package |
org.infinispan.nearcache.jms | |
org.infinispan.notifications.cachelistener.event | |
org.infinispan.query | |
org.infinispan.query.clustered | |
org.infinispan.query.clustered.commandworkers | |
org.infinispan.query.impl | |
org.infinispan.remoting | Remote communication between cache instances. |
org.infinispan.server.websocket | |
org.infinispan.server.websocket.handlers | |
org.infinispan.spring.support | |
org.infinispan.spring.support.embedded | |
org.infinispan.tree | This package contains the TreeCache. |
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 |
ClassLoaderSpecfiedCache<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. |
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
|
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
|
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
|
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
|
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
|
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
|
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
|
AtomicMapLookup.getAtomicMap(Cache<MK,?> cache,
MK key)
Retrieves an atomic map from a given cache, stored under a given key. |
|
static
|
AtomicMapLookup.getAtomicMap(Cache<MK,?> cache,
MK key,
boolean createIfAbsent)
Retrieves an atomic map from a given cache, stored under a given key. |
|
static
|
AtomicMapLookup.getAtomicMap(Cache<MK,?> cache,
MK key,
FlagContainer flagContainer)
Deprecated. use AtomicMapLookup.getAtomicMap(org.infinispan.Cache, Object) |
|
static
|
AtomicMapLookup.getFineGrainedAtomicMap(Cache<MK,?> cache,
MK key)
Retrieves a fine grained atomic map from a given cache, stored under a given key. |
|
static
|
AtomicMapLookup.getFineGrainedAtomicMap(Cache<MK,?> cache,
MK key,
boolean createIfAbsent)
Retrieves an atomic map from a given cache, stored under a given key. |
|
static
|
AtomicMapLookup.getReadOnlyAtomicMap(Cache<MK,?> cache,
MK key)
Retrieves an atomic map from a given cache, stored under a given key, for reading only. |
|
static
|
AtomicHashMap.newInstance(Cache<Object,Object> cache,
Object cacheKey)
Construction only allowed through this factory method. |
|
static
|
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.interceptor |
---|
Methods in org.infinispan.cdi.interceptor that return Cache | ||
---|---|---|
|
DefaultCacheResolver.resolveCache(javax.cache.annotation.CacheInvocationContext<? extends Annotation> cacheInvocationContext)
|
|
|
CacheResolver.resolveCache(javax.cache.annotation.CacheInvocationContext<? extends Annotation> cacheInvocationContext)
Resolve the Cache to use for this CacheInvocationContext . |
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,
StateTransferManager stateTransferManager,
LockManager lockManager,
InternalEntryFactory entryFactory)
|
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,
Transport transport)
|
Uses of Cache in org.infinispan.demo |
---|
Methods in org.infinispan.demo that return Cache | |
---|---|
protected Cache<String,String> |
Demo.startCache()
|
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 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. |
Uses of Cache in org.infinispan.ec2demo |
---|
Methods in org.infinispan.ec2demo that return Cache | |
---|---|
Cache<String,Nucleotide_Protein_Element> |
ProteinCache.getCache()
|
Cache<String,Nucleotide_Protein_Element> |
NucleotideCache.getCache()
|
Cache<String,Influenza_N_P_CR_Element> |
InfluenzaVirusCache.getCache()
|
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 |
CacheLoader.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m)
Used to initialize a cache loader. |
void |
AbstractCacheStore.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m)
|
void |
AbstractCacheLoader.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m)
|
Uses of Cache in org.infinispan.loaders.bdbje |
---|
Methods in org.infinispan.loaders.bdbje with parameters of type Cache | |
---|---|
void |
BdbjeCacheStore.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m)
Used to initialize a cache loader. |
Uses of Cache in org.infinispan.loaders.cassandra |
---|
Methods in org.infinispan.loaders.cassandra with parameters of type Cache | |
---|---|
void |
CassandraCacheStore.init(CacheLoaderConfig clc,
Cache<?,?> cache,
StreamingMarshaller m)
|
Uses of Cache in org.infinispan.loaders.cloud |
---|
Methods in org.infinispan.loaders.cloud with parameters of type Cache | |
---|---|
void |
CloudCacheStore.init(CacheLoaderConfig cfg,
Cache<?,?> cache,
StreamingMarshaller m)
|
void |
CloudCacheStore.init(CacheLoaderConfig cfg,
Cache<?,?> cache,
StreamingMarshaller m,
org.jclouds.blobstore.BlobStoreContext ctx,
org.jclouds.blobstore.BlobStore blobStore,
org.jclouds.blobstore.AsyncBlobStore asyncBlobStore,
boolean constructInternalBlobstores)
|
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 |
ChainingCacheStore.init(CacheLoaderConfig config,
Cache<?,?> cache,
StreamingMarshaller m)
|
void |
AsyncStore.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. |
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.jdbm |
---|
Methods in org.infinispan.loaders.jdbm with parameters of type Cache | |
---|---|
void |
JdbmCacheStore.init(CacheLoaderConfig clc,
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.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.lucenedemo |
---|
Constructors in org.infinispan.lucenedemo with parameters of type Cache | |
---|---|
DemoActions(InfinispanDirectory index,
Cache<?,?> cache)
|
|
DemoDriver(InfinispanDirectory infinispanDirectory,
Cache<?,?> cache)
|
Uses of Cache in org.infinispan.manager |
---|
Methods in org.infinispan.manager that return Cache | ||
---|---|---|
|
DefaultCacheManager.getCache()
Retrieves the default cache associated with this cache manager. |
|
|
CacheContainer.getCache()
This method overrides the underlying CacheContainer.getCache() ,
to return a Cache instead of a BasicCache |
|
|
AbstractDelegatingEmbeddedCacheManager.getCache()
|
|
|
DefaultCacheManager.getCache(String cacheName)
Retrieves a named cache from the system. |
|
|
CacheContainer.getCache(String cacheName)
This method overrides the underlying CacheContainer.getCache(String) ,
to return a Cache instead of a BasicCache |
|
|
AbstractDelegatingEmbeddedCacheManager.getCache(String cacheName)
|
|
|
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. |
|
|
DefaultCacheManager.getCache(String cacheName,
boolean createIfAbsent)
|
|
|
AbstractDelegatingEmbeddedCacheManager.getCache(String cacheName,
boolean createIfAbsent)
|
Uses of Cache in org.infinispan.nearcache.jms |
---|
Constructors in org.infinispan.nearcache.jms with parameters of type Cache | |
---|---|
RemoteEventListener(Cache<Object,Object> cache,
StreamingMarshaller marshaller)
|
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
|
EventImpl.createEvent(Cache<K,V> cache,
Event.Type type)
|
|
void |
EventImpl.setCache(Cache<K,V> cache)
|
Uses of Cache in org.infinispan.query |
---|
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)
|
void |
ClusteredQueryCommand.injectComponents(Cache<?,?> cache)
|
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
|
ComponentRegistryUtils.getComponent(Cache<?,?> cache,
Class<T> class1)
|
Constructors in org.infinispan.query.impl with parameters of type Cache | |
---|---|
EntityLoader(Cache<?,?> cache,
KeyTransformationHandler keyTransformationHandler)
|
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.server.websocket |
---|
Methods in org.infinispan.server.websocket with parameters of type Cache | |
---|---|
void |
OpHandler.handleOp(org.json.JSONObject opPayload,
Cache<Object,Object> cache,
org.jboss.netty.channel.ChannelHandlerContext ctx)
Handle a websocket channel operation. |
static void |
ChannelUtils.pushCacheValue(String key,
Cache<Object,Object> cache,
org.jboss.netty.channel.ChannelHandlerContext ctx)
Push a cache entry value out onto the websocket channel (to the browser). |
Constructor parameters in org.infinispan.server.websocket with type arguments of type Cache | |
---|---|
WebSocketServerHandler(CacheContainer cacheContainer,
Map<String,OpHandler> operationHandlers,
Map<String,Cache> startedCaches)
|
Uses of Cache in org.infinispan.server.websocket.handlers |
---|
Methods in org.infinispan.server.websocket.handlers with parameters of type Cache | |
---|---|
void |
RemoveHandler.handleOp(org.json.JSONObject opPayload,
Cache<Object,Object> cache,
org.jboss.netty.channel.ChannelHandlerContext ctx)
|
void |
PutHandler.handleOp(org.json.JSONObject opPayload,
Cache<Object,Object> cache,
org.jboss.netty.channel.ChannelHandlerContext ctx)
|
void |
NotifyHandler.handleOp(org.json.JSONObject opPayload,
Cache<Object,Object> cache,
org.jboss.netty.channel.ChannelHandlerContext ctx)
|
void |
GetHandler.handleOp(org.json.JSONObject opPayload,
Cache<Object,Object> cache,
org.jboss.netty.channel.ChannelHandlerContext ctx)
|
Uses of Cache in org.infinispan.spring.support |
---|
Methods in org.infinispan.spring.support that return Cache | |
---|---|
Cache<K,V> |
InfinispanDefaultCacheFactoryBean.getObject()
|
Methods in org.infinispan.spring.support that return types with arguments of type Cache | |
---|---|
Class<? extends Cache> |
InfinispanDefaultCacheFactoryBean.getObjectType()
|
Uses of Cache in org.infinispan.spring.support.embedded |
---|
Methods in org.infinispan.spring.support.embedded that return Cache | |
---|---|
Cache<K,V> |
InfinispanNamedEmbeddedCacheFactoryBean.getObject()
|
Methods in org.infinispan.spring.support.embedded that return types with arguments of type Cache | |
---|---|
Class<? extends Cache> |
InfinispanNamedEmbeddedCacheFactoryBean.getObjectType()
|
Uses of Cache in org.infinispan.tree |
---|
Methods in org.infinispan.tree that return Cache | |
---|---|
Cache<?,?> |
TreeCacheImpl.getCache()
|
Cache<?,?> |
TreeCache.getCache()
|
Methods in org.infinispan.tree with parameters of type Cache | ||
---|---|---|
|
TreeCacheFactory.createTreeCache(Cache<K,V> cache)
Creates a TreeCache instance by taking in a Cache as a parameter |
Constructors in org.infinispan.tree with parameters of type Cache | |
---|---|
TreeCacheImpl(Cache<?,?> cache)
|
|
--> |