org.infinispan.config
Class Configuration

java.lang.Object
  extended by org.infinispan.config.AbstractConfigurationBean
      extended by org.infinispan.config.AbstractNamedCacheConfigurationBean
          extended by org.infinispan.config.Configuration
All Implemented Interfaces:
Serializable, Cloneable, CloneableConfigurationComponent, JAXBUnmarshallable

Deprecated. This class is deprecated. Use Configuration instead.

@Deprecated
public class Configuration
extends AbstractNamedCacheConfigurationBean

Encapsulates the configuration of a Cache. Configures the default cache which can be retrieved via CacheManager.getCache(). These default settings are also used as a starting point when configuring namedCaches, since the default settings are inherited by any named cache.

Since:
4.0
Author:
Manik Surtani (manik@jboss.org), Vladimir Blagojevic, Galder ZamarreƱo, Mircea.Markus@jboss.com
See Also:
Configuration reference, Serialized Form

Nested Class Summary
static class Configuration.AsyncType
          Deprecated. 
static class Configuration.BooleanAttributeType
          Deprecated. 
static class Configuration.CacheMode
          Deprecated. 
static class Configuration.ClusteringType
          Deprecated. 
static class Configuration.ClusteringTypeAdapter
          Deprecated. 
static class Configuration.CustomInterceptorPositionType
          Deprecated. 
static class Configuration.CustomInterceptorsType
          Deprecated. 
static class Configuration.DataContainerType
          Deprecated. 
static class Configuration.DeadlockDetectionType
          Deprecated. 
static class Configuration.EvictionType
          Deprecated. 
static class Configuration.ExpirationType
          Deprecated. 
static class Configuration.HashType
          Deprecated. 
static class Configuration.InvocationBatching
          Deprecated. 
static class Configuration.JmxStatistics
          Deprecated. 
static class Configuration.L1Type
          Deprecated. 
static class Configuration.LazyDeserialization
          Deprecated. 
static class Configuration.LockingType
          Deprecated. 
static class Configuration.QueryConfigurationBean
          Deprecated. 
static class Configuration.RecoveryType
          Deprecated. 
static class Configuration.StateRetrievalType
          Deprecated. 
static class Configuration.StoreAsBinary
          Deprecated. 
static class Configuration.SyncType
          Deprecated. 
static class Configuration.TransactionType
          Deprecated. 
static class Configuration.UnsafeType
          Deprecated. 
static class Configuration.VersioningConfigurationBean
          Deprecated. 
 
Field Summary
protected  String name
          Deprecated.  
 
Fields inherited from class org.infinispan.config.AbstractNamedCacheConfigurationBean
cr
 
Fields inherited from class org.infinispan.config.AbstractConfigurationBean
overriddenConfigurationElements
 
Constructor Summary
Configuration()
          Deprecated.  
 
