Package | Description |
---|---|
org.infinispan |
This is the core of Infinispan, a distributed, transactional, highly scalable data grid
platform.
|
org.infinispan.affinity | |
org.infinispan.atomic |
This package contains the
AtomicMap interfaces and API that Infinispan exposes as building
blocks in creating other public interfaces such as the Tree API. |
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.commands.read | |
org.infinispan.container.versioning | |
org.infinispan.distexec | |
org.infinispan.distexec.mapreduce | |
org.infinispan.distexec.mapreduce.spi | |
org.infinispan.distexec.spi | |
org.infinispan.eviction |
Classes related to eviction.
|
org.infinispan.factories |
Factories are internal components used to create other components based on a cache's
configuration.
|
org.infinispan.interceptors.base |
Base interceptors containing common, reusable behavior.
|
org.infinispan.io |
Provides Infinispan-specific input and output streams, buffers and related utilities.
|
org.infinispan.jmx |
Helpers that allow easy exposure of attributes and operations via JMX.
|
org.infinispan.lucene |
Lucene Directory implementation which stores the index in Infinispan.
|
org.infinispan.lucene.directory | |
org.infinispan.lucene.impl | |
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.core | |
org.infinispan.notifications.cachelistener.event | |
org.infinispan.persistence |
This package contains stores, which are used for overflow or persistence.
|
org.infinispan.persistence.cli.upgrade | |
org.infinispan.persistence.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.persistence.spi | |
org.infinispan.persistence.support | |
org.infinispan.query | |
org.infinispan.query.backend | |
org.infinispan.query.clustered | |
org.infinispan.query.clustered.commandworkers | |
org.infinispan.query.impl | |
org.infinispan.query.impl.massindex | |
org.infinispan.query.spi | |
org.infinispan.remoting |
Remote communication between cache instances.
|
org.infinispan.remoting.rpc |
Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances.
|
org.infinispan.statetransfer |
Transfer of state to new caches in a cluster.
|
org.infinispan.tasks | |
org.infinispan.transaction |
JTA transaction support.
|
org.infinispan.transaction.xa |
XA transaction support.
|
org.infinispan.upgrade | |
org.infinispan.xsite |
Modifier and Type | Interface and Description |
---|---|
interface |
AdvancedCache<K,V>
An advanced interface that exposes additional methods not available on
Cache . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDelegatingAdvancedCache<K,V>
Similar to
AbstractDelegatingCache , but for AdvancedCache . |
class |
AbstractDelegatingCache<K,V>
This is a convenient base class for implementing a cache delegate.
|
class |
CacheImpl<K,V> |
class |
DecoratedCache<K,V>
A decorator to a cache, which can be built with a specific
ClassLoader and a set of Flag s. |
Modifier and Type | Method and Description |
---|---|
Cache<K,V> |
AbstractDelegatingCache.getDelegate() |
Constructor and Description |
---|
AbstractDelegatingCache(Cache<K,V> cache) |
Modifier and Type | Method and Description |
---|---|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache,
Collection<Address> filter,
KeyGenerator<K> keyGenerator,
Executor ex,
int keyBufferSize)
|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache,
Collection<Address> filter,
KeyGenerator<K> keyGenerator,
Executor ex,
int keyBufferSize,
boolean start)
Creates a service that would only generate keys for addresses specified in filter.
|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache,
Executor ex,
KeyGenerator<K> keyGenerator,
int keyBufferSize)
|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newKeyAffinityService(Cache<K,V> cache,
Executor ex,
KeyGenerator<K> keyGenerator,
int keyBufferSize,
boolean start)
Creates an
KeyAffinityService instance that generates keys mapped to all addresses
in the cluster. |
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newLocalKeyAffinityService(Cache<K,V> cache,
KeyGenerator<K> keyGenerator,
Executor ex,
int keyBufferSize)
|
static <K,V> KeyAffinityService<K> |
KeyAffinityServiceFactory.newLocalKeyAffinityService(Cache<K,V> cache,
KeyGenerator<K> keyGenerator,
Executor ex,
int keyBufferSize,
boolean start)
Created an service that only generates keys for the local address.
|
Constructor and Description |
---|
KeyAffinityServiceImpl(Executor executor,
Cache<? extends K,?> cache,
KeyGenerator<? extends K> keyGenerator,
int bufferSize,
Collection<Address> filter,
boolean start) |
Modifier and Type | Method and Description |
---|---|
static <MK,K,V> AtomicMap<K,V> |
AtomicMapLookup.getAtomicMap(Cache<MK,?> cache,
MK key)
Retrieves an atomic map from a given cache, stored under a given key.
|
static <MK,K,V> AtomicMap<K,V> |
AtomicMapLookup.getAtomicMap(Cache<MK,?> cache,
MK key,
boolean createIfAbsent)
Retrieves an atomic map from a given cache, stored under a given key.
|
static <MK,K,V> FineGrainedAtomicMap<K,V> |
AtomicMapLookup.getFineGrainedAtomicMap(Cache<MK,?> cache,
MK key)
Retrieves a fine grained atomic map from a given cache, stored under a given key.
|
static <MK,K,V> FineGrainedAtomicMap<K,V> |
AtomicMapLookup.getFineGrainedAtomicMap(Cache<MK,?> cache,
MK key,
boolean createIfAbsent)
Retrieves an atomic map from a given cache, stored under a given key.
|
static <MK,K,V> Map<K,V> |
AtomicMapLookup.getReadOnlyAtomicMap(Cache<MK,?> cache,
MK key)
Retrieves an atomic map from a given cache, stored under a given key, for reading only.
|
static <K,V> AtomicHashMap<K,V> |
AtomicHashMap.newInstance(Cache<Object,Object> cache,
Object cacheKey)
Construction only allowed through this factory method.
|
static <MK> void |
AtomicMapLookup.removeAtomicMap(Cache<MK,?> cache,
MK key)
Removes the atomic map associated with the given key from the underlying cache.
|
Modifier and Type | Method and Description |
---|---|
void |
CommandsFactoryImpl.setupDependencies(DataContainer container,
CacheNotifier notifier,
Cache<Object,Object> cache,
InterceptorChain interceptorChain,
DistributionManager distributionManager,
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) |
Modifier and Type | Method and Description |
---|---|
void |
DistributedExecuteCommand.init(Cache<Object,Object> cache) |
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.
|
Constructor and Description |
---|
MapReduceTask(Cache<KIn,VIn> masterCacheNode)
Create a new MapReduceTask given a master cache node.
|
MapReduceTask(Cache<KIn,VIn> masterCacheNode,
boolean distributeReducePhase)
Create a new MapReduceTask given a master cache node.
|
MapReduceTask(Cache<KIn,VIn> masterCacheNode,
boolean distributeReducePhase,
boolean useIntermediateSharedCache)
Create a new MapReduceTask given a master cache node.
|
Modifier and Type | Method and Description |
---|---|
<KIn,VIn,KOut,VOut> |
MapReduceTaskLifecycleService.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper,
Cache<KIn,VIn> inputCache) |
<KIn,VIn,KOut,VOut> |
MapReduceTaskLifecycle.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper,
Cache<KIn,VIn> inputCache) |
<KIn,VIn,KOut,VOut> |
DefaultMapReduceTaskLifecycle.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper,
Cache<KIn,VIn> inputCache) |
<KOut,VOut> |
MapReduceTaskLifecycleService.onPreExecute(Reducer<KOut,VOut> reducer,
Cache<?,?> inputCache) |
<KOut,VOut> |
MapReduceTaskLifecycle.onPreExecute(Reducer<KOut,VOut> reducer,
Cache<?,?> inputCache) |
<KOut,VOut> |
DefaultMapReduceTaskLifecycle.onPreExecute(Reducer<KOut,VOut> reducer,
Cache<?,?> inputCache) |
Modifier and Type | Method and Description |
---|---|
<T,K,V> void |
DistributedTaskLifecycleService.onPreExecute(Callable<T> task,
Cache<K,V> inputCache) |
<T,K,V> void |
DefaultDistributedTaskLifecycle.onPreExecute(Callable<T> task,
Cache<K,V> inputCache) |
<T,K,V> void |
DistributedTaskLifecycle.onPreExecute(Callable<T> task,
Cache<K,V> inputDataCache) |
Modifier and Type | Method and Description |
---|---|
void |
EvictionManagerImpl.initialize(ScheduledExecutorService executor,
Cache cache,
Configuration cfg,
DataContainer dataContainer,
PersistenceManager persistenceManager,
CacheNotifier 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 | Field and Description |
---|---|
protected Cache<?,?> |
BaseCustomInterceptor.cache |
Modifier and Type | Field and Description |
---|---|
protected Cache<String,byte[]> |
GridFilesystem.data |
protected Cache<String,GridFile.Metadata> |
GridFilesystem.metadata |
Constructor and Description |
---|
GridFilesystem(Cache<String,byte[]> data,
Cache<String,GridFile.Metadata> metadata) |
GridFilesystem(Cache<String,byte[]> data,
Cache<String,GridFile.Metadata> metadata) |
GridFilesystem(Cache<String,byte[]> data,
Cache<String,GridFile.Metadata> metadata,
int defaultChunkSize)
Creates an instance.
|
GridFilesystem(Cache<String,byte[]> data,
Cache<String,GridFile.Metadata> metadata,
int defaultChunkSize)
Creates an instance.
|
Modifier and Type | Method and Description |
---|---|
void |
CacheJmxRegistration.initialize(Cache<?,?> cache,
GlobalConfiguration globalConfig) |
Constructor and Description |
---|
InfinispanDirectory(Cache<?,?> cache)
Deprecated.
|
InfinispanDirectory(Cache<?,?> metadataCache,
Cache<?,?> chunksCache,
Cache<?,?> distLocksCache,
String indexName,
int chunkSize)
Deprecated.
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)
Deprecated.
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)
Deprecated.
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)
Deprecated.
|
InfinispanDirectory(Cache<?,?> metadataCache,
Cache<?,?> chunksCache,
String indexName,
org.apache.lucene.store.LockFactory lf,
int chunkSize,
SegmentReadLocker readLocker)
Deprecated.
|
InfinispanDirectory(Cache<?,?> cache,
String indexName)
Deprecated.
|
InfinispanDirectory(Cache<?,?> cache,
String indexName,
int chunkSize,
SegmentReadLocker readLocker)
Deprecated.
|
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.
|
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 |
---|
BaseLockFactory(Cache<?,?> cache,
String indexName) |
TransactionalLockFactory(Cache<?,?> cache,
String indexName) |
Constructor and Description |
---|
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.
|
Modifier and Type | Method and Description |
---|---|
<K,V> Cache<K,V> |
AbstractDelegatingEmbeddedCacheManager.getCache() |
<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(String cacheName) |
<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,
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,
boolean createIfAbsent) |
Modifier and Type | Method and Description |
---|---|
void |
VersionAwareMarshaller.inject(Cache cache,
Configuration cfg,
InvocationContextContainer icc,
ExternalizerTable extTable,
GlobalConfiguration globalCfg) |
void |
CacheMarshaller.inject(Cache cache,
Configuration cfg,
InvocationContextContainer icc,
ExternalizerTable extTable,
GlobalConfiguration globalCfg) |
Modifier and Type | Method and Description |
---|---|
Cache<K,V> |
Event.getCache() |
Cache<K,V> |
EventImpl.getCache() |
Modifier and Type | Method and Description |
---|---|
static <K,V> EventImpl<K,V> |
EventImpl.createEvent(Cache<K,V> cache,
Event.Type type) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
Cache |
InitialisationContextDelegate.getCache() |
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 |
---|---|
static SearchManager |
Search.getSearchManager(Cache<?,?> cache) |
Modifier and Type | Method and Description |
---|---|
protected void |
QueryInterceptor.injectDependencies(TransactionManager transactionManager,
TransactionSynchronizationRegistry transactionSynchronizationRegistry,
Cache cache,
ClusterRegistry<String,Class<?>,Boolean> clusterRegistry,
DataContainer dataContainer,
ExecutorService e) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Field and Description |
---|---|
protected Cache<?,?> |
ClusteredQueryCommandWorker.cache |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
void |
IndexingMapper.initialize(Cache inputCache) |
void |
IndexingReducer.initialize(Cache<?,?> inputCache) |
<KIn,VIn,KOut,VOut> |
MapReduceInitializer.onPreExecute(Mapper<KIn,VIn,KOut,VOut> mapper,
Cache<KIn,VIn> inputCache) |
<KOut,VOut> |
MapReduceInitializer.onPreExecute(Reducer<KOut,VOut> reducer,
Cache<?,?> inputCache) |
Modifier and Type | Method and Description |
---|---|
void |
ProgrammaticSearchMappingProvider.defineMappings(Cache cache,
org.hibernate.search.cfg.SearchMapping searchMapping) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationQueueImpl.injectDependencies(ScheduledExecutorService executor,
RpcManager rpcManager,
Configuration configuration,
CommandsFactory commandsFactory,
Cache cache) |
Modifier and Type | Method and Description |
---|---|
void |
RpcManagerImpl.injectDependencies(Transport t,
Cache cache,
Configuration cfg,
ReplicationQueue replicationQueue,
CommandsFactory cf,
ExecutorService e,
LocalTopologyManager localTopologyManager,
StateTransferManager stateTransferManager,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
StateProviderImpl.init(Cache cache,
ExecutorService executorService,
Configuration configuration,
RpcManager rpcManager,
CommandsFactory commandsFactory,
CacheNotifier cacheNotifier,
PersistenceManager persistenceManager,
DataContainer dataContainer,
TransactionTable transactionTable,
StateTransferLock stateTransferLock,
StateConsumer stateConsumer,
InternalEntryFactory entryFactory) |
void |
StateConsumerImpl.init(Cache cache,
ExecutorService executorService,
StateTransferManager stateTransferManager,
InterceptorChain interceptorChain,
InvocationContextFactory icf,
Configuration configuration,
RpcManager rpcManager,
TransactionManager transactionManager,
CommandsFactory commandsFactory,
PersistenceManager persistenceManager,
DataContainer dataContainer,
TransactionTable transactionTable,
StateTransferLock stateTransferLock,
CacheNotifier cacheNotifier,
TotalOrderManager totalOrderManager,
BlockingTaskAwareExecutorService remoteCommandsExecutor,
L1Manager l1Manager) |
void |
StateTransferManagerImpl.init(StateConsumer stateConsumer,
StateProvider stateProvider,
Cache cache,
CacheNotifier cacheNotifier,
Configuration configuration,
GlobalConfiguration globalConfiguration,
RpcManager rpcManager,
GroupManager groupManager,
LocalTopologyManager localTopologyManager) |
Modifier and Type | Method and Description |
---|---|
static <K,V> Set<K> |
GlobalKeySetTask.getGlobalKeySet(Cache<K,V> cache) |
void |
GlobalKeySetTask.setEnvironment(Cache<K,V> cache,
Set<K> inputKeys) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionTable.initialize(RpcManager rpcManager,
Configuration configuration,
InvocationContextFactory icf,
InterceptorChain invoker,
CacheNotifier notifier,
TransactionFactory gtf,
TransactionCoordinator txCoordinator,
TransactionSynchronizationRegistry transactionSynchronizationRegistry,
CommandsFactory commandsFactory,
ClusteringDependentLogic clusteringDependentLogic,
Cache cache,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
XaTransactionTable.init(RecoveryManager recoveryManager,
Cache cache) |
Modifier and Type | Method and Description |
---|---|
void |
TargetMigrator.disconnectSource(Cache<Object,Object> cache)
Disconnects the target from the source.
|
void |
RollingUpgradeManager.initialize(Cache<Object,Object> cache,
TimeService timeService) |
long |
TargetMigrator.synchronizeData(Cache<Object,Object> cache)
Performs the synchronization of data between source and target by retrieving the set of known keys and fetching each key in turn
|
Modifier and Type | Field and Description |
---|---|
protected Cache<K,V> |
AbstractCustomFailurePolicy.cache |
Modifier and Type | Method and Description |
---|---|
Cache |
BackupReceiverImpl.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) |
void |
XSiteAdminOperations.init(RpcManager rpcManager,
BackupSender backupSender,
Cache cache) |
Constructor and Description |
---|
BackupReceiverImpl(Cache cache) |
Copyright © 2016 JBoss, a division of Red Hat. All rights reserved.