|
||||||||||
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
.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.
CacheLoaderManagerConfig.addCacheLoader(org.infinispan.loaders.CacheLoaderConfig...)
instead
Fqn
under the current node.
AbstractComponentRegistry.Component.injectionMethods
.
Cache
.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
.mods
atomically by creating a worker
and invoking
them in TransactionRunner.run(com.sleepycat.collections.TransactionWorker)
.
null
.
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.
InfinispanDirectory
,
this factory produces instances of BaseLuceneLock
.Cache.startBatch()
and
Cache.endBatch(boolean)
calls.CacheStore
.BdbjeCacheStore
.LinkedHashMap
except that this version makes use of the fact that entries are
bidirectionally linked and can hence be navigated either from the start or from the end.beforeCommand()
.
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
.
RemoveRecoveryInfoCommand
.
Cache
instance, and is often
used as a starting point to using the Cache
.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)
.
Configuration.isExposeJmxStatistics()
is true, then class will register all the MBeans from cache local's
ConfigurationRegistry to the MBean server.CacheLoader
implementation if there are problems reading from a loader.Cache
and AdvancedCache
.SearchManagerImpl
.CacheRemoveAll
interceptor.CacheRemoveEntry
interceptor.This interceptor uses the following algorithm
describes in JSR-107.CacheResult
interceptor.RpcManager
only replicates commands wrapped in a CacheRpcCommand
.CacheStarted
.CacheStopped
.CacheLoader
interface that can be written to.CacheLoader
based on Apache Cassandra project.CassandraCacheStore
.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
.
RecoveryAwareRemoteTransaction.isOrphan()
.
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
.Configuration
s.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.
JdbmCacheStoreConfig.setComparatorClassName(String)
.
TxInvocationContext
.
NonTxInvocationContext
with the
NonTxInvocationContext.isOriginLocal()
returning true.
NonTxInvocationContext
whose
NonTxInvocationContext.isOriginLocal()
flag will be true.
#createRemoteInvocationContext()
, but returning the flags to the context from
the Command if any Flag was set.
RemoteTransaction
based on the supplied params.
RemoteTransaction
with no modifications.
RemoteTxInvocationContext
.
StoredMap
persisted by the database
StoredMap
persisted by the database
Cache
as a parameter
LocalTxInvocationContext
.
JdbcStringBasedCacheStore
and JdbcBinaryCacheStore
.DataRehashed
.DldGlobalTransaction
with
appropriate information needed in order to accomplish deadlock detection.Version.getVersionShort()
.
ExecutorFactory
based on an ThreadPoolExecutor
.Cache
instance, and is often used as a
starting point to using the Cache
.ContextClassLoader
to add a default class loader
in case the context class loader is null
.ExecutorService
and DistributedExecutorService
.TwoWayKey2StringMapper
that knows how to
handle all primitive wrapper keys and Strings.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.
CompletionService
that uses a supplied DistributedExecutorService
to execute tasks.LinkedBlockingQueue
as a completion queue.
Modification
objects and
executes it against the CacheStore
. Current commands supported are: STORE CLEAR
REMOVE PURGE_EXPIRED
RemoteTransactionLogger.drain()
except that relevant locks are acquired so that no more commands are added to the
transaction log during this process, and transaction logging is disabled after draining.
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
Cache.startBatch()
.
MVCCEntry
instances for use in the InvocationContext
.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
Explanation
object describing the score computation for the matching object/document
in the current query
BucketBasedCacheStore
.FileCacheStore
.Flag
.RecoveryManager.forceTransactionCompletion(javax.transaction.xa.Xid, boolean)
on the specified node.
Node
in a TreeCache
.CacheKey
for the given InvocationContext
by using the given CacheKeyGenerator
class.
Node
.
null
if this map contains no mapping for the
key.
null
if this map contains no mapping for the key.
null
if this map contains no mapping for the
key.
Map.get(Object)
that allows user code to
retrieve the value associated with a key at a later stage, hence allowing
multiple parallel get requests to be sent.
RequestBalancingStrategy
may not be thread-safe.
RemoteCache.getBulk()
, but limits the returned set of values to the specified size.
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.
Configuration.getCacheLoaders()
, Configuration.isCacheLoaderShared()
Configuration.isFetchPersistentState()
, Configuration.isCacheLoaderPassivation()
and Configuration.isCacheLoaderPreload()
instead
org.infinispan.client.hotrod.RemoteCache
does
not support retrieving the set of all cache names from the hotrod server.
clone
of the Configuration
registered under the given name.
CacheLoaderConfig
type.
CacheLoaderConfig
type.
ConnectionFactory
based on the supplied class
name.
ConsistentHash
may not be thread-safe.
DefaultConsistentHash
.
RpcManager.retrieveState(String, long)
has been invoked and hasn't yet returned (i.e., a state transfer is in
progress), this method will return the current Address from which a state transfer is being attempted.
CustomInterceptorConfig
, if any, associated with this configuration
object.
Node
.
DataContainer
DistributionManager
if the cache is configured
to use Distribution.
Configuration.getExpirationWakeUpInterval()
Fqn
which represents the location of this Node
in the cache structure.
RecoveryManager.getInDoubtTransactionInfoFromCluster()
, but only returns transactions from the local node.
Set
containing all the in-doubt transactions from the cluster, including the local node.
Util.getInstance(Class)
except that exceptions are propagated to the caller.
#getInstance(String)
except that exceptions are propagated to the caller.
InvocationContext
that is currently associated with the calling thread.
Set
containing the data in this Node
.
Map.get(Object)
and
Map.containsKey(Object)
operationsFqn.SEPARATOR
.
BucketBasedCacheStore
s the lock should be acquired at bucket level.
MBeanServer
instance.
org.infinispan.manager.EmbeddedCacheManager
that backs this
CacheManager
.
org.infinispan.client.hotrod.RemoteCacheManager
that backs this
SpringRemoteCacheManager
.
DefaultFactoryFor
annotation that is capable of creating the component
class).
TransactionXaAdapter
corresponding to the supplied transaction.
normalizedHash
.
StringPropertyReplacer.replaceProperties(java.lang.String)
to the result.
CacheQuery
, filtered according to a set of classes passed
in.
RemoteCacheManager
that created this cache.
RemoteTransaction
associated with the supplied transaction id.
Status.STATUS_PREPARED
if the tx is prepared
- Status.STATUS_COMMITTED
if the tx is committed
- Status.STATUS_ROLLEDBACK
if the tx is rollback
- null otherwise
Status
field.
VersionedValue
associated to the supplied key param, or null if it doesn't exist.
Configuration.getExpirationWakeUpInterval()
Group
annotation needs customizing.Fqn
passed in exists.
Object.hashCode()
.
VisitableCommand.shouldInvoke(InvocationContext)
but evaluated by InvocationContextInterceptor
.
LockSupportCacheStore.lockForWriting(Object)
, but with 0 timeout.
ImmortalCacheEntry
Map.Entry
} with an immutable Map.Entry
}.
InternalCacheEntry
} with an immutable InternalCacheEntry
}.
Listenable.addListener(Object)
API.Configuration
.FactoryBean
for creating a
native default Infinispan org.infinispan.Cache
, delegating to a configurable
org.infinispan.manager.CacheContainer
.Directory
which uses Infinispan to store Lucene indexes.FactoryBean
for creating an
Infinispan EmbeddedCacheManager
instance.InfinispanDirectory
Directory
FactoryBean
for creating a
native named
Infinispan org.infinispan.Cache
, delegating to a
configurable
org.infinispan.manager.EmbeddedCacheManager
.FactoryBean
for creating a
native named
Infinispan org.infinispan.Cache
, delegating to a
configurable
oorg.infinispan.client.hotrod.RemoteCacheManagerr
.NamespaceHandler
for Infinispan-based caches.FactoryBean
for creating an
Infinispan RemoteCacheManager
instance.ReplicableCommand
read from a data stream with components specific
to the target cache instance.
ModuleCommandFactory.fromStream(byte, Object[])
with
necessary named-cache-specific components.
InvocationContext
and the
calling thread.InvocationContextContainer
.InvocationContext
without changing the context directly
but making sure the specified flags are considered enabled.InvocationContext
without changing the context directly
but making sure the specified flags are considered enabled.
AccessibleObject.setAccessible(boolean)
RpcManager.invokeRemotely(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean)
except that the task is passed to the transport executor and a Future is returned.
RpcManager.invokeRemotely(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean)
except that the task is passed to the transport executor and a Future is returned.
RpcManager.invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand,
boolean, org.infinispan.util.concurrent.NotifyingNotifiableFuture)
except that you can specify a timeout.
Configuration.isUseEagerLocking()
, Configuration.isEagerLockSingleNode()
and the cache is
distributed.
Configuration.isDeadlockDetectionEnabled()
instead.
JdbcStringBasedCacheStore
, but will be injected through JdbcStringBasedCacheStore.doConnectionFactoryInitialization(org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory)
true
.
true
.
true
.
true
.
true
.
true
.
Configuration.isStoreAsBinary()
Synchronization
.
QueryIterator
with a given integer parameter - the fetchSize.
QueryIterator
.
GenericJBossMarshaller
, making use of a custom object table for types internal to
Infinispan.TransactionManager
instance from "java:/TransactionManager".BucketBasedCacheStore
implementation that will store all the buckets as rows in database, each row
corresponding to a bucket.JdbcBinaryCacheStore
.JdbcBinaryCacheStore
and JdbcStringBasedCacheStore
.JdbcMixedCacheStore
.CacheStore
implementation that stores the entries in a database.JdbcStringBasedCacheStore
cache store.CacheLoader
based on the JDBM project.JdbmCacheStore
.StreamingMarshaller
of the cache.ResponseFilter
.KeyAffinityService
.KeyAffinityService
to generate the affinity keys.Set
view of the keys contained in this map.
Set
view of the keys contained in this map.
Map.keySet()
functionality.QueryIterator
with a given integer parameter - the
fetchSize.
CacheQuery.lazyIterator(int fetchSize)
method but passes in a default 1 as a parameter.
QueryIterator
.AdvancedExternalizer
implementations to be registered.AdvancedExternalizer
implementations to be registered.null
the Inifinispan classes'
classloader.
null
the Inifinispan classes' classloader.
DistributedSegmentReadLocker
to minimize
remote operations in case several IndexReaders are opened on the same InfinispanDirectory
.RemoteTransaction
.LocalTransaction
implementation to be used with TransactionXaAdapter
.ConsistentHash.locate(Object, int)
multiple times for each key in the collection of
keys.
DistributionManager.locateAll(java.util.Collection)
, but the list of addresses only contains numOwners owners.
LockManager
.AbstractCacheStore
adding lock support for consistently accessing stored data.LockSupportCacheStore
.Log
instances.DefaultFileLookup
.
DefaultFileLookup
.
DefaultFileLookup
.
DefaultFileLookup
.
MBeanServer
instance based on the
configuration parameters.
Mapper
and Reducer
to remote JVM where they
will get invoked.MarshalledValue
s.MBeanServerLookup
class to be used to bound JMX MBeans to.
DeltaAware
instance, and return a coherent and complete
DeltaAware
instance.
Merged
.CacheStore
modificationModification
s to be performed atomically via TransactionRunner
.Modification
s that will be applied to the supplied CacheStore
ModuleProperties
class represents Infinispan's module configuration key value
pairs.MortalCacheEntry
ComponentName
annotation on the classes requested in Inject
annotated methods.ResponseFilter.isAcceptable(Response, Address)
, this method is called to see whether we are done
with the request and can unblock the caller
KeyAffinityService
instance that generates keys mapped to all addresses
in the cluster.
KeyAffinityServiceFactory.newKeyAffinityService(org.infinispan.Cache, java.util.concurrent.Executor, KeyGenerator, int,
boolean)
with start == true;
KeyAffinityServiceFactory.newKeyAffinityService(org.infinispan.Cache, java.util.Collection, KeyGenerator,
java.util.concurrent.Executor, int, boolean)
with start == true.
KeyAffinityServiceFactory.newLocalKeyAffinityService(org.infinispan.Cache, KeyGenerator, java.util.concurrent.Executor, int, boolean)
with start == true.
named
logical grouping of data in the TreeCache
API of JBoss Cache
.AtomicMap
NotifyingFuture
.StreamingMarshaller.objectFromInputStream(java.io.InputStream)
, but its
implementation has been moved here rather that keeping under a class that implements StreamingMarshaller
in order to avoid code duplication.
ObjectInput
ByteBuffer
which takes
an estimated size as parameter.
ByteBuffer
, which allows direct access to the byte
array with minimal array copying
ObjectOutput
onKeys
allows users to specify a
subset of keys as input to this task
HotRodOperation
objects.AtomicMap
interfaces and API that Infinispan exposes as building
blocks in creating other public interfaces such as the Tree API.Cache.startBatch()
and Cache.endBatch(boolean)
API.CacheManager
and its various Cache
s, and related
utilities.CacheStore
implementation based on
Oracle's BDBJE storage engine.CacheStore
implementation based on
persisting to Apache CassandraCacheStore
implementation based on
JClouds, which in turn is an abstraction layer to store data on cloud infrastructure providers
such as Amazon's S3,
RackspaceCloud's CloudFiles,
Microsoft's Windows Azure Blob Storage API, and others.CacheLoader
(not CacheStore
) that polls other nodes in the cluster for state.CacheStore
implementation.CacheStore
implementation based on
a JDBC database connection.CacheStore
implementation based on
persisting to JDBM.CacheStore
.Cache
-specific notifications and eventing.CacheManager
-specific notifications and eventing.TransactionManager
s.OwnableReentrantLock
s.org.infinispan.config.GlobalConfiguration#getDefaultConfiguration()
This is typically used to configure a DefaultCacheManager
DataContainer.get(Object)
}
except that it does not update or reorder any of the internal constructs.
MBeanServerLookup
, will return the platform MBean server.TransactionRunner
, which allows us to prepare a transaction without committing it. The
transaction prepared is accessible via CurrentTransaction.getTransaction()
superclass
and caches a current reference to CurrentTransaction
.
superclass
and caches
a current reference to CurrentTransaction
.
SleepyCat transaction
associated with tx
.
run
, except that the
transaction is not committed on success.
org.hibernate.search.bridge.TwoWayFieldBridge
Unless notified in their JavaDoc, all built-in bridges are two-way.
StoredMap.entrySet()
and remove, if expired.
Map.put(Object, Object)
, which takes in lifespan parameters.
Map.put(Object, Object)
, which takes in lifespan parameters.
Node
in this cache.
Node
.
Map.putAll(Map)
, which takes in lifespan parameters.
Map.putAll(Map)
, which takes in lifespan parameters.
Map.putAll(Map)
.
Cache.putAll(Map, long, TimeUnit)
.
Cache.putAll(Map, long, TimeUnit, long, TimeUnit)
.
Map.put(Object, Object)
.
Cache.put(Object, Object, long, TimeUnit)
.
Cache.put(Object, Object, long, TimeUnit, long, TimeUnit)
.
ConcurrentMap.putIfAbsent(Object, Object)
, which takes in lifespan parameters.
ConcurrentMap.putIfAbsent(Object, Object)
, which takes in lifespan parameters.
ConcurrentMap.putIfAbsent(Object, Object)
.
Cache.putIfAbsent(Object, Object, long, TimeUnit)
.
Cache.putIfAbsent(Object, Object, long, TimeUnit, long, TimeUnit)
.
Map.put(Object, Object)
Base64.InputStream.read()
repeatedly until the end of stream
is reached or len bytes are read.
XmlConfigHelper.readStringContents(org.w3c.dom.Element,String)
except that it returns a boolean.
XmlConfigHelper.readStringContents(org.w3c.dom.Element,String)
except that it returns a boolean.
ImmutableListCopy.writeExternal(java.io.ObjectOutput)
for serialization format
CacheLoader
, i.e., suppressing all write
methods.AbstractQueuedSynchronizer
.GlobalTransaction
.LocalXaTransaction
and adds recovery related information.RemoteTransaction
and adds recovery related information and functionality.RecoveryManager
.XAResource.recover(int)
.RecoveryManager
Synchronization
callback with this transaction.
RemoteCache
s.Marshaller
for marshalling
keys and values to be send over to the remote Infinispan cluster.
Marshaller
for marshalling
keys and values to be send over to the remote Infinispan cluster.
RemoteCacheManager.RemoteCacheManager(Marshaller, java.util.Properties, boolean)
with start = true.
RemoteCacheManager.RemoteCacheManager(Marshaller, java.util.Properties, boolean)
with start = true.
RemoteCacheManager.RemoteCacheManager(java.util.Properties, boolean)
, and it also starts the cache (start==true).
RemoteCacheManager.RemoteCacheManager(java.util.Properties, boolean)
, and it also starts the cache (start==true).
RemoteCacheManager.RemoteCacheManager(java.util.Properties)
, but it will try to lookup the config properties in the
classpath, in a file named hotrod-client.properties.
RemoteCacheManager.RemoteCacheManager(boolean)
and it also starts the cache.
RemoteCacheManager.RemoteCacheManager(String, int, boolean)
with start=true.
RemoteCacheManager.RemoteCacheManager(String, int, boolean)
with start=true.
RemoteCacheManager.RemoteCacheManager(String, boolean)
, with start=true.
RemoteCacheManager.RemoteCacheManager(String, boolean)
, with start=true.
RemoteCacheManager.RemoteCacheManager(java.util.Properties)
, but it will try to lookup the config properties in
supplied URL.
RemoteCacheManager.RemoteCacheManager(java.util.Properties)
, but it will try to lookup the config properties in
supplied URL.
RemoteCacheManager.RemoteCacheManager(java.net.URL)
and it also starts the cache (start==true).
RemoteCacheManager.RemoteCacheManager(java.net.URL)
and it also starts the cache (start==true).
RemoteCache
that is associated to an
RemoteCacheManager
that was not started.ReplicableCommand
s from a byte stream.RemoteTransaction
corresponding to the given tx.
CacheStore.remove(Object)
modificationMap.remove(Object)
.
ConcurrentMap.remove(Object, Object)
.
Fqn
.
TransactionXaAdapter
corresponding to the given tx.
Node
indicated by absolute Fqn
.
RecoveryManager.removeRecoveryInformation(javax.transaction.xa.Xid)
but identifies the tx by its internal id.
#removeRecoveryInformationFromCluster(java.util.Collection
but the transaction
is identified by its internal id, and not by its xid.
ReadCommittedEntry
that provides Repeatable Read semanticsConcurrentMap.replace(Object, Object)
, which takes in lifespan parameters.
ConcurrentMap.replace(Object, Object, Object)
, which takes in lifespan parameters.
ConcurrentMap.replace(Object, Object)
, which takes in lifespan parameters.
ConcurrentMap.replace(Object, Object, Object)
, which takes in lifespan parameters.
Node.putAll(java.util.Map)
except that it removes any entries that exists in the data map first.
ConcurrentMap.replace(Object, Object)
.
Cache.replace(Object, Object, long, TimeUnit)
.
Cache.replace(Object, Object, long, TimeUnit, long, TimeUnit)
.
ConcurrentMap.replace(Object, Object, Object)
.
Cache.replace(Object, Object, Object, long, TimeUnit)
.
Cache.replace(Object, Object, Object, long, TimeUnit, long, TimeUnit)
.
InvocationContext
with the calling thread.
InboundInvocationHandler.generateState(String, java.io.OutputStream)
), and applies this
state to the current cache via the InboundInvocationHandler.applyState(String, java.io.InputStream)
callback.
ReversibleOrderedSet.reverseIterator()
method.Random
's distribution to generate keys.CacheStore.prepare(java.util.List, org.infinispan.transaction.xa.GlobalTransaction, boolean)
.
CacheStore.prepare(java.util.List, org.infinispan.transaction.xa.GlobalTransaction, boolean)
.
TransactionXaAdapter.prepare(javax.transaction.xa.Xid)
applies for commit.
RequestBalancingStrategy
.Transport
.Transport
implementation,
and is used to set up the transport and provide lifecycle and dependency hooks into external transport
implementations.SearchConfiguration
so that within Infinispan-Query, there is
no need for a Hibernate Core configuration object.Xid
is not Serializable
and
we need to serialize it and send it over the network.ClassExternalizerFactory
that
allows for Infinispan annotations to be used instead of JBoss Marshalling
ones in order to discover which classes are serializable with Infinispan
externalizers.GlobalConfiguration.GlobalJmxStatisticsType.allowDuplicateDomains(Boolean)
instead
FluentGlobalConfiguration.GlobalJmxStatisticsConfig.allowDuplicateDomains(Boolean)
instead
FluentConfiguration.StateRetrievalConfig.alwaysProvideInMemoryState(Boolean)
instead
Configuration.StateRetrievalType.alwaysProvideInMemoryState(Boolean)
instead
FluentGlobalTypes.asyncListenerExecutor()
instead
FluentGlobalTypes.asyncListenerExecutor()
instead
FluentGlobalTypes.asyncListenerExecutor()
instead
Configuration.AsyncType.asyncMarshalling(Boolean)
CacheStoreConfig.asyncStore()
instead
FluentGlobalTypes.asyncTransportExecutor()
instead
FluentGlobalTypes.asyncTransportExecutor()
instead
FluentGlobalTypes.asyncTransportExecutor()
instead
FluentConfiguration.LoadersConfig.addCacheLoader(org.infinispan.loaders.CacheLoaderConfig...)
instead
GlobalConfiguration.GlobalJmxStatisticsType.cacheManagerName(String)
instead
FluentGlobalConfiguration.GlobalJmxStatisticsConfig.cacheManagerName(String)
instead
FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode)
instead
FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode)
instead
FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode)
instead
name
of the org.infinispan.Cache
to be created.
name
of the org.infinispan.Cache
to be created.
FluentConfiguration.TransactionConfig.cacheStopTimeout(Integer)
instead
Configuration.TransactionType.cacheStopTimeout(Integer)
instead
FluentGlobalConfiguration.TransportConfig.clusterName(String)
instead
GlobalConfiguration.TransportType.clusterName(String)
instead
Configuration.LockingType.concurrencyLevel(Integer)
instead
FluentConfiguration.LockingConfig.concurrencyLevel(Integer)
instead
location
of the
configuration file which will be used to configure the
EmbeddedCacheManager
the
SpringEmbeddedCacheManager
created by this FactoryBean
delegates
to.
Configuration.HashType.consistentHashClass(Class)
FluentConfiguration.HashConfig.consistentHashClass(Class)
instead
Configuration.CustomInterceptorsType.add(org.infinispan.interceptors.base.CommandInterceptor)
instead
FluentConfiguration.CustomInterceptorCumulator.add(org.infinispan.interceptors.base.CommandInterceptor)
FluentConfiguration.DeadlockDetectionConfig.spinDuration(Long)
instead
FluentGlobalConfiguration.TransportConfig.distributedSyncTimeout(Long)
instead
GlobalConfiguration.TransportType.distributedSyncTimeout(Long)
instead
FluentConfiguration.TransactionConfig.eagerLockSingleNode(Boolean)
instead
Configuration.TransactionType.eagerLockSingleNode(Boolean)
instead
Configuration.BooleanAttributeType.enabled(Boolean)
instead
AbstractConfigurationBeanWithGCR.globalJmxStatistics()
instead
AbstractFluentConfigurationBean.deadlockDetection()
instead
FluentConfiguration.EvictionConfig.maxEntries(Integer)
instead
FluentGlobalTypes.evictionScheduledExecutor()
instead
FluentGlobalTypes.evictionScheduledExecutor()
instead
FluentGlobalTypes.evictionScheduledExecutor()
instead
FluentConfiguration.EvictionConfig.strategy(org.infinispan.eviction.EvictionStrategy)
instead
FluentConfiguration.EvictionConfig.strategy(org.infinispan.eviction.EvictionStrategy)
instead
FluentConfiguration.EvictionConfig.threadPolicy(org.infinispan.eviction.EvictionThreadPolicy)
instead
FluentConfiguration.EvictionConfig.threadPolicy(org.infinispan.eviction.EvictionThreadPolicy)
instead
FluentConfiguration.ExpirationConfig.wakeUpInterval(Long)
instead
FluentConfiguration.ExpirationConfig.lifespan(Long)
instead
FluentConfiguration.ExpirationConfig.maxIdle(Long)
instead
AbstractConfigurationBeanWithGCR.globalJmxStatistics()
instead
AbstractFluentConfigurationBean.jmxStatistics()
instead
AdvancedExternalizer
implementation that knows how to marshall or unmarshall instances of one, or
several, user-defined, types.
FluentConfiguration.StateRetrievalConfig.fetchInMemoryState(Boolean)
instead
Configuration.StateRetrievalType.fetchInMemoryState(Boolean)
instead
CacheStoreConfig.fetchPersistentState(Boolean)
instead
AsyncStoreConfig.flushLockTimeout(Long)
instead.
Configuration.HashType.hashFunctionClass(Class)
FluentConfiguration.HashConfig.hashFunctionClass(Class)
instead
GlobalConfiguration.ShutdownType.hookBehavior(org.infinispan.config.GlobalConfiguration.ShutdownHookBehavior)
instead
AdvancedExternalizer
implementations, providing a more performant way to ship class information around
rather than passing class names or class information in general around.
CacheStoreConfig.ignoreModifications(Boolean)
instead
AbstractFluentConfigurationBean.indexing()
instead
Configuration.QueryConfigurationBean.indexLocalOnly(Boolean)
instead
FluentConfiguration.IndexingConfig.indexLocalOnly(Boolean)
instead
org.infinispan.manager.CacheContainer
to be used for creating our
Cache
instance.
org.infinispan.manager.EmbeddedCacheManager
to be used for creating our
Cache
instance.
org.infinispan.client.hotrod.RemoteCacheManager
to be used for creating our
Cache
instance.
Configuration.StateRetrievalType.initialRetryWaitTime(Long)
instead
AbstractFluentConfigurationBean.invocationBatching()
instead
Configuration.LockingType.isolationLevel(org.infinispan.util.concurrent.IsolationLevel)
instead
FluentConfiguration.LockingConfig.isolationLevel(org.infinispan.util.concurrent.IsolationLevel)
instead
FluentConfiguration.LockingConfig.isolationLevel(org.infinispan.util.concurrent.IsolationLevel)
instead
GlobalConfiguration.GlobalJmxStatisticsType.jmxDomain(String)
instead
FluentGlobalConfiguration.GlobalJmxStatisticsConfig.jmxDomain(String)
instead
AbstractFluentConfigurationBean.l1()
instead
FluentConfiguration.L1Config.invalidationThreshold(Integer)
instead
FluentConfiguration.L1Config.lifespan(Long)
instead
FluentConfiguration.L1Config.onRehash(Boolean)
instead
Configuration.ExpirationType.lifespan(Long)
Configuration.L1Type.lifespan(Long)
FileCacheStoreConfig.location(String)
Configuration.LockingType.lockAcquisitionTimeout(Long)
instead
FluentConfiguration.LockingConfig.lockAcquisitionTimeout(Long)
instead
FluentConfiguration.LockingConfig.lockAcquisitionTimeout(Long)
instead
Configuration.StateRetrievalType.logFlushTimeout(Long)
instead
FluentGlobalConfiguration.TransportConfig.machineId(String)
instead
GlobalConfiguration.TransportType.machineId(String)
instead
GlobalConfiguration.SerializationType.marshallerClass(Class)
instead
FluentGlobalConfiguration.SerializationConfig.marshallerClass(Class)
instead
FluentGlobalConfiguration.SerializationConfig.version(short)
instead
FluentGlobalConfiguration.SerializationConfig.version(String)
instead
Configuration.EvictionType.maxEntries(Integer)
Configuration.ExpirationType.maxIdle(Long)
Configuration.StateRetrievalType.maxNonProgressingLogWrites(Integer)
instead
GlobalConfiguration.GlobalJmxStatisticsType.mBeanServerLookupClass(Class)
instead
FluentGlobalConfiguration.GlobalJmxStatisticsConfig.mBeanServerLookupClass(Class)
instead
FluentGlobalConfiguration.GlobalJmxStatisticsConfig.mBeanServerLookup(org.infinispan.jmx.MBeanServerLookup)
instead
GlobalConfiguration.GlobalJmxStatisticsType.mBeanServerLookup(org.infinispan.jmx.MBeanServerLookup)
instead
FluentGlobalConfiguration.GlobalJmxStatisticsConfig.mBeanServerLookup(org.infinispan.jmx.MBeanServerLookup)
instead
FluentGlobalConfiguration.GlobalJmxStatisticsConfig.withProperties(java.util.Properties)
or
FluentGlobalConfiguration.GlobalJmxStatisticsConfig.addProperty(String, String)
instead
#mode(CacheMode)
GlobalConfiguration.TransportType.nodeName(String)
instead
Configuration.HashType.numOwners(Integer)
FluentConfiguration.HashConfig.numOwners(Integer)
instead
Configuration.StateRetrievalType.numRetries(Integer)
instead
Configuration.HashType.numVirtualNodes(Integer)
Configuration.L1Type.onRehash(Boolean)
CommandsFactory
to create a command from raw data read off a stream.
CacheLoaderManagerConfig.passivation(Boolean)
instead.
CacheLoaderManagerConfig.preload(Boolean)
instead.
GlobalConfiguration.FactoryClassWithPropertiesType.addProperty(String, String)
or GlobalConfiguration.FactoryClassWithPropertiesType.withProperties(java.util.Properties)
instead
GlobalConfiguration.GlobalJmxStatisticsType.withProperties(java.util.Properties)
instead
GlobalConfiguration.TransportType.withProperties(java.util.Properties)
or GlobalConfiguration.TransportType.addProperty(String, String)
instead
CacheStoreConfig.purgeOnStartup(Boolean)
instead
AbstractCacheStoreConfig.purgerThreads(Integer)
instead
CacheStoreConfig.purgeSynchronously(Boolean)
instead
SingletonStoreConfig.pushStateTimeout(Long)
instead.
SingletonStoreConfig.pushStateWhenCoordinator(Boolean)
instead.
FluentGlobalConfiguration.TransportConfig.rackId(String)
instead
GlobalConfiguration.TransportType.rackId(String)
instead
Configuration.HashType.rehashEnabled(Boolean)
FluentConfiguration.HashConfig.rehashEnabled(Boolean)
instead
Configuration.HashType.rehashRpcTimeout(Long)
FluentConfiguration.HashConfig.rehashRpcTimeout(Long)
instead
Configuration.HashType.rehashWait(Long)
FluentConfiguration.HashConfig.rehashWait(Long)
instead
ClusterCacheLoaderConfig.remoteCallTimeout(long)
FluentGlobalTypes.replicationQueueScheduledExecutor()
instead
FluentGlobalTypes.replicationQueueScheduledExecutor()
instead
FluentGlobalTypes.replicationQueueScheduledExecutor()
instead
Configuration.AsyncType.replQueueClass(Class)
FluentConfiguration.AsyncConfig.replQueueClass(Class)
instead
Configuration.AsyncType.replQueueInterval(Long)
FluentConfiguration.AsyncConfig.replQueueInterval(Long)
instead
FluentConfiguration.AsyncConfig.replQueueInterval(Long)
instead
Configuration.AsyncType.replQueueMaxElements(Integer)
FluentConfiguration.AsyncConfig.replQueueMaxElements(Integer)
instead
Configuration.SyncType.replTimeout(Long)
Configuration.StateRetrievalType.retryWaitTimeIncreaseFactor(Integer)
instead
CacheEntry
instead of the corresponding value associated with the key.
CacheLoaderManagerConfig.shared(Boolean)
instead.
FluentGlobalConfiguration.ShutdownConfig.hookBehavior(org.infinispan.config.GlobalConfiguration.ShutdownHookBehavior)
instead
FluentGlobalConfiguration.ShutdownConfig.hookBehavior(org.infinispan.config.GlobalConfiguration.ShutdownHookBehavior)
instead
AsyncStoreConfig.shutdownTimeout(Long)
instead.
CacheStoreConfig.singletonStore()
instead
CacheStoreConfig.singletonStore()
instead.
FluentGlobalConfiguration.TransportConfig.siteId(String)
instead
GlobalConfiguration.TransportType.siteId(String)
instead
Configuration.DeadlockDetectionType.spinDuration(Long)
FluentConfiguration.StateRetrievalConfig.initialRetryWaitTime(Long)
instead
FluentConfiguration.StateRetrievalConfig.initialRetryWaitTime(Long)
instead
FluentConfiguration.StateRetrievalConfig.logFlushTimeout(Long)
instead
FluentConfiguration.StateRetrievalConfig.logFlushTimeout(Long)
instead
FluentConfiguration.StateRetrievalConfig.maxNonProgressingLogWrites(Integer)
instead
FluentConfiguration.StateRetrievalConfig.numRetries(Integer)
instead
FluentConfiguration.StateRetrievalConfig.retryWaitTimeIncreaseFactor(Integer)
instead
FluentConfiguration.StateRetrievalConfig.timeout(Long)
instead
FluentConfiguration.StateRetrievalConfig.timeout(Long)
instead
Configuration.EvictionType.strategy(EvictionStrategy)
FileCacheStoreConfig.streamBufferSize(int)
instead
FluentGlobalConfiguration.TransportConfig.strictPeerToPeer(Boolean)
instead
GlobalConfiguration.TransportType.strictPeerToPeer(Boolean)
instead
FluentConfiguration.TransactionConfig.syncCommitPhase(Boolean)
instead
Configuration.TransactionType.syncCommitPhase(Boolean)
instead
FluentConfiguration.SyncConfig.replTimeout(Long)
instead
FluentConfiguration.SyncConfig.replTimeout(Long)
instead
FluentConfiguration.TransactionConfig.syncRollbackPhase(Boolean)
instead
Configuration.TransactionType.setSyncRollbackPhase(Boolean)
instead
Configuration.EvictionType.threadPolicy(EvictionThreadPolicy)
AsyncStoreConfig.threadPoolSize(Integer)
instead.
Configuration.StateRetrievalType.timeout(Long)
instead
FluentConfiguration.TransactionConfig.transactionManagerLookup(TransactionManagerLookup)
instead
FluentConfiguration.TransactionConfig.transactionManagerLookupClass(Class)
instead
Configuration.TransactionType.transactionManagerLookupClass(Class)
instead
DummyBaseTransactionManager.begin()
method.
DummyUserTransaction.begin()
method.
FluentGlobalConfiguration.TransportConfig.transportClass(Class)
instead
GlobalConfiguration.TransportType.transportClass(Class)
instead
FluentGlobalConfiguration.TransportConfig.nodeName(String)
instead
FluentGlobalConfiguration.TransportConfig.withProperties(java.util.Properties)
or
FluentGlobalConfiguration.TransportConfig.addProperty(String, String)
instead
FluentGlobalConfiguration.TransportConfig.withProperties(java.util.Properties)
or
FluentGlobalConfiguration.TransportConfig.addProperty(String, String)
instead
Configuration.UnsafeType.unreliableReturnValues(Boolean)
instead
FluentConfiguration.UnsafeConfig.unreliableReturnValues(Boolean)
instead
FluentConfiguration.AsyncConfig.asyncMarshalling(Boolean)
instead
FluentConfiguration.TransactionConfig.useEagerLocking(Boolean)
instead
Configuration.TransactionType.useEagerLocking(Boolean)
instead
AbstractFluentConfigurationBean.storeAsBinary()
instead
Configuration.LockingType.useLockStriping(Boolean)
instead
FluentConfiguration.LockingConfig.useLockStriping(Boolean)
instead
Configuration.AsyncType.useReplQueue(Boolean)
FluentConfiguration.AsyncConfig.useReplQueue(Boolean)
instead
GlobalConfiguration.SerializationType.version(String)
instead
FluentConfiguration.ExpirationConfig.wakeUpInterval(Long)
Configuration.LockingType.writeSkewCheck(Boolean)
instead
FluentConfiguration.LockingConfig.writeSkewCheck(Boolean)
instead
MultipleRpcCommand
, but it only aggregates a single command for
replication.Cache
implementation that delegates to a
org.infinispan.Cache
instance supplied at construction
time.CacheManager
implementation that is
backed by an Infinispan EmbeddedCacheManager
instance.FactoryBean
for creating an
SpringEmbeddedCacheManager
instance.CacheManager
implementation that is
backed by an Infinispan RemoteCacheManager
instance.FactoryBean
for creating an
SpringRemoteCacheManager
instance.Environment
, then opens the databases
.
org.infinispan.client.hotrod.RemoteCacheManager
that backs this
SpringRemoteCacheManager
.
StateTransferManager
instances.ComponentStatus.TERMINATED
once it
is done.
EmbeddedCacheManager
this
CacheManager
delegates to.
org.infinispan.client.hotrod.RemoteCacheManager
that backs this
SpringRemoteCacheManager
.
CacheStore.store(org.infinispan.container.entries.InternalCacheEntry)
Marshaller
that supports streams.Element
.
CacheLoader
implemtations thread safe.StripedLock.StripedLock(int)
with a default concurrency value of 20.
ComponentRegistry
,
that are meant to be retained in the component registry even after the component registry is stopped.Synchronization
implementation for integrating with the TM.LocalTransaction
implementation to be used with SynchronizationAdapter
.InternalCacheValue
.
ConsistentHash
implementation
in use by the DistributionManager
changes due to a change in cluster topology.TopologyChanged
.key
value
.
Fqn.SEPARATOR
and joining each subsequent
element with a Fqn.SEPARATOR
.
Properties
instance to an instance of TypedProperties
Properties
instance to an instance of TypedProperties, if needed.
TransactionContext
interface.InfinispanDirectory
,
this factory produces instances of TransactionalSharedLuceneLock
.GlobalTransaction
TransactionCompleted
.TransactionManager
.
if (txLogger.beforeCommand()) {
try {
// execute this command!
} finally {
txLogger.afterCommand(cmd);
}
}
When draining, the following pattern should be used:
List<WriteCommand> c = null;
while (txLogger.shouldDrainWithoutLock()) {
c = txLogger.drain();
applyCommands(c);
}
c = txLogger.drainAndLock();
applyCommands(c);
applyPendingPrepares(txLogger.getPendingPrepares());
txLogger.unlockAndDisable();
Cache
to use different transactional systems.TransactionManager
.
Synchronization
with a registered TransactionManager
.TransactionRegistered
.RemoteTransaction
and TransactionXaAdapter
s (locally originated transactions).TransactionTable
objects.CacheTransaction
and implementor of an XAResource
that will be called by tx manager on various tx stages.InfinispanCollections.MapMakerFunction
TransientCacheEntry
TransientMortalCacheEntry
Transport
objects.Cache
allowing for efficient tree-style access to cached data.TreeCache
Key2StringMapper
and allows a bidirectional transformation between keys and Strings.beforeCommand()
.
ObjectInput
that delegates all methods except ObjectInput.close()
.ObjectOutput
.ObjectName
ComponentsJmxRegistration.registerMBeans()
.
Collection
view of the values contained in this map.
Collection
view of the values contained in this map.
Map.values()
functionality.JBossMarshaller
.ViewChanged
.Map.get(Object)
.
LinkedHashSet
except that it sets the underlying LinkedHashMap
's accessOrder constructor parameter to true, allowing for recording of
visits.Visitor
s, such as CommandInterceptor
s.viewId
has finished.
Inject
annotation, creating more components
as needed based on the Configuration passed in if these additional components don't exist in the ComponentRegistry
.
Flag
s to the scope of a single invocation.
Base64.OutputStream.write(int)
repeatedly until len
bytes are written.
TransactionTable
to be used with TransactionXaAdapter
.
|
--> |