Method Summary
 void accept(ConfigurationBeanVisitor v)
          Deprecated.  
 void applyOverrides(Configuration overrides)
          Deprecated.  
 void assertValid()
          Deprecated.  
 Configuration clone()
          Deprecated.  
 boolean equals(Object o)
          Deprecated. Also see equalsIgnoreName(Object) for equality that does not consider the name of the configuration.
 boolean equalsIgnoreName(Object o)
          Deprecated. Same as equals(Object) but it ignores the getName() attribute in the comparison.
 FluentConfiguration fluent()
          Deprecated.  
 CacheLoaderManagerConfig getCacheLoaderManagerConfig()
          Deprecated. Use getCacheLoaders(), isCacheLoaderShared() isFetchPersistentState(), isCacheLoaderPassivation() and isCacheLoaderPreload() instead
 List<CacheLoaderConfig> getCacheLoaders()
          Deprecated.  
 Configuration.CacheMode getCacheMode()
          Deprecated.  
 String getCacheModeString()
          Deprecated.  
 int getCacheStopTimeout()
          Deprecated.  
 ClassLoader getClassLoader()
          Deprecated.  
 int getConcurrencyLevel()
          Deprecated.  
 String getConsistentHashClass()
          Deprecated.  
 List<CustomInterceptorConfig> getCustomInterceptors()
          Deprecated. Returns the CustomInterceptorConfig, if any, associated with this configuration object.
 DataContainer getDataContainer()
          Deprecated.  
 String getDataContainerClass()
          Deprecated. Pluggable data container class which must implement DataContainer
 TypedProperties getDataContainerProperties()
          Deprecated.  
 long getDeadlockDetectionSpinDuration()
          Deprecated.  
 int getEvictionMaxEntries()
          Deprecated.  
 EvictionStrategy getEvictionStrategy()
          Deprecated.  
 EvictionThreadPolicy getEvictionThreadPolicy()
          Deprecated.  
 long getEvictionWakeUpInterval()
          Deprecated. Use getExpirationWakeUpInterval()
 long getExpirationLifespan()
          Deprecated. Expiration lifespan, in milliseconds
 long getExpirationMaxIdle()
          Deprecated. Expiration max idle time, in milliseconds
 long getExpirationWakeUpInterval()
          Deprecated. Eviction thread wake up interval, in milliseconds.
 GlobalConfiguration getGlobalConfiguration()
          Deprecated.  
 List<Grouper<?>> getGroupers()
          Deprecated.  
 String getHashFunctionClass()
          Deprecated.  
 TypedProperties getIndexingProperties()
          Deprecated.  
 IsolationLevel getIsolationLevel()
          Deprecated.  
 long getL1InvalidationCleanupTaskFrequency()
          Deprecated.  
 int getL1InvalidationThreshold()
          Deprecated.  
 long getL1Lifespan()
          Deprecated.  
 long getLockAcquisitionTimeout()
          Deprecated.  
 String getName()
          Deprecated. Returns the name of the cache associated with this configuration.
 int getNumOwners()
          Deprecated.  
 int getNumVirtualNodes()
          Deprecated.  
 long getRehashRpcTimeout()
          Deprecated.  
 long getRehashWaitTime()
          Deprecated.  
 String getReplQueueClass()
          Deprecated.  
 long getReplQueueInterval()
          Deprecated.  
 int getReplQueueMaxElements()
          Deprecated.  
 int getStateRetrievalChunkSize()
          Deprecated.  
 long getStateRetrievalInitialRetryWaitTime()
          Deprecated.  
 long getStateRetrievalLogFlushTimeout()
          Deprecated.  
 int getStateRetrievalMaxNonProgressingLogWrites()
          Deprecated.  
 int getStateRetrievalNumRetries()
          Deprecated.  
 int getStateRetrievalRetryWaitTimeIncreaseFactor()
          Deprecated.  
 long getStateRetrievalTimeout()
          Deprecated.  
 long getSyncReplTimeout()
          Deprecated.  
 LockingMode getTransactionLockingMode()
          Deprecated. Returns the locking mode for this cache.
 TransactionManagerLookup getTransactionManagerLookup()
          Deprecated.  
 String getTransactionManagerLookupClass()
          Deprecated.  
 TransactionMode getTransactionMode()
          Deprecated. Returns cache's transaction mode.
 String getTransactionRecoveryCacheName()
          Deprecated. Returns the name of the cache used in order to keep recovery information.
 TransactionSynchronizationRegistryLookup getTransactionSynchronizationRegistryLookup()
          Deprecated.  
 VersioningScheme getVersioningScheme()
          Deprecated. 
 boolean hasConsistentHashClass()
          Deprecated.  
 int hashCode()
          Deprecated.  
 void inject(ComponentRegistry cr)
          Deprecated.  
 boolean isAlwaysProvideInMemoryState()
          Deprecated.  
 boolean isCacheLoaderPassivation()
          Deprecated.  
 boolean isCacheLoaderPreload()
          Deprecated.  
 boolean isCacheLoaderShared()
          Deprecated.  
 boolean isCustomConsistentHashClass()
          Deprecated.  
 boolean isCustomHashFunctionClass()
          Deprecated.  
 boolean isDeadlockDetectionEnabled()
          Deprecated.  
 boolean isEagerLockingSingleNodeInUse()
          Deprecated. this is deprecated as starting with Infinispan 5.1 a single lock is always acquired disregarding the number of owner.
 boolean isEagerLockSingleNode()
          Deprecated. starting with Infinispan 5.1 single node locking is used by default
 boolean isEnableDeadlockDetection()
          Deprecated. Use isDeadlockDetectionEnabled() instead.
 boolean isEnableVersioning()
          Deprecated. 
 boolean isExpirationReaperEnabled()
          Deprecated.  
 boolean isExposeJmxStatistics()
          Deprecated.  
 boolean isFetchInMemoryState()
          Deprecated.  
 boolean isFetchPersistentState()
          Deprecated.  
 boolean isGroupsEnabled()
          Deprecated.  
 boolean isHashActivated()
          Deprecated.  
 boolean isIndexingEnabled()
          Deprecated.  
 boolean isIndexLocalOnly()
          Deprecated.  
 boolean isInvocationBatchingEnabled()
          Deprecated.  
 boolean isL1CacheActivated()
          Deprecated.  
 boolean isL1CacheEnabled()
          Deprecated.  
 boolean isL1OnRehash()
          Deprecated.  
 boolean isOnePhaseCommit()
          Deprecated.  
 boolean isRehashEnabled()
          Deprecated.  
 boolean isSecondPhaseAsync()
          Deprecated. Returns true if the 2nd phase of the 2PC (i.e.
 boolean isStateTransferEnabled()
          Deprecated.  
 boolean isStoreAsBinary()
          Deprecated.  
 boolean isStoreKeysAsBinary()
          Deprecated.  
 boolean isStoreValuesAsBinary()
          Deprecated.  
 boolean isSyncCommitPhase()
          Deprecated. Important - to be used with caution: if you have two transactions writing to the same key concurrently and the commit is configured to be performed asynchronously then inconsistencies might happen.
 boolean isSyncRollbackPhase()
          Deprecated.  
 boolean isTransactionalCache()
          Deprecated. Returns true if the cache is configured to run in transactional mode, false otherwise.
 boolean isTransactionAutoCommit()
          Deprecated. If the cache is transactional (i.e.
 boolean isTransactionRecoveryEnabled()
          Deprecated. Returns true if transaction recovery information is collected.
 boolean isUnsafeUnreliableReturnValues()
          Deprecated.  
 boolean isUse1PcForAutoCommitTransactions()
          Deprecated. Enabling this would cause autoCommit transactions (isTransactionAutoCommit()) to complete with 1 RPC instead of 2 RPCs (which is default).
 boolean isUseAsyncMarshalling()
          Deprecated.  
 boolean isUseEagerLocking()
          Deprecated. 
 boolean isUseLazyDeserialization()
          Deprecated. Use isStoreAsBinary()
 boolean isUseLockStriping()
          Deprecated.  
 boolean isUseReplQueue()
          Deprecated.  
 boolean isUseSynchronizationForTransactions()
          Deprecated. If enabled Infinispan enlists within transactions as a Synchronization.
 boolean isUsingCacheLoaders()
          Deprecated.  
 boolean isWriteSkewCheck()
          Deprecated.  
 void setAlwaysProvideInMemoryState(boolean alwaysProvideInMemoryState)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.alwaysProvideInMemoryState(Boolean) instead
 void setCacheLoaderManagerConfig(CacheLoaderManagerConfig cacheLoaderManagerConfig)
          Deprecated. Use FluentConfiguration.LoadersConfig.addCacheLoader(org.infinispan.loaders.CacheLoaderConfig...) instead
 void setCacheMode(Configuration.CacheMode cacheModeInt)
          Deprecated. Use FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode) instead
 void setCacheMode(String cacheMode)
          Deprecated. Use FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode) instead
 void setCacheModeString(String cacheMode)
          Deprecated. Use FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode) instead
 Configuration setCacheStopTimeout(int cacheStopTimeout)
          Deprecated. Use FluentConfiguration.TransactionConfig.cacheStopTimeout(Integer) instead
 void setClassLoader(ClassLoader cl)
          Deprecated.  
 void setConcurrencyLevel(int concurrencyLevel)
          Deprecated. Use FluentConfiguration.LockingConfig.concurrencyLevel(Integer) instead
 void setConsistentHashClass(String consistentHashClass)
          Deprecated. Use FluentConfiguration.HashConfig.consistentHashClass(Class) instead
 void setCustomInterceptors(List<CustomInterceptorConfig> customInterceptors)
          Deprecated. Use FluentConfiguration.CustomInterceptorCumulator.add(org.infinispan.interceptors.base.CommandInterceptor)
 void setDeadlockDetectionSpinDuration(long eagerDeadlockSpinDuration)
          Deprecated. Use FluentConfiguration.DeadlockDetectionConfig.spinDuration(Long) instead
 void setEagerLockSingleNode(boolean eagerLockSingleNode)
          Deprecated. Use FluentConfiguration.TransactionConfig.eagerLockSingleNode(Boolean) instead
 void setEnableDeadlockDetection(boolean useEagerDeadlockDetection)
          Deprecated. Use AbstractFluentConfigurationBean.deadlockDetection() instead
 void setEnableVersioning(boolean enabled)
          Deprecated. 
 void setEvictionMaxEntries(int evictionMaxEntries)
          Deprecated. Use FluentConfiguration.EvictionConfig.maxEntries(Integer) instead
 void setEvictionStrategy(EvictionStrategy evictionStrategy)
          Deprecated. Use FluentConfiguration.EvictionConfig.strategy(org.infinispan.eviction.EvictionStrategy) instead
 void setEvictionStrategy(String eStrategy)
          Deprecated. Use FluentConfiguration.EvictionConfig.strategy(org.infinispan.eviction.EvictionStrategy) instead
 void setEvictionThreadPolicy(EvictionThreadPolicy policy)
          Deprecated. Use FluentConfiguration.EvictionConfig.threadPolicy(org.infinispan.eviction.EvictionThreadPolicy) instead
 void setEvictionThreadPolicy(String policy)
          Deprecated. Use FluentConfiguration.EvictionConfig.threadPolicy(org.infinispan.eviction.EvictionThreadPolicy) instead
 void setEvictionWakeUpInterval(long evictionWakeUpInterval)
          Deprecated. Use FluentConfiguration.ExpirationConfig.wakeUpInterval(Long) instead
 void setExpirationLifespan(long expirationLifespan)
          Deprecated. Use FluentConfiguration.ExpirationConfig.lifespan(Long) instead
 void setExpirationMaxIdle(long expirationMaxIdle)
          Deprecated. Use FluentConfiguration.ExpirationConfig.maxIdle(Long) instead
 void setExposeJmxStatistics(boolean useMbean)
          Deprecated. Use AbstractFluentConfigurationBean.jmxStatistics() instead
 void setFetchInMemoryState(boolean fetchInMemoryState)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.fetchInMemoryState(Boolean) instead
 void setGlobalConfiguration(GlobalConfiguration gc)
          Deprecated.  
 void setHashFunctionClass(String hashFunctionClass)
          Deprecated. Use FluentConfiguration.HashConfig.hashFunctionClass(Class) instead
 void setIndexingEnabled(boolean enabled)
          Deprecated. Use AbstractFluentConfigurationBean.indexing() instead
 void setIndexLocalOnly(boolean indexLocalOnly)
          Deprecated. Use FluentConfiguration.IndexingConfig.indexLocalOnly(Boolean) instead
 void setInvocationBatchingEnabled(boolean enabled)
          Deprecated. Use AbstractFluentConfigurationBean.invocationBatching() instead
 void setIsolationLevel(IsolationLevel isolationLevel)
          Deprecated. Use FluentConfiguration.LockingConfig.isolationLevel(org.infinispan.util.concurrent.IsolationLevel) instead
 void setIsolationLevel(String isolationLevel)
          Deprecated. Use FluentConfiguration.LockingConfig.isolationLevel(org.infinispan.util.concurrent.IsolationLevel) instead
 void setL1CacheEnabled(boolean l1CacheEnabled)
          Deprecated. Use AbstractFluentConfigurationBean.l1() instead
 void setL1InvalidationCleanupTaskFrequency(long frequencyMillis)
          Deprecated.  
 void setL1InvalidationThreshold(int threshold)
          Deprecated. Use FluentConfiguration.L1Config.invalidationThreshold(Integer) instead
 void setL1Lifespan(long l1Lifespan)
          Deprecated. Use FluentConfiguration.L1Config.lifespan(Long) instead
 void setL1OnRehash(boolean l1OnRehash)
          Deprecated. Use FluentConfiguration.L1Config.onRehash(Boolean) instead
 void setLockAcquisitionTimeout(long lockAcquisitionTimeout)
          Deprecated. Use FluentConfiguration.LockingConfig.lockAcquisitionTimeout(Long) instead
 void setLockAcquisitionTimeout(long lockAcquisitionTimeout, TimeUnit timeUnit)
          Deprecated. Use FluentConfiguration.LockingConfig.lockAcquisitionTimeout(Long) instead
 void setNumOwners(int numOwners)
          Deprecated. Use FluentConfiguration.HashConfig.numOwners(Integer) instead
 void setRehashEnabled(boolean rehashEnabled)
          Deprecated. Use FluentConfiguration.HashConfig.rehashEnabled(Boolean) instead
 void setRehashRpcTimeout(long rehashRpcTimeout)
          Deprecated. Use FluentConfiguration.HashConfig.rehashRpcTimeout(Long) instead
 void setRehashWaitTime(long rehashWaitTime)
          Deprecated. Use FluentConfiguration.HashConfig.rehashWait(Long) instead
 void setReplQueueClass(String classname)
          Deprecated. Use FluentConfiguration.AsyncConfig.replQueueClass(Class) instead
 void setReplQueueInterval(long replQueueInterval)
          Deprecated. Use FluentConfiguration.AsyncConfig.replQueueInterval(Long) instead
 void setReplQueueInterval(long replQueueInterval, TimeUnit timeUnit)
          Deprecated. Use FluentConfiguration.AsyncConfig.replQueueInterval(Long) instead
 void setReplQueueMaxElements(int replQueueMaxElements)
          Deprecated. Use FluentConfiguration.AsyncConfig.replQueueMaxElements(Integer) instead
 void setStateRetrievalChunkSize(int chunkSize)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.chunkSize(Integer) instead
 void setStateRetrievalInitialRetryWaitTime(long initialRetryWaitTime)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.initialRetryWaitTime(Long) instead
 void setStateRetrievalInitialRetryWaitTime(long initialRetryWaitTime, TimeUnit timeUnit)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.initialRetryWaitTime(Long) instead
 void setStateRetrievalLogFlushTimeout(long logFlushTimeout)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.logFlushTimeout(Long) instead
 void setStateRetrievalLogFlushTimeout(long logFlushTimeout, TimeUnit timeUnit)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.logFlushTimeout(Long) instead
 void setStateRetrievalMaxNonProgressingLogWrites(int maxNonProgressingLogWrites)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.maxNonProgressingLogWrites(Integer) instead
 void setStateRetrievalNumRetries(int numRetries)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.numRetries(Integer) instead
 void setStateRetrievalRetryWaitTimeIncreaseFactor(int retryWaitTimeIncreaseFactor)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.retryWaitTimeIncreaseFactor(Integer) instead
 void setStateRetrievalTimeout(long stateRetrievalTimeout)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.timeout(Long) instead
 void setStateRetrievalTimeout(long stateRetrievalTimeout, TimeUnit timeUnit)
          Deprecated. Use FluentConfiguration.StateRetrievalConfig.timeout(Long) instead
 void setSyncCommitPhase(boolean syncCommitPhase)
          Deprecated. Use FluentConfiguration.TransactionConfig.syncCommitPhase(Boolean) instead
 void setSyncReplTimeout(long syncReplTimeout)
          Deprecated. Use FluentConfiguration.SyncConfig.replTimeout(Long) instead
 void setSyncReplTimeout(long syncReplTimeout, TimeUnit timeUnit)
          Deprecated. Use FluentConfiguration.SyncConfig.replTimeout(Long) instead
 void setSyncRollbackPhase(boolean syncRollbackPhase)
          Deprecated. Use FluentConfiguration.TransactionConfig.syncRollbackPhase(Boolean) instead
 void setTransactionManagerLookup(TransactionManagerLookup transactionManagerLookup)
          Deprecated. Use FluentConfiguration.TransactionConfig.transactionManagerLookup(TransactionManagerLookup) instead
 void setTransactionManagerLookupClass(String transactionManagerLookupClass)
          Deprecated. Use FluentConfiguration.TransactionConfig.transactionManagerLookupClass(Class) instead
 void setUnsafeUnreliableReturnValues(boolean unsafeUnreliableReturnValues)
          Deprecated. Use FluentConfiguration.UnsafeConfig.unreliableReturnValues(Boolean) instead
 void setUseAsyncMarshalling(boolean useAsyncMarshalling)
          Deprecated. Use FluentConfiguration.AsyncConfig.asyncMarshalling(Boolean) instead
 void setUseEagerLocking(boolean useEagerLocking)
          Deprecated. Use FluentConfiguration.TransactionConfig.useEagerLocking(Boolean) instead
 void setUseLazyDeserialization(boolean useLazyDeserialization)
          Deprecated. Use AbstractFluentConfigurationBean.storeAsBinary() instead
 void setUseLockStriping(boolean useLockStriping)
          Deprecated. Use FluentConfiguration.LockingConfig.useLockStriping(Boolean) instead
 void setUseReplQueue(boolean useReplQueue)
          Deprecated. Use FluentConfiguration.AsyncConfig.useReplQueue(Boolean) instead
 void setVersioningScheme(VersioningScheme versioningScheme)
          Deprecated. 
 void setWriteSkewCheck(boolean writeSkewCheck)
          Deprecated. Use FluentConfiguration.LockingConfig.writeSkewCheck(Boolean) instead
 String toXmlString()
          Deprecated. Converts this configuration instance to an XML representation containing the current settings.
 
