Package | Description |
---|---|
org.infinispan.cache.impl | |
org.infinispan.cli.interpreter | |
org.infinispan.cli.interpreter.session | |
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.commands.write |
Commands that alter the state of the cache.
|
org.infinispan.container |
Data containers which store cache entries.
|
org.infinispan.container.entries |
Entries which are stored in data containers.
|
org.infinispan.distexec.mapreduce |
Map/Reduce APIs
|
org.infinispan.distribution.impl | |
org.infinispan.eviction.impl | |
org.infinispan.executors |
Implementations of different executors used for asynchronous operation.
|
org.infinispan.expiration.impl | |
org.infinispan.factories |
Factories are internal components used to create other components based on a cache's
configuration.
|
org.infinispan.globalstate.impl | |
org.infinispan.interceptors |
Infinispan is designed around a set of interceptors around a data container.
|
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.persistence |
This package contains stores, which are used for overflow or persistence.
|
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.manager | |
org.infinispan.persistence.spi |
The Persistence SPI
|
org.infinispan.persistence.support | |
org.infinispan.remoting.rpc |
Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances.
|
org.infinispan.remoting.transport.jgroups |
A transport implementation based on JGroups.
|
org.infinispan.stats |
Cache statistics.
|
org.infinispan.stats.container | |
org.infinispan.stats.impl | |
org.infinispan.stats.wrappers | |
org.infinispan.topology | |
org.infinispan.transaction.impl | |
org.infinispan.transaction.xa |
XA transaction support.
|
org.infinispan.upgrade | |
org.infinispan.util |
General utilities that are not specific to Infinispan, including string parsing helpers, reflection tools and
collections and containers designed to supplement the JDK-provided containers.
|
org.infinispan.util.concurrent |
Thread-safe containers and other concurrency-related utilities, designed to supplement JDK concurrency utilities
and containers.
|
org.infinispan.util.concurrent.locks.impl | |
org.infinispan.xsite |
Modifier and Type | Method and Description |
---|---|
void |
SimpleCacheImpl.injectDependencies(ComponentRegistry componentRegistry,
Configuration configuration,
EmbeddedCacheManager cacheManager,
DataContainer dataContainer,
CacheNotifier cacheNotifier,
TimeService timeService,
InternalEntryFactory entryFactory) |
void |
StatsCollectingCache.injectDependencies(StatsCollector statsCollector,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
Interpreter.initialize(EmbeddedCacheManager cacheManager,
TimeService timeService) |
Constructor and Description |
---|
SessionImpl(CodecRegistry codecRegistry,
EmbeddedCacheManager cacheManager,
String id,
TimeService timeService) |
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 | Field and Description |
---|---|
protected TimeService |
RemoveExpiredCommand.timeService |
Modifier and Type | Method and Description |
---|---|
void |
RemoveExpiredCommand.init(CacheNotifier notifier,
Configuration configuration,
TimeService timeService) |
Constructor and Description |
---|
RemoveExpiredCommand(Object key,
Object value,
Long lifespan,
CacheNotifier notifier,
Equivalence valueEquivalence,
TimeService timeService,
CommandInvocationId commandInvocationId) |
Modifier and Type | Method and Description |
---|---|
void |
DefaultDataContainer.initialize(EvictionManager evictionManager,
PassivationManager passivator,
InternalEntryFactory entryFactory,
ActivationManager activator,
PersistenceManager clm,
TimeService timeService,
CacheNotifier cacheNotifier,
ExpirationManager<K,V> expirationManager) |
void |
EntryFactoryImpl.injectDependencies(DataContainer dataContainer,
Configuration configuration,
DistributionManager distributionManager,
TimeService timeService) |
void |
InternalEntryFactoryImpl.injectTimeService(TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
boolean |
ClusteredRepeatableReadEntry.performWriteSkewCheck(DataContainer container,
PersistenceManager persistenceManager,
TxInvocationContext ctx,
EntryVersion versionSeen,
VersionGenerator versionGenerator,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
MapReduceManagerImpl.init(EmbeddedCacheManager cacheManager,
PersistenceManager persistenceManager,
ExecutorService asyncTransportExecutor,
ClusteringDependentLogic cdl,
TimeService timeService,
Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
void |
L1ManagerImpl.init(Configuration configuration,
RpcManager rpcManager,
CommandsFactory commandsFactory,
ScheduledExecutorService scheduledExecutor,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
PassivationManagerImpl.inject(PersistenceManager persistenceManager,
CacheNotifier notifier,
Configuration cfg,
DataContainer container,
TimeService timeService,
MarshalledEntryFactory marshalledEntryFactory,
DistributionManager distributionManager) |
Constructor and Description |
---|
LazyInitializingBlockingTaskAwareExecutorService(ThreadPoolExecutorFactory<ExecutorService> executorFactory,
ThreadFactory threadFactory,
TimeService timeService,
String controllerThreadName) |
Modifier and Type | Field and Description |
---|---|
protected TimeService |
ExpirationManagerImpl.timeService |
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 |
---|---|
TimeService |
GlobalComponentRegistry.getTimeService() |
abstract TimeService |
AbstractComponentRegistry.getTimeService() |
TimeService |
ComponentRegistry.getTimeService() |
Modifier and Type | Method and Description |
---|---|
void |
GlobalStateManagerImpl.inject(GlobalConfiguration globalConfiguration,
TimeService timeService,
EmbeddedCacheManager cacheManager) |
Modifier and Type | Method and Description |
---|---|
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.
|
void |
CacheMgmtInterceptor.setDependencies(DataContainer dataContainer,
TimeService timeService)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected TimeService |
ClusteringDependentLogic.AbstractClusteringDependentLogic.timeService |
Modifier and Type | Method and Description |
---|---|
void |
ClusteringDependentLogic.AbstractClusteringDependentLogic.init(DataContainer<Object,Object> dataContainer,
CacheNotifier<Object,Object> notifier,
Configuration configuration,
CommitManager commitManager,
PersistenceManager persistenceManager,
TimeService timeService,
FunctionalNotifier<Object,Object> functionalNotifier) |
Modifier and Type | Field and Description |
---|---|
protected TimeService |
LocalEntryRetriever.timeService |
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 |
---|---|
TimeService |
InitializationContextImpl.getTimeService() |
Modifier and Type | Method and Description |
---|---|
static MarshalledEntry |
PersistenceUtil.loadAndCheckExpiration(PersistenceManager persistenceManager,
Object key,
InvocationContext context,
TimeService timeService) |
static <K,V> InternalCacheEntry<K,V> |
PersistenceUtil.loadAndStoreInDataContainer(DataContainer<K,V> dataContainer,
PersistenceManager persistenceManager,
K key,
InvocationContext ctx,
TimeService timeService,
AtomicReference<Boolean> isLoaded) |
Constructor and Description |
---|
InitializationContextImpl(StoreConfiguration configuration,
Cache cache,
StreamingMarshaller marshaller,
TimeService timeService,
ByteBufferFactory byteBufferFactory,
MarshalledEntryFactory mef) |
Modifier and Type | Method and Description |
---|---|
TimeService |
InitialisationContextDelegate.getTimeService() |
Modifier and Type | Method and Description |
---|---|
void |
PersistenceManagerImpl.inject(AdvancedCache<Object,Object> cache,
StreamingMarshaller marshaller,
Configuration configuration,
TransactionManager transactionManager,
TimeService timeService,
ExecutorService persistenceExecutor,
ByteBufferFactory byteBufferFactory,
MarshalledEntryFactory marshalledEntryFactory,
CacheStoreFactoryRegistry cacheStoreFactoryRegistry,
ExpirationManager expirationManager) |
Modifier and Type | Method and Description |
---|---|
TimeService |
InitializationContext.getTimeService() |
Modifier and Type | Method and Description |
---|---|
boolean |
Bucket.contains(Object key,
TimeService timeService) |
MarshalledEntry |
Bucket.getEntry(Object key,
TimeService timeService) |
Map<Object,MarshalledEntry> |
Bucket.getStoredEntries(KeyFilter filter,
TimeService timeService) |
Set<Object> |
Bucket.removeExpiredEntries(TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
RpcManagerImpl.injectDependencies(Transport t,
Configuration cfg,
ReplicationQueue replicationQueue,
CommandsFactory cf,
StateTransferManager stateTransferManager,
TimeService timeService) |
Modifier and Type | Field and Description |
---|---|
protected TimeService |
JGroupsTransport.timeService |
Modifier and Type | Method and Description |
---|---|
void |
JGroupsTransport.initialize(StreamingMarshaller marshaller,
CacheManagerNotifier notifier,
GlobalComponentRegistry gcr,
TimeService timeService,
InboundInvocationHandler globalHandler,
ScheduledExecutorService timeoutExecutor)
Initializes the transport with global cache configuration and transport-specific properties.
|
Constructor and Description |
---|
CommandAwareRpcDispatcher(org.jgroups.Channel channel,
JGroupsTransport transport,
InboundInvocationHandler globalHandler,
ScheduledExecutorService timeoutExecutor,
TimeService timeService) |
JGroupsBackupResponse(Map<XSiteBackup,Future<Object>> syncBackupCalls,
TimeService timeService) |
Modifier and Type | Field and Description |
---|---|
protected TimeService |
TransactionStatistics.timeService |
Constructor and Description |
---|
CacheStatisticCollector(TimeService timeService) |
CacheStatisticManager(Configuration configuration,
TimeService timeService) |
LocalTransactionStatistics(boolean optimisticLockingScheme,
TimeService timeService) |
RemoteTransactionStatistics(TimeService timeService) |
TransactionStatistics(ExtendedStatisticsContainer container,
TimeService timeService) |
Constructor and Description |
---|
ConcurrentGlobalContainer(TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
ClusterCacheStatsImpl.injectDependencies(Cache<?,?> cache,
TimeService ts,
Configuration configuration) |
void |
StatsCollector.injectDependencies(TimeService timeService,
DataContainer dataContainer,
Configuration configuration) |
void |
CacheContainerStatsImpl.setDependencies(TimeService timeService) |
Constructor and Description |
---|
ExtendedStatisticLockManager(LockManager actual,
CacheStatisticManager cacheStatisticManager,
TimeService timeService) |
ExtendedStatisticRpcManager(RpcManager actual,
CacheStatisticManager cacheStatisticManager,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
LocalTopologyManagerImpl.inject(Transport transport,
ExecutorService asyncTransportExecutor,
GlobalComponentRegistry gcr,
TimeService timeService,
GlobalStateManager globalStateManager) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionFactory.init(Configuration configuration,
VersionGenerator clusterIdGenerator,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
RollingUpgradeManager.initialize(Cache<Object,Object> cache,
TimeService timeService) |
Modifier and Type | Class and Description |
---|---|
class |
DefaultTimeService
The default implementation of
TimeService . |
Constructor and Description |
---|
BlockingTaskAwareExecutorServiceImpl(String controllerThreadName,
ExecutorService executorService,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
void |
PerKeyLockContainer.inject(TimeService timeService) |
void |
StripedLockContainer.inject(TimeService timeService) |
void |
DefaultPendingLockManager.inject(TransactionTable transactionTable,
TimeService timeService,
ScheduledExecutorService timeoutExecutor,
StateTransferManager stateTransferManager) |
void |
InfinispanLock.setTimeService(TimeService timeService)
Tests purpose only!
|
Constructor and Description |
---|
InfinispanLock(TimeService timeService)
Creates a new instance.
|
InfinispanLock(TimeService timeService,
Runnable releaseRunnable)
Creates a new instance.
|
Modifier and Type | Field and Description |
---|---|
protected TimeService |
BaseBackupReceiver.timeService |
Modifier and Type | Method and Description |
---|---|
void |
BackupSenderImpl.init(Cache cache,
Transport transport,
TransactionTable txTable,
GlobalConfiguration gc,
TimeService timeService,
CommandsFactory commandsFactory) |
Constructor and Description |
---|
OfflineStatus(TakeOfflineConfiguration takeOfflineConfiguration,
TimeService timeService) |
Copyright © 2020 JBoss, a division of Red Hat. All rights reserved.