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 |
---|---|
Cache |
Updatable.getCache() |
Modifier and Type | Method and Description |
---|---|
static AtomicObjectFactory |
AtomicObjectFactory.forCache(Cache<?,?> 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> 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.
|
void |
Updatable.setCache(Cache cache) |
Constructor and Description |
---|
AtomicObjectFactory(Cache<?,?> c)
Return an AtomicObjectFactory built on top of cache c.
|
AtomicObjectFactory(Cache<?,?> c,
int m)
Returns an object factory built on top of cache c with a bounded amount m of
containers in it.
|
Constructor and Description |
---|
Container(Cache c,
Class cl,
Object k,
boolean readOptimization,
boolean forceNew,
List<String> methods,
Object... initArgs) |
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 |
---|---|
static <K,V> Cache<K,V> |
ContextInputCache.get() |
Modifier and Type | Method and Description |
---|---|
<T,K,V> void |
DelegatingDistributedTaskLifecycle.onPreExecute(Callable<T> task,
Cache<K,V> inputDataCache) |
<KIn,VIn,KOut,VOut> |
DelegatingMapReduceTaskLifecycle.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper,
Cache<KIn,VIn> inputCache) |
<KOut,VOut> |
DelegatingMapReduceTaskLifecycle.onPreExecute(Reducer<KOut,VOut> reducer,
Cache<?,?> cache) |
static <K,V> void |
ContextInputCache.set(Cache<K,V> input) |
Modifier and Type | Method and Description |
---|---|
Metadata |
AbstractCodec.encodeMetadata(Cache<?,?> cache,
Long expires,
Long maxIdle) |
Metadata |
Codec.encodeMetadata(Cache<?,?> cache,
Long expires,
Long maxIdle) |
protected EntryVersion |
AbstractCodec.generateVersion(Cache<?,?> cache) |
Modifier and Type | Method and Description |
---|---|
<K,V> Cache<K,V> |
Session.getCache(String cacheName)
Returns a named cache.
|
<K,V> Cache<K,V> |
SessionImpl.getCache(String cacheName) |
<K,V> Cache<K,V> |
Session.getCurrentCache()
Obtains the currently selected cache.
|
<K,V> Cache<K,V> |
SessionImpl.getCurrentCache() |
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 |
NumericVersionGenerator.init(Cache<?,?> cache) |
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.
|
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 |
DefaultDistributedTaskLifecycle.onPreExecute(Callable<T> task,
Cache<K,V> inputCache) |
<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) |
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(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,?> |
TransactionAwareCloseableIterable.cache |
protected Cache<K,V> |
LocalEntryRetriever.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) |
Modifier and Type | Method and Description |
---|---|
void |
CacheJmxRegistration.initialize(Cache<?,?> cache,
GlobalConfiguration globalConfig) |
Modifier and Type | Method and Description |
---|---|
static BuildContext |
DirectoryBuilder.newDirectoryInstance(Cache<?,?> metadataCache,
Cache<?,?> chunksCache,
Cache<?,?> distLocksCache,
String indexName)
Starting point to create a Directory instance.
|
static BuildContext |
DirectoryBuilder.newDirectoryInstance(Cache<?,?> metadataCache,
Cache<?,?> chunksCache,
Cache<?,?> distLocksCache,
String indexName)
Starting point to create a Directory instance.
|
static BuildContext |
DirectoryBuilder.newDirectoryInstance(Cache<?,?> metadataCache,
Cache<?,?> chunksCache,
Cache<?,?> distLocksCache,
String indexName)
Starting point to create a Directory instance.
|
Modifier and Type | Method and Description |
---|---|
Cache |
DirectoryExtensions.getDataCache() |
Cache |
DirectoryExtensions.getMetadataCache() |
Constructor and Description |
---|
DirectoryBuilderImpl(Cache<?,?> metadataCache,
Cache<?,?> chunksCache,
Cache<?,?> distLocksCache,
String indexName) |
DirectoryBuilderImpl(Cache<?,?> metadataCache,
Cache<?,?> chunksCache,
Cache<?,?> distLocksCache,
String indexName) |
DirectoryBuilderImpl(Cache<?,?> metadataCache,
Cache<?,?> chunksCache,
Cache<?,?> distLocksCache,
String indexName) |
Constructor and Description |
---|
DistributedSegmentReadLocker(Cache<?,?> cache,
String indexName,
int affinitySegmentId) |
DistributedSegmentReadLocker(Cache<Object,Integer> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
int affinitySegmentId) |
DistributedSegmentReadLocker(Cache<Object,Integer> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
int affinitySegmentId) |
DistributedSegmentReadLocker(Cache<Object,Integer> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
int affinitySegmentId) |
DistributedSegmentReadLocker(Cache<Object,Integer> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
int affinitySegmentId,
boolean forceSynchronousDeletes) |
DistributedSegmentReadLocker(Cache<Object,Integer> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
int affinitySegmentId,
boolean forceSynchronousDeletes) |
DistributedSegmentReadLocker(Cache<Object,Integer> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
int affinitySegmentId,
boolean forceSynchronousDeletes) |
LocalLockMergingSegmentReadLocker(Cache<?,?> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
boolean forceSynchronousDeletes,
int affinitySegmentId) |
LocalLockMergingSegmentReadLocker(Cache<?,?> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
boolean forceSynchronousDeletes,
int affinitySegmentId) |
LocalLockMergingSegmentReadLocker(Cache<?,?> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
boolean forceSynchronousDeletes,
int affinitySegmentId) |
LocalLockMergingSegmentReadLocker(Cache<?,?> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
int affinitySegmentId)
Create a new LocalLockMergingSegmentReadLocker with special purpose caches
|
LocalLockMergingSegmentReadLocker(Cache<?,?> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
int affinitySegmentId)
Create a new LocalLockMergingSegmentReadLocker with special purpose caches
|
LocalLockMergingSegmentReadLocker(Cache<?,?> locksCache,
Cache<?,?> chunksCache,
Cache<?,?> metadataCache,
String indexName,
int affinitySegmentId)
Create a new LocalLockMergingSegmentReadLocker with special purpose caches
|
LocalLockMergingSegmentReadLocker(Cache<?,?> cache,
String indexName,
int affinitySegmentId)
Create a new LocalLockMergingSegmentReadLocker for specified cache and index name.
|
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 |
ClusterListenerReplicateCallable.setEnvironment(Cache<K,V> cache,
Set<K> inputKeys) |
void |
ClusterEventCallable.setEnvironment(Cache<K,V> cache,
Set<K> inputKeys) |
void |
ClusterListenerRemoveCallable.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,
StreamingMarshaller marshaller,
TimeService timeService,
ByteBufferFactory byteBufferFactory,
MarshalledEntryFactory mef) |
Modifier and Type | Method and Description |
---|---|
void |
CLInterfaceTargetMigrator.disconnectSource(Cache<Object,Object> cache) |
long |
CLInterfaceTargetMigrator.synchronizeData(Cache<Object,Object> cache) |
long |
CLInterfaceTargetMigrator.synchronizeData(Cache<Object,Object> cache,
int readBatch,
int threads) |
Modifier and Type | Method and Description |
---|---|
Cache |
InitialisationContextDelegate.getCache() |
Modifier and Type | Method and Description |
---|---|
void |
HotRodTargetMigrator.disconnectSource(Cache<Object,Object> cache) |
void |
MigrationTask.setEnvironment(Cache<Object,Object> cache,
Set<Object> inputKeys) |
long |
HotRodTargetMigrator.synchronizeData(Cache<Object,Object> cache) |
long |
HotRodTargetMigrator.synchronizeData(Cache<Object,Object> cache,
int readBatch,
int threads) |
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 |
OpHandler.handleOp(JsonObject opPayload,
Cache<Object,Object> cache,
io.netty.channel.ChannelHandlerContext ctx)
Handle a websocket channel operation.
|
static void |
ChannelUtils.pushCacheValue(String key,
Cache<Object,Object> cache,
io.netty.channel.ChannelHandlerContext ctx)
Push a cache entry value out onto the websocket channel (to the browser).
|
Constructor and Description |
---|
WebSocketServerHandler(CacheContainer cacheContainer,
Map<String,OpHandler> operationHandlers,
Map<String,Cache<Object,Object>> startedCaches,
org.infinispan.server.core.CacheIgnoreAware cacheIgnoreAware) |
Modifier and Type | Method and Description |
---|---|
void |
GetHandler.handleOp(JsonObject opPayload,
Cache<Object,Object> cache,
io.netty.channel.ChannelHandlerContext ctx) |
void |
NotifyHandler.handleOp(JsonObject opPayload,
Cache<Object,Object> cache,
io.netty.channel.ChannelHandlerContext ctx) |
void |
PutHandler.handleOp(JsonObject opPayload,
Cache<Object,Object> cache,
io.netty.channel.ChannelHandlerContext ctx) |
void |
RemoveHandler.handleOp(JsonObject opPayload,
Cache<Object,Object> cache,
io.netty.channel.ChannelHandlerContext ctx) |
Modifier and Type | Method and Description |
---|---|
Cache<K,V> |
InfinispanDefaultCacheFactoryBean.getObject() |
Modifier and Type | Method and Description |
---|---|
Class<? extends Cache> |
InfinispanDefaultCacheFactoryBean.getObjectType() |
Modifier and Type | Method and Description |
---|---|
Cache<K,V> |
InfinispanNamedEmbeddedCacheFactoryBean.getObject() |
Modifier and Type | Method and Description |
---|---|
Class<? extends Cache> |
InfinispanNamedEmbeddedCacheFactoryBean.getObjectType() |
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 |
---|---|
static StreamSummaryContainer |
StreamSummaryContainer.getOrCreateStreamLibContainer(Cache cache) |
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(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 |
---|---|
Optional<Cache<?,?>> |
TaskContext.getCache()
The default cache.
|
Modifier and Type | Method and Description |
---|---|
TaskContext |
TaskContext.cache(Cache<?,?> cache)
The cache against which this task will be executed.
|
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 |
---|---|
Cache<?,?> |
TreeCache.getCache() |
Modifier and Type | Method and Description |
---|---|
<K,V> TreeCache<K,V> |
TreeCacheFactory.createTreeCache(Cache<K,V> cache)
Creates a TreeCache instance by taking in a
Cache as a parameter |
Modifier and Type | Method and Description |
---|---|
Cache<?,?> |
TreeCacheImpl.getCache() |
Constructor and Description |
---|
TreeCacheImpl(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 © 2024 JBoss, a division of Red Hat. All rights reserved.