Methods inherited from class org.infinispan.config.AbstractNamedCacheConfigurationBean
hasComponentStarted
 
Methods inherited from class org.infinispan.config.AbstractConfigurationBean
testImmutability, toTypedProperties, toTypedProperties, uc, willUnmarshall
 
Methods inherited from class java.lang.Object
finalize, getClass, notify, notifyAll, toString, wait, wait, wait
 

Field Detail

name

protected String name
Deprecated. 
Constructor Detail

Configuration

public Configuration()
Deprecated. 
Method Detail

applyOverrides

public void applyOverrides(Configuration overrides)
Deprecated. 

inject

public void inject(ComponentRegistry cr)
Deprecated. 
Overrides:
inject in class AbstractNamedCacheConfigurationBean

fluent

public FluentConfiguration fluent()
Deprecated. 

getGlobalConfiguration

public GlobalConfiguration getGlobalConfiguration()
Deprecated. 

setGlobalConfiguration

public void setGlobalConfiguration(GlobalConfiguration gc)
Deprecated. 

getName

public final String getName()
Deprecated. 
Returns the name of the cache associated with this configuration.


getClassLoader

public ClassLoader getClassLoader()
Deprecated. 

setClassLoader

public void setClassLoader(ClassLoader cl)
Deprecated. 

