|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
CacheLoader
that holds common implementations for some methodsCacheStore
that holds common implementations for some methodsAbstractCacheStore
.AbstractDelegatingCache
, but for AdvancedCache
.AdvancedExternalizer
implementations that offers default
implementations for some of its methods.CacheManagerNotifierImpl
and
CacheNotifierImpl
ModuleLifecycle
interface, designed for easy
extension.AbstractConfigurationBean
.GlobalTransaction
TxInvocationContext
.LockManager.acquireLock(org.infinispan.context.InvocationContext, Object)
, but doesn't check whether the
lock is already acquired by the caller.
SegmentReadLocker.deleteOrReleaseReadLock(String)
from deleting the file.
SegmentReadLocker.deleteOrReleaseReadLock(String)
from deleting the file.
BufferSizePredictor
that automatically increases and
decreases the predicted buffer size on feed back.AdvancedExternalizer
with the give id.
AdvancedExternalizer
.
AdvancedExternalizer
implementation
alongside its corresponding identifier.
AdvancedExternalizer
implementations.
AdvancedExternalizer
implementation alongside its corresponding identifier.
AdvancedExternalizer
implementation alongside its corresponding identifier.
AdvancedExternalizer
implementations.
CacheLoaderManagerConfig.addCacheLoader(org.infinispan.loaders.CacheLoaderConfig...)
instead
Fqn
under the current node.
Cache
.Cache
and AdvancedCache
.AdvancedExternalizer
provides an alternative way to provide
externalizers for marshalling/unmarshalling user defined classes that
overcome the deficiencies of the more user-friendly externalizer definition
model explained in Externalizer
.NotifyingNotifiableFuture
implementation that allows a dynamic number of futures to be attached.mods
atomically by creating a worker
and invoking
them in TransactionRunner.run(com.sleepycat.collections.TransactionWorker)
.
null
.
Set
with the given elements.
AtomicMap
.AtomicHashMap
to provide consistency and isolation for concurrent readers
while writes may also be going on.Base64.InputStream
will read data from another
java.io.InputStream, given in the constructor,
and encode/decode to/from Base64 notation on the fly.Base64.InputStream
in DECODE mode.
Base64.InputStream
in
either ENCODE or DECODE mode.
Base64.OutputStream
will write data to another
java.io.OutputStream, given in the constructor,
and encode/decode to/from Base64 notation on the fly.Base64.OutputStream
in ENCODE mode.
Base64.OutputStream
in
either ENCODE or DECODE mode.
AdvancedCache.addInterceptor(CommandInterceptor, int)
method (or any of its
overloaded forms) or registering custom interceptors via XML should extend this base class when creating their own
custom interceptors.InfinispanDirectory
,
this factory produces instances of BaseLuceneLock
.BasicCache
.Log
instances.Cache.startBatch()
and
Cache.endBatch(boolean)
calls.CacheStore
.BdbjeCacheStore
.Executors
except that the factory methods here allow you to specify the
size of the blocking queue that backs the executor.RpcManager.broadcastRpcCommand(org.infinispan.commands.ReplicableCommand, boolean)
except that the task
is passed to the transport executor and a Future is returned.
RpcManager.broadcastRpcCommand(org.infinispan.commands.ReplicableCommand, boolean, boolean)
except that
the task is passed to the transport executor and a Future is returned.
CacheStoreConfig
level.
GetInDoubtTransactionsCommand
.
CommandsFactory.buildLockControlCommand(Object, java.util.Set, org.infinispan.transaction.xa.GlobalTransaction)
but for locking a single key vs a collection of keys.
TxCompletionNotificationCommand
.
PutKeyValueCommand
that also holds a reference to a version to be applied.
CacheEntriesEvicted
.CacheEntryActivated
.CacheEntryCreated
.CacheLoader
.CacheEntryLoaded
.CacheEntryModified
The CacheEntryModifiedEvent.getValue()
method's behavior is specific to whether the callback is triggered before or after the event
in question.CacheEntryPassivated
.CacheEntryRemoved
.CacheEntryVisited
.Cache
fail unexpectedly.CacheContainer.getCache()
methods and has not yet been removed via
EmbeddedCacheManager.removeCache(String)
.
CacheInvocationParameter
implementation.Configuration.isExposeJmxStatistics()
is true, then class will register all the MBeans from cache local's
ConfigurationRegistry to the MBean server.CacheKeyInvocationContext
implementation.CacheLoader
implementation if there are problems reading from a loader.CacheViewsManager
instances.CachePut
interceptor implementation.SearchManagerImpl
.CacheRemoveAll
interceptor implementation.CacheRemoveEntry
interceptor implementation.This interceptor uses the following algorithm describes in
JSR-107.Cache
.CacheResult
interceptor implementation.RpcManager
only replicates commands wrapped in a CacheRpcCommand
.CacheStarted
.CacheStopped
.CacheLoader
interface that can be written to.CacheLoader
based on Apache Cassandra project.CassandraCacheStore
.chunkSize
cache entries.
chunkSize
cache entries.
CacheStore.clear()
modificationMap.clear()
.
CloudCacheStore
.ClusterCacheLoader
.ClusteredGetCommand
s.Mapper
ReplicableCommand
s.Visitor
interface allowing it to
intercept invocations on VisitableCommand
s.DeltaAware.delta()
) and can be
discarded.
TransactionXaAdapter.prepare(javax.transaction.xa.Xid)
applies for commit.
FqnComparator
.
tx
.
Scope
, SurvivesRestarts
,
DefaultFactoryFor
, ComponentName
, Inject
, Start
and Stop
annotations.Inject
Start
or @Stop
null
if there is no current
mapping).
RecoveryAwareRemoteTransaction.isOrphan()
.
initialCapacity
) and
initial table density (loadFactor
).
initialCapacity
), table
density (loadFactor
), and number of concurrently
updating threads (concurrencyLevel
).
null
if there is no current
mapping).ConcurrentHashMap
to deal with the fact that the
JDK does not have a proper concurrent Set implementation that uses efficient lock striping.ConcurrentMap
which is similar to ConcurrentHashMap
.Configuration
instead.Configuration
.Configuration
s.Configuration
.ConnectionFactory
.ConsistentHash
function.MurmurHash2
;FactoryBean
for creating a CacheManager
for a pre-defined CacheContainer
.CacheLoader.load(Object)
, to ensure that a response is
returned only if the entry is not expired.
true
if this map maps one or more keys to the
specified value.
InternalCacheEntry
instance based on the key, value, version and timestamp/lifespan
information reflected in the CacheEntry
instance passed in.
InternalCacheEntry
instance based on the version and timestamp/lifespan
information reflected in the CacheEntry
instance passed in.
InternalCacheEntry
instance
InternalCacheEntry
instance
InternalCacheEntry
instance
JdbmCacheStoreConfig.setComparatorClassName(String)
.
TxInvocationContext
.
NonTxInvocationContext
with the NonTxInvocationContext.isOriginLocal()
returning true.
NonTxInvocationContext
whose NonTxInvocationContext.isOriginLocal()
flag will be true.
InvocationContextContainer.createRemoteInvocationContext(org.infinispan.remoting.transport.Address)
, but returning the flags to
the context from the Command if any Flag was set.
RemoteTransaction
with no modifications.
RemoteTxInvocationContext
.
NonTxInvocationContext
with the NonTxInvocationContext.isOriginLocal()
returning true.
StoredMap
persisted by the database
StoredMap
persisted by the database
Cache
as a parameter
LocalTxInvocationContext
.
InternalCacheValue
based on the InternalCacheEntry
passed in.
ThreadLocalRandom
.
System.nanoTime()
is less expensive than System.currentTimeMillis()
and better suited
to measure time intervals.
JdbcStringBasedCacheStore
and JdbcBinaryCacheStore
.DataRehashed
.DldGlobalTransaction
with
appropriate information needed in order to accomplish deadlock detection.ClassLoader
and a set of Flag
s.add(-1)
.
Version.getVersionShort()
.
Version.getVersionShort()
.
ExecutorFactory
based on an ThreadPoolExecutor
.CacheKey
implementation.CacheKeyGenerator
implementation.Cache
instance, and is often used as a
starting point to using the Cache
.DefaultCacheManager.DefaultCacheManager(org.infinispan.configuration.cache.Configuration)
instead
DefaultCacheManager.DefaultCacheManager(org.infinispan.configuration.cache.Configuration, boolean)
instead
DefaultCacheManager.DefaultCacheManager(org.infinispan.configuration.global.GlobalConfiguration)
instead
DefaultCacheManager.DefaultCacheManager(org.infinispan.configuration.global.GlobalConfiguration, boolean)
instead
DefaultCacheManager.DefaultCacheManager(org.infinispan.configuration.global.GlobalConfiguration, org.infinispan.configuration.cache.Configuration, boolean)
instead
CacheResolver
implementation.ContextClassLoader
to add a default class loader
in case the context class loader is null
.Configuration
producer.EmbeddedCacheManager
producer.ExecutorService
and DistributedExecutorService
.RemoteCacheManager
producer.TwoWayKey2StringMapper
that knows how to handle all primitive
wrapper keys and Strings.#defineConfiguration(String, String, org.infinispan.configuration.cache.Configuration)
instead
EmbeddedCacheManager.defineConfiguration(String, org.infinispan.configuration.cache.Configuration)
instead
InfinispanIndexInput
instances are reading from it, then it will
be effectively deleted.
DeltaAware
implementation.Delta
s.SpringEmbeddedCacheManager
instance created by this
FactoryBean
.
stop
the
RemoteCacheManager
created by this factory.
EmbeddedCacheManager
instance created by this
FactoryBean
.
org.infinispan.Cache
created by this FactoryBean
.
org.infinispan.Cache
created by this FactoryBean
.
stop
the
RemoteCacheManager
created by this factory.
FluentTypes.indexing()
method enables Indexing implicitly.
Group
annotations are not used and any configured
groupers will not be be invoked
CompletionService
that uses a supplied DistributedExecutorService
to execute tasks.LinkedBlockingQueue
as a completion queue.
StateTransferManager
LongAdder.sum()
as a double
after a widening
primitive conversion.
Modification
objects and
executes it against the CacheStore
. Current commands supported are: STORE CLEAR
REMOVE PURGE_EXPIRED
RoundRobinBalancingStrategy.nextServer()
without modifying indexes/state.
DummyTransactionManager
.Configuration
as being modifiable even after the cache has started.Mapper
implementor
Group
annotations are honoured and any configured
groupers will be invoked
Group
annotations are honored and any configured
groupers will be invoked
Group
annotations are honored and any configured
groupers will be invoked
Group
annotations are honored and any configured
groupers will be invoked
Cache.startBatch()
.
MVCCEntry
instances for use in the InvocationContext
.EntryFactory
implementation to be used for optimistic locking scheme.Set
view of the mappings contained in this map.
Set
view of the mappings contained in this map.
Set
view of the mappings contained in this map.
Map.entrySet()
functionality.Configuration.equalsIgnoreName(Object)
for equality that does not consider the name of the configuration.
Configuration.equals(Object)
but it ignores the Configuration.getName()
attribute in the comparison.
Collator
Collator
and wrapped by Future
ExposedByteArrayOutputStream
but with the benefit of not having to allocate unnecessary byte arrays byt not extending ByteArrayOutputStream
.