Package | Description |
---|---|
org.infinispan |
This is the core of Infinispan, a distributed, transactional, highly scalable data grid
platform.
|
org.infinispan.cache.impl | |
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.commands.remote |
Meta-commands that wrap other commands for remote execution.
|
org.infinispan.commands.write |
Commands that alter the state of the cache.
|
org.infinispan.container |
Data containers which store cache entries.
|
org.infinispan.distexec.mapreduce |
Map/Reduce APIs
|
org.infinispan.distribution.impl | |
org.infinispan.eviction.impl | |
org.infinispan.interceptors |
Infinispan is designed around a set of interceptors around a data container.
|
org.infinispan.interceptors.distribution | |
org.infinispan.interceptors.locking | |
org.infinispan.iteration.impl |
Provides Infinispan-specific implementation details iterating over entries in the cache, specifically optimized for
distributed caches.
|
org.infinispan.partitionhandling.impl | |
org.infinispan.security.actions | |
org.infinispan.security.impl | |
org.infinispan.stream.impl | |
org.infinispan.stream.impl.tx |
Modifier and Type | Method and Description |
---|---|
DistributionManager |
AdvancedCache.getDistributionManager()
Retrieves a reference to the
DistributionManager if the cache is configured
to use Distribution. |
Modifier and Type | Method and Description |
---|---|
DistributionManager |
CacheImpl.getDistributionManager() |
DistributionManager |
SimpleCacheImpl.getDistributionManager() |
DistributionManager |
AbstractDelegatingAdvancedCache.getDistributionManager() |
Modifier and Type | Method and Description |
---|---|
void |
CacheImpl.injectDependencies(EvictionManager evictionManager,
ExpirationManager expirationManager,
InvocationContextFactory invocationContextFactory,
InvocationContextContainer icc,
CommandsFactory commandsFactory,
InterceptorChain interceptorChain,
Configuration configuration,
CacheNotifier notifier,
ComponentRegistry componentRegistry,
TransactionManager transactionManager,
BatchContainer batchContainer,
RpcManager rpcManager,
DataContainer dataContainer,
StreamingMarshaller marshaller,
DistributionManager distributionManager,
EmbeddedCacheManager cacheManager,
ExecutorService asyncExecutor,
TransactionTable txTable,
RecoveryManager recoveryManager,
TransactionCoordinator txCoordinator,
LockManager lockManager,
AuthorizationManager authorizationManager,
GlobalConfiguration globalCfg,
PartitionHandlingManager partitionHandlingManager,
LocalTopologyManager localTopologyManager) |
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) |
Modifier and Type | Method and Description |
---|---|
void |
ClusteredGetCommand.initialize(InvocationContextFactory icf,
CommandsFactory commandsFactory,
InternalEntryFactory entryFactory,
InterceptorChain interceptorChain,
DistributionManager distributionManager,
TransactionTable txTable,
Equivalence keyEquivalence) |
Modifier and Type | Method and Description |
---|---|
void |
InvalidateL1Command.init(Configuration config,
DistributionManager dm,
CacheNotifier n,
DataContainer dc) |
Constructor and Description |
---|
InvalidateL1Command(Address writeOrigin,
DataContainer dc,
DistributionManager dm,
CacheNotifier notifier,
Set<Flag> flags,
Collection<Object> keys,
CommandInvocationId commandInvocationId) |
InvalidateL1Command(DataContainer dc,
DistributionManager dm,
CacheNotifier notifier,
Set<Flag> flags,
Collection<Object> keys,
CommandInvocationId commandInvocationId) |
InvalidateL1Command(DataContainer dc,
DistributionManager dm,
CacheNotifier notifier,
Set<Flag> flags,
CommandInvocationId commandInvocationId,
Object... keys) |
Modifier and Type | Method and Description |
---|---|
void |
EntryFactoryImpl.injectDependencies(DataContainer dataContainer,
Configuration configuration,
DistributionManager distributionManager,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
protected <KIn> Set<KIn> |
MapReduceManagerImpl.filterLocalPrimaryOwner(Set<KIn> nodeLocalKeys,
DistributionManager dm) |
protected <T> Map<Address,? extends Collection<T>> |
MapReduceTask.mapKeysToNodes(DistributionManager dm,
Collection<T> keysToMap,
boolean useIntermediateCompositeKey)
Deprecated.
|
<T> Map<Address,List<T>> |
MapReduceManager.mapKeysToNodes(DistributionManager dm,
String taskId,
Collection<T> keysToMap)
Maps Map/Reduce task intermediate or input keys to nodes on Infinispan cluster
|
<T> Map<Address,List<T>> |
MapReduceManagerImpl.mapKeysToNodes(DistributionManager dm,
String taskId,
Collection<T> keysToMap) |
Modifier and Type | Class and Description |
---|---|
class |
DistributionManagerImpl
The default distribution manager implementation
|
Modifier and Type | Method and Description |
---|---|
void |
PassivationManagerImpl.inject(PersistenceManager persistenceManager,
CacheNotifier notifier,
Configuration cfg,
DataContainer container,
TimeService timeService,
MarshalledEntryFactory marshalledEntryFactory,
DistributionManager distributionManager) |
Modifier and Type | Method and Description |
---|---|
void |
DistCacheWriterInterceptor.inject(DistributionManager dm,
Transport transport,
ClusteringDependentLogic cdl)
Deprecated.
|
protected void |
IsMarshallableInterceptor.injectMarshaller(StreamingMarshaller marshaller,
DistributionManager distManager)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected DistributionManager |
BaseDistributionInterceptor.dm
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
BaseDistributionInterceptor.injectDependencies(DistributionManager distributionManager,
ClusteringDependentLogic cdl,
RemoteValueRetrievedListener rvrl,
GroupManager groupManager)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
ClusteringDependentLogic.DistributionLogic.init(DistributionManager dm,
Configuration configuration,
RpcManager rpcManager,
StateTransferLock stateTransferLock) |
Modifier and Type | Method and Description |
---|---|
void |
DistributedEntryRetriever.initialize(DistributionManager distributionManager,
PersistenceManager persistenceManager,
CommandsFactory commandsFactory,
RpcManager rpcManager,
ExecutorService remoteExecutorService) |
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 |
---|---|
DistributionManager |
GetCacheDistributionManagerAction.run() |
Modifier and Type | Method and Description |
---|---|
DistributionManager |
SecureCacheImpl.getDistributionManager() |
Modifier and Type | Field and Description |
---|---|
protected DistributionManager |
AbstractCacheStream.dm |
Constructor and Description |
---|
AbstractCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry>> supplier,
ClusterStreamManager<Object> csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry) |
DistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry<K,V>>> supplier,
ClusterStreamManager csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry)
Standard constructor requiring all pertinent information to properly utilize a distributed cache stream
|
DistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry<K,V>>> supplier,
ClusterStreamManager csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
Function<? super CacheEntry<K,V>,R> function)
Constructor that also allows a simple map method to be inserted first to change to another type.
|
Constructor and Description |
---|
TxDistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry<K,V>>> supplier,
TxClusterStreamManager<?> csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
Function<? super CacheEntry<K,V>,R> function,
LocalTxInvocationContext ctx) |
TxDistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry<K,V>>> supplier,
TxClusterStreamManager<?> csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
LocalTxInvocationContext ctx) |
Copyright © 2022 JBoss, a division of Red Hat. All rights reserved.