isStateTransferEnabled

public boolean isStateTransferEnabled()
Deprecated. 

getDeadlockDetectionSpinDuration

public long getDeadlockDetectionSpinDuration()
Deprecated. 

setDeadlockDetectionSpinDuration

@Deprecated
public void setDeadlockDetectionSpinDuration(long eagerDeadlockSpinDuration)
Deprecated. Use FluentConfiguration.DeadlockDetectionConfig.spinDuration(Long) instead

Time period that determines how often is lock acquisition attempted within maximum time allowed to acquire a particular lock

Parameters:
eagerDeadlockSpinDuration -

isEnableDeadlockDetection

@Deprecated
public boolean isEnableDeadlockDetection()
Deprecated. Use isDeadlockDetectionEnabled() instead.


isDeadlockDetectionEnabled

public boolean isDeadlockDetectionEnabled()
Deprecated. 

setEnableDeadlockDetection

@Deprecated
public void setEnableDeadlockDetection(boolean useEagerDeadlockDetection)
Deprecated. Use AbstractFluentConfigurationBean.deadlockDetection() instead

Toggle to enable/disable deadlock detection

Parameters:
useEagerDeadlockDetection -

setUseLockStriping

@Deprecated
public void setUseLockStriping(boolean useLockStriping)
Deprecated. Use FluentConfiguration.LockingConfig.useLockStriping(Boolean) instead

If true, a pool of shared locks is maintained for all entries that need to be locked. Otherwise, a lock is created per entry in the cache. Lock striping helps control memory footprint but may reduce concurrency in the system.

Parameters:
useLockStriping -

isUseLockStriping

public boolean isUseLockStriping()
Deprecated. 

isUnsafeUnreliableReturnValues

public boolean isUnsafeUnreliableReturnValues()
Deprecated. 

setUnsafeUnreliableReturnValues

@Deprecated
public void setUnsafeUnreliableReturnValues(boolean unsafeUnreliableReturnValues)
Deprecated. Use FluentConfiguration.UnsafeConfig.unreliableReturnValues(Boolean) instead

Toggle to enable/disable return value fetching

Parameters:
unsafeUnreliableReturnValues -

setRehashRpcTimeout

@Deprecated
public void setRehashRpcTimeout(long rehashRpcTimeout)
Deprecated. Use FluentConfiguration.HashConfig.rehashRpcTimeout(Long) instead

Rehashing timeout

Parameters:
rehashRpcTimeout -

getRehashRpcTimeout

public long getRehashRpcTimeout()
Deprecated. 

isWriteSkewCheck

public boolean isWriteSkewCheck()
Deprecated. 

setWriteSkewCheck

@Deprecated
public void setWriteSkewCheck(boolean writeSkewCheck)
Deprecated. Use FluentConfiguration.LockingConfig.writeSkewCheck(Boolean) instead

This setting is only applicable in the case of REPEATABLE_READ. When write skew check is set to false, if the writer at commit time discovers that the working entry and the underlying entry have different versions, the working entry will overwrite the underlying entry. If true, such version conflict - known as a write-skew - will throw an Exception.

Parameters:
writeSkewCheck -

getConcurrencyLevel

public int getConcurrencyLevel()
Deprecated. 

setConcurrencyLevel

@Deprecated
public void setConcurrencyLevel(int concurrencyLevel)
Deprecated. Use FluentConfiguration.LockingConfig.concurrencyLevel(Integer) instead

Concurrency level for lock containers. Adjust this value according to the number of concurrent threads interating with Infinispan. Similar to the concurrencyLevel tuning parameter seen in the JDK's ConcurrentHashMap.

Parameters:
concurrencyLevel -

setReplQueueMaxElements

@Deprecated
public void setReplQueueMaxElements(int replQueueMaxElements)
Deprecated. Use FluentConfiguration.AsyncConfig.replQueueMaxElements(Integer) instead

If useReplQueue is set to true, this attribute can be used to trigger flushing of the queue when it reaches a specific threshold.

Parameters:
replQueueMaxElements -

setReplQueueInterval

@Deprecated
public void setReplQueueInterval(long replQueueInterval)
Deprecated. Use FluentConfiguration.AsyncConfig.replQueueInterval(Long) instead

If useReplQueue is set to true, this attribute controls how often the asynchronous thread used to flush the replication queue runs. This should be a positive integer which represents thread wakeup time in milliseconds.

Parameters:
replQueueInterval -

setReplQueueInterval

@Deprecated
public void setReplQueueInterval(long replQueueInterval,
                                            TimeUnit timeUnit)
Deprecated. Use FluentConfiguration.AsyncConfig.replQueueInterval(Long) instead


setReplQueueClass

@Deprecated
public void setReplQueueClass(String classname)
Deprecated. Use FluentConfiguration.AsyncConfig.replQueueClass(Class) instead

This overrides the replication queue implementation class. Overriding the default allows you to add behavior to the queue, typically by subclassing the default implementation.

Parameters:
classname -

setExposeJmxStatistics

@Deprecated
public void setExposeJmxStatistics(boolean useMbean)
Deprecated. Use AbstractFluentConfigurationBean.jmxStatistics() instead


setInvocationBatchingEnabled

@Deprecated
public void setInvocationBatchingEnabled(boolean enabled)
Deprecated. Use AbstractFluentConfigurationBean.invocationBatching() instead

Enables invocation batching if set to true. You still need to use Cache.startBatch() and Cache.endBatch(boolean) to demarcate the start and end of batches.

Parameters:
enabled - if true, batching is enabled.
Since:
4.0

setFetchInMemoryState

@Deprecated
public void setFetchInMemoryState(boolean fetchInMemoryState)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.fetchInMemoryState(Boolean) instead

If true, this will cause the cache to ask neighboring caches for state when it starts up, so the cache starts 'warm', although it will impact startup time.

Parameters:
fetchInMemoryState -

setAlwaysProvideInMemoryState

@Deprecated
public void setAlwaysProvideInMemoryState(boolean alwaysProvideInMemoryState)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.alwaysProvideInMemoryState(Boolean) instead

If true, this will allow the cache to provide in-memory state to a neighbor, even if the cache is not configured to fetch state from its neighbors (fetchInMemoryState is false)

Parameters:
alwaysProvideInMemoryState -

setLockAcquisitionTimeout

@Deprecated
public void setLockAcquisitionTimeout(long lockAcquisitionTimeout)
Deprecated. Use FluentConfiguration.LockingConfig.lockAcquisitionTimeout(Long) instead

Maximum time to attempt a particular lock acquisition

Parameters:
lockAcquisitionTimeout -

setLockAcquisitionTimeout

@Deprecated
public void setLockAcquisitionTimeout(long lockAcquisitionTimeout,
                                                 TimeUnit timeUnit)
Deprecated. Use FluentConfiguration.LockingConfig.lockAcquisitionTimeout(Long) instead

Maximum time to attempt a particular lock acquisition

Parameters:
lockAcquisitionTimeout -
timeUnit -

setSyncReplTimeout

@Deprecated
public void setSyncReplTimeout(long syncReplTimeout)
Deprecated. Use FluentConfiguration.SyncConfig.replTimeout(Long) instead

This is the timeout (in ms) used to wait for an acknowledgment when making a remote call, after which the call is aborted and an exception is thrown.

Parameters:
syncReplTimeout -

setSyncReplTimeout

@Deprecated
public void setSyncReplTimeout(long syncReplTimeout,
                                          TimeUnit timeUnit)
Deprecated. Use FluentConfiguration.SyncConfig.replTimeout(Long) instead

This is the timeout used to wait for an acknowledgment when making a remote call, after which the call is aborted and an exception is thrown.

Parameters:
syncReplTimeout -
timeUnit -

setCacheMode

@Deprecated
public void setCacheMode(Configuration.CacheMode cacheModeInt)
Deprecated. Use FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode) instead

Cache mode. For distribution, set mode to either 'd', 'dist' or 'distribution'. For replication, use either 'r', 'repl' or 'replication'. Finally, for invalidation, 'i', 'inv' or 'invalidation'. If the cache mode is set to 'l' or 'local', the cache in question will not support clustering even if its cache manager does. When no transport is enabled, the default is 'local' (instead of 'dist').


setCacheMode

@Deprecated
public void setCacheMode(String cacheMode)
Deprecated. Use FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode) instead

Cache mode. For distribution, set mode to either 'd', 'dist' or 'distribution'. For replication, use either 'r', 'repl' or 'replication'. Finally, for invalidation, 'i', 'inv' or 'invalidation'. If the cache mode is set to 'l' or 'local', the cache in question will not support clustering even if its cache manager does. When no transport is enabled, the default is 'local' (instead of 'dist').


getCacheModeString

public String getCacheModeString()
Deprecated. 

setCacheModeString

@Deprecated
public void setCacheModeString(String cacheMode)
Deprecated. Use FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode) instead


getDataContainerClass

public String getDataContainerClass()
Deprecated. 
Pluggable data container class which must implement DataContainer


getDataContainer

public DataContainer getDataContainer()
Deprecated. 

getDataContainerProperties

public TypedProperties getDataContainerProperties()
Deprecated. 

getEvictionWakeUpInterval

@Deprecated
public long getEvictionWakeUpInterval()
Deprecated. Use getExpirationWakeUpInterval()


setEvictionWakeUpInterval

@Deprecated
public void setEvictionWakeUpInterval(long evictionWakeUpInterval)
Deprecated. Use FluentConfiguration.ExpirationConfig.wakeUpInterval(Long) instead


getEvictionStrategy

public EvictionStrategy getEvictionStrategy()
Deprecated. 

setEvictionStrategy

@Deprecated
public void setEvictionStrategy(EvictionStrategy evictionStrategy)
Deprecated. Use FluentConfiguration.EvictionConfig.strategy(org.infinispan.eviction.EvictionStrategy) instead

Eviction strategy. Available options are 'UNORDERED', 'FIFO', 'LRU', 'LIRS' and 'NONE' (to disable eviction).

Parameters:
evictionStrategy -

setEvictionStrategy

@Deprecated
public void setEvictionStrategy(String eStrategy)
Deprecated. Use FluentConfiguration.EvictionConfig.strategy(org.infinispan.eviction.EvictionStrategy) instead

Eviction strategy. Available options are 'UNORDERED', 'FIFO', 'LRU', 'LIRS' and 'NONE' (to disable eviction).

Parameters:
eStrategy -

getEvictionThreadPolicy

public EvictionThreadPolicy getEvictionThreadPolicy()
Deprecated. 

setEvictionThreadPolicy

@Deprecated
public void setEvictionThreadPolicy(EvictionThreadPolicy policy)
Deprecated. Use FluentConfiguration.EvictionConfig.threadPolicy(org.infinispan.eviction.EvictionThreadPolicy) instead

Threading policy for eviction.

Parameters:
policy -

setEvictionThreadPolicy

@Deprecated
public void setEvictionThreadPolicy(String policy)
Deprecated. Use FluentConfiguration.EvictionConfig.threadPolicy(org.infinispan.eviction.EvictionThreadPolicy) instead

Threading policy for eviction.

Parameters:
policy -

getEvictionMaxEntries

public int getEvictionMaxEntries()
Deprecated. 

setEvictionMaxEntries

@Deprecated
public void setEvictionMaxEntries(int evictionMaxEntries)
Deprecated. Use FluentConfiguration.EvictionConfig.maxEntries(Integer) instead

Maximum number of entries in a cache instance. If selected value is not a power of two the actual value will default to the least power of two larger than selected value. -1 means no limit.

Parameters:
evictionMaxEntries -

setVersioningScheme

@Deprecated
public void setVersioningScheme(VersioningScheme versioningScheme)
Deprecated. 


setEnableVersioning

@Deprecated
public void setEnableVersioning(boolean enabled)
Deprecated. 


getExpirationLifespan

public long getExpirationLifespan()
Deprecated. 
Expiration lifespan, in milliseconds


getVersioningScheme

@Deprecated
public VersioningScheme getVersioningScheme()
Deprecated. 


isEnableVersioning

@Deprecated
public boolean isEnableVersioning()
Deprecated. 


setExpirationLifespan

@Deprecated
public void setExpirationLifespan(long expirationLifespan)
Deprecated. Use FluentConfiguration.ExpirationConfig.lifespan(Long) instead

Maximum lifespan of a cache entry, after which the entry is expired cluster-wide, in milliseconds. -1 means the entries never expire.

Note that this can be overriden on a per-entry basis by using the Cache API.

Parameters:
expirationLifespan -

getExpirationMaxIdle

public long getExpirationMaxIdle()
Deprecated. 
Expiration max idle time, in milliseconds


setExpirationMaxIdle

@Deprecated
public void setExpirationMaxIdle(long expirationMaxIdle)
Deprecated. Use FluentConfiguration.ExpirationConfig.maxIdle(Long) instead

Maximum idle time a cache entry will be maintained in the cache, in milliseconds. If the idle time is exceeded, the entry will be expired cluster-wide. -1 means the entries never expire.

Note that this can be overriden on a per-entry basis by using the Cache API.

Parameters:
expirationMaxIdle -

getExpirationWakeUpInterval

public long getExpirationWakeUpInterval()
Deprecated. 
Eviction thread wake up interval, in milliseconds.


setTransactionManagerLookupClass

@Deprecated
public void setTransactionManagerLookupClass(String transactionManagerLookupClass)
Deprecated. Use FluentConfiguration.TransactionConfig.transactionManagerLookupClass(Class) instead

Fully qualified class name of a class that looks up a reference to a TransactionManager. The default provided is capable of locating the default TransactionManager in most popular Java EE systems, using a JNDI lookup. Calling this method marks the cache as transactional.

Parameters:
transactionManagerLookupClass -

setTransactionManagerLookup

@Deprecated
public void setTransactionManagerLookup(TransactionManagerLookup transactionManagerLookup)
Deprecated. Use FluentConfiguration.TransactionConfig.transactionManagerLookup(TransactionManagerLookup) instead


setCacheLoaderManagerConfig

@Deprecated
public void setCacheLoaderManagerConfig(CacheLoaderManagerConfig cacheLoaderManagerConfig)
Deprecated. Use FluentConfiguration.LoadersConfig.addCacheLoader(org.infinispan.loaders.CacheLoaderConfig...) instead


setSyncCommitPhase

@Deprecated
public void setSyncCommitPhase(boolean syncCommitPhase)
Deprecated. Use FluentConfiguration.TransactionConfig.syncCommitPhase(Boolean) instead

If true, the cluster-wide commit phase in two-phase commit (2PC) transactions will be synchronous, so Infinispan will wait for responses from all nodes to which the commit was sent. Otherwise, the commit phase will be asynchronous. Keeping it as false improves performance of 2PC transactions, since any remote failures are trapped during the prepare phase anyway and appropriate rollbacks are issued.

Parameters:
syncCommitPhase -

setSyncRollbackPhase

@Deprecated
public void setSyncRollbackPhase(boolean syncRollbackPhase)
Deprecated. Use FluentConfiguration.TransactionConfig.syncRollbackPhase(Boolean) instead

If true, the cluster-wide rollback phase in two-phase commit (2PC) transactions will be synchronous, so Infinispan will wait for responses from all nodes to which the rollback was sent. Otherwise, the rollback phase will be asynchronous. Keeping it as false improves performance of 2PC transactions.

Parameters:
syncRollbackPhase -

setUseEagerLocking

@Deprecated
public void setUseEagerLocking(boolean useEagerLocking)
Deprecated. Use FluentConfiguration.TransactionConfig.useEagerLocking(Boolean) instead

Only has effect for DIST mode and when useEagerLocking is set to true. When this is enabled, then only one node is locked in the cluster, disregarding numOwners config. On the opposite, if this is false, then on all cache.lock() calls numOwners RPCs are being performed. The node that gets locked is the main data owner, i.e. the node where data would reside if numOwners==1. If the node where the lock resides crashes, then the transaction is marked for rollback - data is in a consistent state, no fault tolerance.

Parameters:
useEagerLocking -

setEagerLockSingleNode

@Deprecated
public void setEagerLockSingleNode(boolean eagerLockSingleNode)
Deprecated. Use FluentConfiguration.TransactionConfig.eagerLockSingleNode(Boolean) instead

Only has effect for DIST mode and when useEagerLocking is set to true. When this is enabled, then only one node is locked in the cluster, disregarding numOwners config. On the opposite, if this is false, then on all cache.lock() calls numOwners RPCs are being performed. The node that gets locked is the main data owner, i.e. the node where data would reside if numOwners==1. If the node where the lock resides crashes, then the transaction is marked for rollback - data is in a consistent state, no fault tolerance.

Parameters:
eagerLockSingleNode -

setCacheStopTimeout

@Deprecated
public Configuration setCacheStopTimeout(int cacheStopTimeout)
Deprecated. Use FluentConfiguration.TransactionConfig.cacheStopTimeout(Integer) instead

If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish. The amount of time to wait for is defined by the cache stop timeout. It is recommended that this value does not exceed the transaction timeout because even if a new transaction was started just before the cache was stopped, this could only last as long as the transaction timeout allows it.


setUseReplQueue

@Deprecated
public void setUseReplQueue(boolean useReplQueue)
Deprecated. Use FluentConfiguration.AsyncConfig.useReplQueue(Boolean) instead

If true, this forces all async communications to be queued up and sent out periodically as a batch.

Parameters:
useReplQueue -

setIsolationLevel

@Deprecated
public void setIsolationLevel(IsolationLevel isolationLevel)
Deprecated. Use FluentConfiguration.LockingConfig.isolationLevel(org.infinispan.util.concurrent.IsolationLevel) instead

Cache isolation level. Infinispan only supports READ_COMMITTED or REPEATABLE_READ isolation levels. See http://en.wikipedia.org/wiki/Isolation_level for a discussion on isolation levels.

Parameters:
isolationLevel -

setStateRetrievalTimeout

@Deprecated
public void setStateRetrievalTimeout(long stateRetrievalTimeout)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.timeout(Long) instead

This is the maximum amount of time - in milliseconds - to wait for state from neighboring caches, before throwing an exception and aborting startup.

Parameters:
stateRetrievalTimeout -

setStateRetrievalTimeout

@Deprecated
public void setStateRetrievalTimeout(long stateRetrievalTimeout,
                                                TimeUnit timeUnit)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.timeout(Long) instead


setStateRetrievalLogFlushTimeout

@Deprecated
public void setStateRetrievalLogFlushTimeout(long logFlushTimeout)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.logFlushTimeout(Long) instead

This is the maximum amount of time to run a cluster-wide flush, to allow for syncing of transaction logs.

Parameters:
logFlushTimeout -

setStateRetrievalLogFlushTimeout

@Deprecated
public void setStateRetrievalLogFlushTimeout(long logFlushTimeout,
                                                        TimeUnit timeUnit)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.logFlushTimeout(Long) instead


setStateRetrievalMaxNonProgressingLogWrites

@Deprecated
public void setStateRetrievalMaxNonProgressingLogWrites(int maxNonProgressingLogWrites)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.maxNonProgressingLogWrites(Integer) instead

This is the maximum number of non-progressing transaction log writes after which a brute-force flush approach is resorted to, to synchronize transaction logs.

Parameters:
maxNonProgressingLogWrites -

setStateRetrievalChunkSize

@Deprecated
public void setStateRetrievalChunkSize(int chunkSize)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.chunkSize(Integer) instead

The size of a state transfer "chunk", in cache entries.

Parameters:
chunkSize -

setStateRetrievalInitialRetryWaitTime

@Deprecated
public void setStateRetrievalInitialRetryWaitTime(long initialRetryWaitTime)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.initialRetryWaitTime(Long) instead

Initial wait time when backing off before retrying state transfer retrieval

Parameters:
initialRetryWaitTime -

setStateRetrievalInitialRetryWaitTime

@Deprecated
public void setStateRetrievalInitialRetryWaitTime(long initialRetryWaitTime,
                                                             TimeUnit timeUnit)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.initialRetryWaitTime(Long) instead


setStateRetrievalRetryWaitTimeIncreaseFactor

@Deprecated
public void setStateRetrievalRetryWaitTimeIncreaseFactor(int retryWaitTimeIncreaseFactor)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.retryWaitTimeIncreaseFactor(Integer) instead

Wait time increase factor over successive state retrieval backoffs

Parameters:
retryWaitTimeIncreaseFactor -

setStateRetrievalNumRetries

@Deprecated
public void setStateRetrievalNumRetries(int numRetries)
Deprecated. Use FluentConfiguration.StateRetrievalConfig.numRetries(Integer) instead

Number of state retrieval retries before giving up and aborting startup.

Parameters:
numRetries -

setIsolationLevel

@Deprecated
public void setIsolationLevel(String isolationLevel)
Deprecated. Use FluentConfiguration.LockingConfig.isolationLevel(org.infinispan.util.concurrent.IsolationLevel) instead


setUseLazyDeserialization

@Deprecated
public void setUseLazyDeserialization(boolean useLazyDeserialization)
Deprecated. Use AbstractFluentConfigurationBean.storeAsBinary() instead


setL1CacheEnabled

@Deprecated
public void setL1CacheEnabled(boolean l1CacheEnabled)
Deprecated. Use AbstractFluentConfigurationBean.l1() instead

Toggle to enable/disable L1 cache.

Parameters:
l1CacheEnabled -

setL1Lifespan

@Deprecated
public void setL1Lifespan(long l1Lifespan)
Deprecated. Use FluentConfiguration.L1Config.lifespan(Long) instead

Maximum lifespan of an entry placed in the L1 cache.

Parameters:
l1Lifespan -

setL1OnRehash

@Deprecated
public void setL1OnRehash(boolean l1OnRehash)
Deprecated. Use FluentConfiguration.L1Config.onRehash(Boolean) instead

If true, entries removed due to a rehash will be moved to L1 rather than being removed altogether.

Parameters:
l1OnRehash -

setL1InvalidationThreshold

@Deprecated
public void setL1InvalidationThreshold(int threshold)
Deprecated. Use FluentConfiguration.L1Config.invalidationThreshold(Integer) instead

Determines whether a multicast or a web of unicasts are used when performing L1 invalidations.

By default multicast will be used.

If the threshold is set to -1, then unicasts will always be used. If the threshold is set to 0, then multicast will be always be used.

Parameters:
threshold - the threshold over which to use a multicast

getL1InvalidationThreshold

public int getL1InvalidationThreshold()
Deprecated. 

setConsistentHashClass

@Deprecated
public void setConsistentHashClass(String consistentHashClass)
Deprecated. Use FluentConfiguration.HashConfig.consistentHashClass(Class) instead

Fully qualified name of class providing consistent hash algorithm

Parameters:
consistentHashClass -

setHashFunctionClass

@Deprecated
public void setHashFunctionClass(String hashFunctionClass)
Deprecated. Use FluentConfiguration.HashConfig.hashFunctionClass(Class) instead

A fully qualified name of the class providing a hash function, used as a bit spreader and a general hash code generator. Typically used in conjunction with the many default ConsistentHash implementations shipped.

Parameters:
hashFunctionClass -

setNumOwners

@Deprecated
public void setNumOwners(int numOwners)
Deprecated. Use FluentConfiguration.HashConfig.numOwners(Integer) instead

Number of cluster-wide replicas for each cache entry.

Parameters:
numOwners -

setRehashEnabled

@Deprecated
public void setRehashEnabled(boolean rehashEnabled)
Deprecated. Use FluentConfiguration.HashConfig.rehashEnabled(Boolean) instead

If false, no rebalancing or rehashing will take place when a new node joins the cluster or a node leaves

Parameters:
rehashEnabled -

setRehashWaitTime

@Deprecated
public void setRehashWaitTime(long rehashWaitTime)
Deprecated. Use FluentConfiguration.HashConfig.rehashWait(Long) instead


setUseAsyncMarshalling

@Deprecated
public void setUseAsyncMarshalling(boolean useAsyncMarshalling)
Deprecated. Use FluentConfiguration.AsyncConfig.asyncMarshalling(Boolean) instead

If true, asynchronous marshalling is enabled which means that caller can return even quicker, but it can suffer from reordering of operations. You can find more information here

Parameters:
useAsyncMarshalling -

setIndexingEnabled

@Deprecated
public void setIndexingEnabled(boolean enabled)
Deprecated. Use AbstractFluentConfigurationBean.indexing() instead

If enabled, entries will be indexed when they are added to the cache. Indexes will be updated as entries change or are removed.

Parameters:
enabled -

setIndexLocalOnly

@Deprecated
public void setIndexLocalOnly(boolean indexLocalOnly)
Deprecated. Use FluentConfiguration.IndexingConfig.indexLocalOnly(Boolean) instead

If true, only index changes made locally, ignoring remote changes. This is useful if indexes are shared across a cluster to prevent redundant indexing of updates.

Parameters:
indexLocalOnly -

isUseAsyncMarshalling

public boolean isUseAsyncMarshalling()
Deprecated. 

isUseReplQueue

public boolean isUseReplQueue()
Deprecated. 

getReplQueueMaxElements

public int getReplQueueMaxElements()
Deprecated. 

getReplQueueInterval

public long getReplQueueInterval()
Deprecated. 

getReplQueueClass

public String getReplQueueClass()
Deprecated. 

isExposeJmxStatistics

public boolean isExposeJmxStatistics()
Deprecated. 

isInvocationBatchingEnabled

public boolean isInvocationBatchingEnabled()
Deprecated. 
Returns:
true if invocation batching is enabled.
Since:
4.0

isIndexingEnabled

public boolean isIndexingEnabled()
Deprecated. 

isIndexLocalOnly

public boolean isIndexLocalOnly()
Deprecated. 

getIndexingProperties

public TypedProperties getIndexingProperties()
Deprecated. 

isFetchInMemoryState

public boolean isFetchInMemoryState()
Deprecated. 

isAlwaysProvideInMemoryState

public boolean isAlwaysProvideInMemoryState()
Deprecated. 

isEagerLockingSingleNodeInUse

@Deprecated
public boolean isEagerLockingSingleNodeInUse()
Deprecated. this is deprecated as starting with Infinispan 5.1 a single lock is always acquired disregarding the number of owner.

Returns true if and only if isUseEagerLocking(), isEagerLockSingleNode() and the cache is distributed.


getLockAcquisitionTimeout

public long getLockAcquisitionTimeout()
Deprecated. 

getSyncReplTimeout

public long getSyncReplTimeout()
Deprecated. 

getCacheMode

public Configuration.CacheMode getCacheMode()
Deprecated. 

getTransactionLockingMode

public LockingMode getTransactionLockingMode()
Deprecated. 
Returns the locking mode for this cache.

See Also:
LockingMode

getTransactionMode

public TransactionMode getTransactionMode()
Deprecated. 
Returns cache's transaction mode. By default a cache is not transactinal, i.e. the transaction mode is TransactionMode.NON_TRANSACTIONAL

See Also:
TransactionMode

isTransactionAutoCommit

public boolean isTransactionAutoCommit()
Deprecated. 
If the cache is transactional (i.e. isTransactionalCache() == true) and transactionAutoCommit is enabled then for single operation transactions the user doesn't need to manually start a transaction, but a transactions is injected by the system. Defaults to true.


isUse1PcForAutoCommitTransactions

public boolean isUse1PcForAutoCommitTransactions()
Deprecated. 
Enabling this would cause autoCommit transactions (isTransactionAutoCommit()) to complete with 1 RPC instead of 2 RPCs (which is default).
Important: enabling this feature might cause inconsistencies when two transactions concurrently write on the same key. This is explained here: isSyncCommitPhase().
The reason this configuration was added is the following:


getIsolationLevel

public IsolationLevel getIsolationLevel()
Deprecated. 

getTransactionManagerLookupClass

public String getTransactionManagerLookupClass()
Deprecated. 

getTransactionManagerLookup

public TransactionManagerLookup getTransactionManagerLookup()
Deprecated. 

getTransactionSynchronizationRegistryLookup

public TransactionSynchronizationRegistryLookup getTransactionSynchronizationRegistryLookup()
Deprecated. 

getCacheLoaderManagerConfig

@Deprecated
public CacheLoaderManagerConfig getCacheLoaderManagerConfig()
Deprecated. Use getCacheLoaders(), isCacheLoaderShared() isFetchPersistentState(), isCacheLoaderPassivation() and isCacheLoaderPreload() instead


getCacheLoaders

public List<CacheLoaderConfig> getCacheLoaders()
Deprecated. 

isCacheLoaderShared

public boolean isCacheLoaderShared()
Deprecated. 

isFetchPersistentState

public boolean isFetchPersistentState()
Deprecated. 

isCacheLoaderPassivation

public boolean isCacheLoaderPassivation()
Deprecated. 

isCacheLoaderPreload

public boolean isCacheLoaderPreload()
Deprecated. 

isSyncCommitPhase

public boolean isSyncCommitPhase()
Deprecated. 
Important - to be used with caution: if you have two transactions writing to the same key concurrently and the commit is configured to be performed asynchronously then inconsistencies might happen. This is because in order to have such consistency guarantees locks need to be released asynchronously after all the commits are acknowledged on the originator. In the case of an asynchronous commit messages we don't wait for all the commit messages to be acknowledged, but release the locks together with the commit message.


isSyncRollbackPhase

public boolean isSyncRollbackPhase()
Deprecated. 

isSecondPhaseAsync

public boolean isSecondPhaseAsync()
Deprecated. 
Returns true if the 2nd phase of the 2PC (i.e. either commit or rollback) is sent asynchronously.


isUseEagerLocking

@Deprecated
public boolean isUseEagerLocking()
Deprecated. 

This is now deprecated. An "eager" locking cache is a transactional cache running in pessimistic mode.

See Also:
getTransactionLockingMode()

isEagerLockSingleNode

@Deprecated
public boolean isEagerLockSingleNode()
Deprecated. starting with Infinispan 5.1 single node locking is used by default


getCacheStopTimeout

public int getCacheStopTimeout()
Deprecated. 

getStateRetrievalTimeout

public long getStateRetrievalTimeout()
Deprecated. 

getStateRetrievalInitialRetryWaitTime

public long getStateRetrievalInitialRetryWaitTime()
Deprecated. 

getStateRetrievalRetryWaitTimeIncreaseFactor

public int getStateRetrievalRetryWaitTimeIncreaseFactor()
Deprecated. 

getStateRetrievalNumRetries

public int getStateRetrievalNumRetries()
Deprecated. 

getStateRetrievalMaxNonProgressingLogWrites

public int getStateRetrievalMaxNonProgressingLogWrites()
Deprecated. 

getStateRetrievalChunkSize

public int getStateRetrievalChunkSize()
Deprecated. 

getStateRetrievalLogFlushTimeout

public long getStateRetrievalLogFlushTimeout()
Deprecated. 

isUseLazyDeserialization

@Deprecated
public boolean isUseLazyDeserialization()
Deprecated. Use isStoreAsBinary()


isStoreAsBinary

public boolean isStoreAsBinary()
Deprecated. 

isL1CacheEnabled

public boolean isL1CacheEnabled()
Deprecated. 

isL1CacheActivated

public boolean isL1CacheActivated()
Deprecated. 

getL1Lifespan

public long getL1Lifespan()
Deprecated. 

isL1OnRehash

public boolean isL1OnRehash()
Deprecated. 

getConsistentHashClass

public String getConsistentHashClass()
Deprecated. 

hasConsistentHashClass

public boolean hasConsistentHashClass()
Deprecated. 

isCustomConsistentHashClass

public boolean isCustomConsistentHashClass()
Deprecated. 

isCustomHashFunctionClass

public boolean isCustomHashFunctionClass()
Deprecated. 

getHashFunctionClass

public String getHashFunctionClass()
Deprecated. 

getNumOwners

public int getNumOwners()
Deprecated. 

getNumVirtualNodes

public int getNumVirtualNodes()
Deprecated. 

isGroupsEnabled

public boolean isGroupsEnabled()
Deprecated. 

getGroupers

public List<Grouper<?>> getGroupers()
Deprecated. 

isRehashEnabled

public boolean isRehashEnabled()
Deprecated. 

getRehashWaitTime

public long getRehashWaitTime()
Deprecated. 

isTransactionRecoveryEnabled

public boolean isTransactionRecoveryEnabled()
Deprecated. 
Returns true if transaction recovery information is collected.


getTransactionRecoveryCacheName

public String getTransactionRecoveryCacheName()
Deprecated. 
Returns the name of the cache used in order to keep recovery information.


isUseSynchronizationForTransactions

public boolean isUseSynchronizationForTransactions()
Deprecated. 
If enabled Infinispan enlists within transactions as a Synchronization. If disabled (default) then Infinispan enlists as an XAResource, being able to fully participate in distributed transaction. More about this here.


accept

public void accept(ConfigurationBeanVisitor v)
Deprecated. 

equals

public boolean equals(Object o)
Deprecated. 
Also see equalsIgnoreName(Object) for equality that does not consider the name of the configuration.

Overrides:
equals in class Object

equalsIgnoreName

public boolean equalsIgnoreName(Object o)
Deprecated. 
Same as equals(Object) but it ignores the getName() attribute in the comparison.


hashCode

public int hashCode()
Deprecated. 
Overrides:
hashCode in class Object

clone

public Configuration clone()
Deprecated. 
Specified by:
clone in interface CloneableConfigurationComponent
Overrides:
clone in class AbstractNamedCacheConfigurationBean

toXmlString

public String toXmlString()
Deprecated. 
Converts this configuration instance to an XML representation containing the current settings.

Returns:
a string containing the formatted XML representation of this configuration instance.

isUsingCacheLoaders

public boolean isUsingCacheLoaders()
Deprecated. 

getCustomInterceptors

public List<CustomInterceptorConfig> getCustomInterceptors()
Deprecated. 
Returns the CustomInterceptorConfig, if any, associated with this configuration object. The custom interceptors will be added to the cache at startup in the sequence defined by this list.

Returns:
List of custom interceptors, never null

isStoreKeysAsBinary

public boolean isStoreKeysAsBinary()
Deprecated. 

isStoreValuesAsBinary

public boolean isStoreValuesAsBinary()
Deprecated. 

setCustomInterceptors

@Deprecated
public void setCustomInterceptors(List<CustomInterceptorConfig> customInterceptors)
Deprecated. Use FluentConfiguration.CustomInterceptorCumulator.add(org.infinispan.interceptors.base.CommandInterceptor)


assertValid

public void assertValid()
                 throws ConfigurationException
Deprecated. 
Throws:
ConfigurationException

isOnePhaseCommit

public boolean isOnePhaseCommit()
Deprecated. 

isTransactionalCache

public boolean isTransactionalCache()
Deprecated. 
Returns true if the cache is configured to run in transactional mode, false otherwise. Starting with Infinispan version 5.1 a cache doesn't support mixed access: i.e.won't support transactional and non-transactional operations. A cache is transactional if one the following:
 - a transactionManagerLookup is configured for the cache
 - batching is enabled
 - it is explicitly marked as transactional: config.fluent().transaction().transactionMode(TransactionMode.TRANSACTIONAL).
   In this last case a transactionManagerLookup needs to be explicitly set
 
By default a cache is not transactional.

See Also:
isTransactionAutoCommit()

isExpirationReaperEnabled

public boolean isExpirationReaperEnabled()
Deprecated. 

isHashActivated

public boolean isHashActivated()
Deprecated. 

getL1InvalidationCleanupTaskFrequency

public long getL1InvalidationCleanupTaskFrequency()
Deprecated. 

setL1InvalidationCleanupTaskFrequency

public void setL1InvalidationCleanupTaskFrequency(long frequencyMillis)
Deprecated. 

-->

Copyright © 2012 JBoss, a division of Red Hat. All Rights Reserved.