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

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 interface Configuration.AsyncConfig
          If configured all communications are asynchronous, in that whenever a thread sends a message sent over the wire, it does not wait for an acknowledgment before returning.
static class Configuration.AsyncType
          If this element is present, all communications are asynchronous, in that whenever a thread sends a message sent over the wire, it does not wait for an acknowledgment before returning.
static class Configuration.BooleanAttributeType
           
static class Configuration.CacheMode
          Cache replication mode.
static interface Configuration.ClusteringConfig
          Defines clustered characteristics of the cache.
static class Configuration.ClusteringType
          Defines clustered characteristics of the cache.
static class Configuration.ClusteringTypeAdapter
           
static interface Configuration.CustomInterceptorsConfig
          Configures custom interceptors to be added to the cache.
static class Configuration.CustomInterceptorsType
          Configures custom interceptors to be added to the cache.
static class Configuration.DataContainerType
          This element controls the data container for the cache.
static interface Configuration.DeadlockDetectionConfig
          Configures deadlock detection.
static class Configuration.DeadlockDetectionType
          This element configures deadlock detection.
static interface Configuration.EvictionConfig
          Controls the eviction settings for the cache.
static class Configuration.EvictionType
          This element controls the eviction settings for the cache.
static interface Configuration.ExpirationConfig
          Controls the default expiration settings for entries in the cache.
static class Configuration.ExpirationType
          This element controls the default expiration settings for entries in the cache.
static interface Configuration.HashConfig
          Allows fine-tuning of rehashing characteristics.
static class Configuration.HashType
          Allows fine-tuning of rehashing characteristics.
static interface Configuration.IndexingConfig
          Configures indexing of entries in the cache for searching.
static class Configuration.InvocationBatching
          Defines whether invocation batching is allowed in this cache instance, and sets up internals accordingly to allow use of this API.
static class Configuration.JmxStatistics
          This element specifies whether cache statistics are gathered and reported via JMX.
static interface Configuration.L1Config
          Configures the L1 cache behavior in 'distributed' caches instances.
static class Configuration.L1Type
          This element configures the L1 cache behavior in 'distributed' caches instances.
static class Configuration.LazyDeserialization
          A mechanism by which serialization and deserialization of objects is deferred till the point in time in which they are used and needed.
static interface Configuration.LoadersConfig
          Holds the configuration for cache loaders and stores.
static interface Configuration.LockingConfig
          Defines the local, in-VM locking and concurrency characteristics of the cache.
static class Configuration.LockingType
          Defines the local, in-VM locking and concurrency characteristics of the cache.
static class Configuration.QueryConfigurationBean
          Configures indexing of entries in the cache for searching.
static interface Configuration.StateRetrievalConfig
          Configures how state is retrieved when a new cache joins the cluster.
static class Configuration.StateRetrievalType
          Configures how state is retrieved when a new cache joins the cluster.
static interface Configuration.SyncConfig
          If configured all communications are synchronous, in that whenever a thread sends a message sent over the wire, it blocks until it receives an acknowledgment from the recipient.
static class Configuration.SyncType
          If this element is present, all communications are synchronous, in that whenever a thread sends a message sent over the wire, it blocks until it receives an acknowledgment from the recipient.
static interface Configuration.TransactionConfig
          Defines transactional (JTA) characteristics of the cache.
static class Configuration.TransactionType
          Defines transactional (JTA) characteristics of the cache.
static class Configuration.UnsafeType
          Allows you to tune various unsafe or non-standard characteristics.
 
Field Summary
protected  String name
           
 
Fields inherited from class org.infinispan.config.AbstractNamedCacheConfigurationBean
cr
 
Fields inherited from class org.infinispan.config.AbstractConfigurationBean
EMPTY_PROPERTIES, log, overriddenConfigurationElements
 
Constructor Summary
Configuration()
           
 
Method Summary
 void accept(ConfigurationBeanVisitor v)
           
 void applyOverrides(Configuration overrides)
           
 void assertValid()
           
 Configuration clone()
           
 Configuration.ClusteringConfig configureClustering()
           
 Configuration.DeadlockDetectionConfig configureDeadlockDetection()
           
 Configuration.EvictionConfig configureEviction()
           
 Configuration.ExpirationConfig configureExpiration()
           
 Configuration.IndexingConfig configureIndexing()
           
 Configuration.CustomInterceptorsConfig configureInterceptors()
           
 Configuration.LoadersConfig configureLoaders()
           
 Configuration.LockingConfig configureLocking()
           
 Configuration.TransactionConfig configureTransaction()
           
 boolean equals(Object o)
           
 CacheLoaderManagerConfig getCacheLoaderManagerConfig()
           
 Configuration.CacheMode getCacheMode()
           
 String getCacheModeString()
           
 int getCacheStopTimeout()
           
 int getConcurrencyLevel()
           
 String getConsistentHashClass()
           
 List<CustomInterceptorConfig> getCustomInterceptors()
          Returns the CustomInterceptorConfig, if any, associated with this configuration object.
 DataContainer getDataContainer()
           
 String getDataContainerClass()
           
 TypedProperties getDataContainerProperties()
           
 long getDeadlockDetectionSpinDuration()
           
 int getEvictionMaxEntries()
           
 EvictionStrategy getEvictionStrategy()
           
 EvictionThreadPolicy getEvictionThreadPolicy()
           
 long getEvictionWakeUpInterval()
          Eviction thread wake up interval, in milliseconds.
 long getExpirationLifespan()
          Expiration lifespan, in milliseconds
 long getExpirationMaxIdle()
          Expiration max idle time, in milliseconds
 GlobalConfiguration getGlobalConfiguration()
           
 String getHashFunctionClass()
           
 IsolationLevel getIsolationLevel()
           
 long getL1Lifespan()
           
 long getLockAcquisitionTimeout()
           
 String getName()
           
 int getNumOwners()
           
 long getRehashRpcTimeout()
           
 long getRehashWaitTime()
           
 String getReplQueueClass()
           
 long getReplQueueInterval()
           
 int getReplQueueMaxElements()
           
 long getStateRetrievalInitialRetryWaitTime()
           
 long getStateRetrievalLogFlushTimeout()
           
 int getStateRetrievalMaxNonProgressingLogWrites()
           
 int getStateRetrievalNumRetries()
           
 int getStateRetrievalRetryWaitTimeIncreaseFactor()
           
 long getStateRetrievalTimeout()
           
 long getSyncReplTimeout()
           
 TransactionManagerLookup getTransactionManagerLookup()
           
 String getTransactionManagerLookupClass()
           
 int hashCode()
           
 void inject(ComponentRegistry cr)
           
 boolean isAlwaysProvideInMemoryState()
           
 boolean isEagerLockSingleNode()
           
 boolean isEnableDeadlockDetection()
           
 boolean isExposeJmxStatistics()
           
 boolean isFetchInMemoryState()
           
 boolean isIndexingEnabled()
           
 boolean isIndexLocalOnly()
           
 boolean isInvocationBatchingEnabled()
           
 boolean isL1CacheEnabled()
           
 boolean isL1OnRehash()
           
 boolean isOnePhaseCommit()
           
 boolean isRehashEnabled()
           
 boolean isStateTransferEnabled()
           
 boolean isSyncCommitPhase()
           
 boolean isSyncRollbackPhase()
           
 boolean isUnsafeUnreliableReturnValues()
           
 boolean isUseAsyncMarshalling()
           
 boolean isUseEagerLocking()
           
 boolean isUseLazyDeserialization()
           
 boolean isUseLockStriping()
           
 boolean isUseReplQueue()
           
 boolean isUsingCacheLoaders()
           
 boolean isWriteSkewCheck()
           
 void setAlwaysProvideInMemoryState(boolean alwaysProvideInMemoryState)
          Deprecated. 
 void setCacheLoaderManagerConfig(CacheLoaderManagerConfig cacheLoaderManagerConfig)
           
 void setCacheMode(Configuration.CacheMode cacheModeInt)
          Deprecated. 
 void setCacheMode(String cacheMode)
          Deprecated. 
 void setCacheModeString(String cacheMode)
          Deprecated. 
 Configuration setCacheStopTimeout(int cacheStopTimeout)
          Deprecated. 
 void setConcurrencyLevel(int concurrencyLevel)
          Deprecated. 
 void setConsistentHashClass(String consistentHashClass)
          Deprecated. 
 void setCustomInterceptors(List<CustomInterceptorConfig> customInterceptors)
          Deprecated. 
 void setDataContainer(DataContainer dataContainer)
          Deprecated. 
 void setDataContainerClass(Class<? extends DataContainer> dataContainerClass)
          Deprecated. 
 void setDataContainerClass(String dataContainerClass)
          Deprecated. 
 void setDataContainerProperties(TypedProperties properties)
          Deprecated. 
 void setDeadlockDetectionSpinDuration(long eagerDeadlockSpinDuration)
          Deprecated. 
 void setEagerLockSingleNode(boolean eagerLockSingleNode)
          Deprecated. 
 void setEnableDeadlockDetection(boolean useEagerDeadlockDetection)
          Deprecated. 
 void setEvictionMaxEntries(int evictionMaxEntries)
          Deprecated. 
 void setEvictionStrategy(EvictionStrategy evictionStrategy)
          Deprecated. 
 void setEvictionStrategy(String eStrategy)
          Deprecated. 
 void setEvictionThreadPolicy(EvictionThreadPolicy policy)
          Deprecated. 
 void setEvictionThreadPolicy(String policy)
          Deprecated. 
 void setEvictionWakeUpInterval(long evictionWakeUpInterval)
          Deprecated. 
 void setExpirationLifespan(long expirationLifespan)
          Deprecated. 
 void setExpirationMaxIdle(long expirationMaxIdle)
          Deprecated. 
 void setExposeJmxStatistics(boolean useMbean)
          Deprecated. 
 void setFetchInMemoryState(boolean fetchInMemoryState)
          Deprecated. 
 void setGlobalConfiguration(GlobalConfiguration gc)
           
 void setHashFunctionClass(String hashFunctionClass)
          Deprecated. 
 void setIndexingEnabled(boolean enabled)
          Deprecated. 
 void setIndexLocalOnly(boolean indexLocalOnly)
          Deprecated. 
 void setInvocationBatchingEnabled(boolean enabled)
          Enables invocation batching if set to true.
 void setIsolationLevel(IsolationLevel isolationLevel)
          Deprecated. 
 void setIsolationLevel(String isolationLevel)
          Deprecated. 
 void setL1CacheEnabled(boolean l1CacheEnabled)
          Deprecated. 
 void setL1Lifespan(long l1Lifespan)
          Deprecated. 
 void setL1OnRehash(boolean l1OnRehash)
          Deprecated. 
 void setLockAcquisitionTimeout(long lockAcquisitionTimeout)
          Deprecated. 
 void setLockAcquisitionTimeout(long lockAcquisitionTimeout, TimeUnit timeUnit)
          Deprecated. 
 void setNumOwners(int numOwners)
          Deprecated. 
 void setRehashEnabled(boolean rehashEnabled)
          Deprecated. 
 void setRehashRpcTimeout(long rehashRpcTimeout)
          Deprecated. 
 void setRehashWaitTime(long rehashWaitTime)
          Deprecated. 
 void setReplQueueClass(String classname)
          Deprecated. 
 void setReplQueueInterval(long replQueueInterval)
          Deprecated. 
 void setReplQueueInterval(long replQueueInterval, TimeUnit timeUnit)
          Deprecated. 
 void setReplQueueMaxElements(int replQueueMaxElements)
          Deprecated. 
 void setStateRetrievalInitialRetryWaitTime(long initialRetryWaitTime)
          Deprecated. 
 void setStateRetrievalInitialRetryWaitTime(long initialRetryWaitTime, TimeUnit timeUnit)
          Deprecated. 
 void setStateRetrievalLogFlushTimeout(long logFlushTimeout)
          Deprecated. 
 void setStateRetrievalLogFlushTimeout(long logFlushTimeout, TimeUnit timeUnit)
          Deprecated. 
 void setStateRetrievalMaxNonProgressingLogWrites(int maxNonProgressingLogWrites)
          Deprecated. 
 void setStateRetrievalNumRetries(int numRetries)
          Deprecated. 
 void setStateRetrievalRetryWaitTimeIncreaseFactor(int retryWaitTimeIncreaseFactor)
          Deprecated. 
 void setStateRetrievalTimeout(long stateRetrievalTimeout)
          Deprecated. 
 void setStateRetrievalTimeout(long stateRetrievalTimeout, TimeUnit timeUnit)
          Deprecated. 
 void setSyncCommitPhase(boolean syncCommitPhase)
          Deprecated. 
 void setSyncReplTimeout(long syncReplTimeout)
          Deprecated. 
 void setSyncReplTimeout(long syncReplTimeout, TimeUnit timeUnit)
          Deprecated. 
 void setSyncRollbackPhase(boolean syncRollbackPhase)
          Deprecated. 
 void setTransactionManagerLookup(TransactionManagerLookup transactionManagerLookup)
          Deprecated. 
 void setTransactionManagerLookupClass(String transactionManagerLookupClass)
          Deprecated. 
 void setUnsafeUnreliableReturnValues(boolean unsafeUnreliableReturnValues)
          Toggle to enable/disable return value fetching
 void setUseAsyncMarshalling(boolean useAsyncMarshalling)
          Deprecated. 
 void setUseEagerLocking(boolean useEagerLocking)
          Deprecated. 
 void setUseLazyDeserialization(boolean useLazyDeserialization)
           
 void setUseLockStriping(boolean useLockStriping)
          Deprecated. 
 void setUseReplQueue(boolean useReplQueue)
          Deprecated. 
 void setWriteSkewCheck(boolean writeSkewCheck)
          Deprecated. 
 
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
Constructor Detail

Configuration

public Configuration()
Method Detail

configureLocking

public Configuration.LockingConfig configureLocking()

configureLoaders

public Configuration.LoadersConfig configureLoaders()

configureTransaction

public Configuration.TransactionConfig configureTransaction()

configureInterceptors

public Configuration.CustomInterceptorsConfig configureInterceptors()

configureEviction

public Configuration.EvictionConfig configureEviction()

configureExpiration

public Configuration.ExpirationConfig configureExpiration()

configureClustering

public Configuration.ClusteringConfig configureClustering()

configureDeadlockDetection

public Configuration.DeadlockDetectionConfig configureDeadlockDetection()

configureIndexing

public Configuration.IndexingConfig configureIndexing()

applyOverrides

public void applyOverrides(Configuration overrides)

inject

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

getGlobalConfiguration

public GlobalConfiguration getGlobalConfiguration()

setGlobalConfiguration

public void setGlobalConfiguration(GlobalConfiguration gc)

getName

public String getName()

isStateTransferEnabled

public boolean isStateTransferEnabled()

getDeadlockDetectionSpinDuration

public long getDeadlockDetectionSpinDuration()

setDeadlockDetectionSpinDuration

@Deprecated
public void setDeadlockDetectionSpinDuration(long eagerDeadlockSpinDuration)
Deprecated. 

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

Parameters:
eagerDeadlockSpinDuration -

isEnableDeadlockDetection

public boolean isEnableDeadlockDetection()

setEnableDeadlockDetection

@Deprecated
public void setEnableDeadlockDetection(boolean useEagerDeadlockDetection)
Deprecated. 

Toggle to enable/disable deadlock detection

Parameters:
useEagerDeadlockDetection -

setUseLockStriping

@Deprecated
public void setUseLockStriping(boolean useLockStriping)
Deprecated. 

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()

isUnsafeUnreliableReturnValues

public boolean isUnsafeUnreliableReturnValues()

setUnsafeUnreliableReturnValues

public void setUnsafeUnreliableReturnValues(boolean unsafeUnreliableReturnValues)
Toggle to enable/disable return value fetching

Parameters:
unsafeUnreliableReturnValues -

setRehashRpcTimeout

@Deprecated
public void setRehashRpcTimeout(long rehashRpcTimeout)
Deprecated. 

Rehashing timeout

Parameters:
rehashRpcTimeout -

getRehashRpcTimeout

public long getRehashRpcTimeout()

isWriteSkewCheck

public boolean isWriteSkewCheck()

setWriteSkewCheck

@Deprecated
public void setWriteSkewCheck(boolean writeSkewCheck)
Deprecated. 

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()

setConcurrencyLevel

@Deprecated
public void setConcurrencyLevel(int concurrencyLevel)
Deprecated. 

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. 

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. 

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. 


setReplQueueClass

@Deprecated
public void setReplQueueClass(String classname)
Deprecated. 

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. 


setInvocationBatchingEnabled

public void setInvocationBatchingEnabled(boolean enabled)
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. 

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. 

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. 

Maximum time to attempt a particular lock acquisition

Parameters:
lockAcquisitionTimeout -

setLockAcquisitionTimeout

@Deprecated
public void setLockAcquisitionTimeout(long lockAcquisitionTimeout,
                                                 TimeUnit timeUnit)
Deprecated. 

Maximum time to attempt a particular lock acquisition

Parameters:
lockAcquisitionTimeout -
timeUnit -

setSyncReplTimeout

@Deprecated
public void setSyncReplTimeout(long syncReplTimeout)
Deprecated. 

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. 

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. 

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.


setCacheMode

@Deprecated
public void setCacheMode(String cacheMode)
Deprecated. 

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.


getCacheModeString

public String getCacheModeString()

setCacheModeString

@Deprecated
public void setCacheModeString(String cacheMode)
Deprecated. 


setDataContainerClass

@Deprecated
public void setDataContainerClass(Class<? extends DataContainer> dataContainerClass)
Deprecated. 


setDataContainerClass

@Deprecated
public void setDataContainerClass(String dataContainerClass)
Deprecated. 


getDataContainerClass

public String getDataContainerClass()

setDataContainer

@Deprecated
public void setDataContainer(DataContainer dataContainer)
Deprecated. 


getDataContainer

public DataContainer getDataContainer()

setDataContainerProperties

@Deprecated
public void setDataContainerProperties(TypedProperties properties)
Deprecated. 


getDataContainerProperties

public TypedProperties getDataContainerProperties()

getEvictionWakeUpInterval

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


setEvictionWakeUpInterval

@Deprecated
public void setEvictionWakeUpInterval(long evictionWakeUpInterval)
Deprecated. 

Interval between subsequent eviction runs, in milliseconds. If you wish to disable the periodic eviction process altogether, set wakeupInterval to -1.

Parameters:
evictionWakeUpInterval -

getEvictionStrategy

public EvictionStrategy getEvictionStrategy()

setEvictionStrategy

@Deprecated
public void setEvictionStrategy(EvictionStrategy evictionStrategy)
Deprecated. 

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

Parameters:
evictionStrategy -

setEvictionStrategy

@Deprecated
public void setEvictionStrategy(String eStrategy)
Deprecated. 

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

Parameters:
eStrategy -

getEvictionThreadPolicy

public EvictionThreadPolicy getEvictionThreadPolicy()

setEvictionThreadPolicy

@Deprecated
public void setEvictionThreadPolicy(EvictionThreadPolicy policy)
Deprecated. 

Threading policy for eviction.

Parameters:
policy -

setEvictionThreadPolicy

@Deprecated
public void setEvictionThreadPolicy(String policy)
Deprecated. 

Threading policy for eviction.

Parameters:
policy -

getEvictionMaxEntries

public int getEvictionMaxEntries()

setEvictionMaxEntries

@Deprecated
public void setEvictionMaxEntries(int evictionMaxEntries)
Deprecated. 

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 -

getExpirationLifespan

public long getExpirationLifespan()
Expiration lifespan, in milliseconds


setExpirationLifespan

@Deprecated
public void setExpirationLifespan(long expirationLifespan)
Deprecated. 

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 bassi by using the Cache API.

Parameters:
expirationLifespan -

getExpirationMaxIdle

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


setExpirationMaxIdle

@Deprecated
public void setExpirationMaxIdle(long expirationMaxIdle)
Deprecated. 

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 bassi by using the Cache API.

Parameters:
expirationMaxIdle -

setTransactionManagerLookupClass

@Deprecated
public void setTransactionManagerLookupClass(String transactionManagerLookupClass)
Deprecated. 

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.

Parameters:
transactionManagerLookupClass -

setTransactionManagerLookup

@Deprecated
public void setTransactionManagerLookup(TransactionManagerLookup transactionManagerLookup)
Deprecated. 


setCacheLoaderManagerConfig

public void setCacheLoaderManagerConfig(CacheLoaderManagerConfig cacheLoaderManagerConfig)

setSyncCommitPhase

@Deprecated
public void setSyncCommitPhase(boolean syncCommitPhase)
Deprecated. 

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. 

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. 

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. 

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. 

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. 

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. 

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. 

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. 


setStateRetrievalLogFlushTimeout

@Deprecated
public void setStateRetrievalLogFlushTimeout(long logFlushTimeout)
Deprecated. 

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. 


setStateRetrievalMaxNonProgressingLogWrites

@Deprecated
public void setStateRetrievalMaxNonProgressingLogWrites(int maxNonProgressingLogWrites)
Deprecated. 

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 -

setStateRetrievalInitialRetryWaitTime

@Deprecated
public void setStateRetrievalInitialRetryWaitTime(long initialRetryWaitTime)
Deprecated. 

Initial wait time when backing off before retrying state transfer retrieval

Parameters:
initialRetryWaitTime -

setStateRetrievalInitialRetryWaitTime

@Deprecated
public void setStateRetrievalInitialRetryWaitTime(long initialRetryWaitTime,
                                                             TimeUnit timeUnit)
Deprecated. 


setStateRetrievalRetryWaitTimeIncreaseFactor

@Deprecated
public void setStateRetrievalRetryWaitTimeIncreaseFactor(int retryWaitTimeIncreaseFactor)
Deprecated. 

Wait time increase factor over successive state retrieval backoffs

Parameters:
retryWaitTimeIncreaseFactor -

setStateRetrievalNumRetries

@Deprecated
public void setStateRetrievalNumRetries(int numRetries)
Deprecated. 

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

Parameters:
numRetries -

setIsolationLevel

@Deprecated
public void setIsolationLevel(String isolationLevel)
Deprecated. 


setUseLazyDeserialization

public void setUseLazyDeserialization(boolean useLazyDeserialization)

setL1CacheEnabled

@Deprecated
public void setL1CacheEnabled(boolean l1CacheEnabled)
Deprecated. 

Toggle to enable/disable L1 cache.

Parameters:
l1CacheEnabled -

setL1Lifespan

@Deprecated
public void setL1Lifespan(long l1Lifespan)
Deprecated. 

Maximum lifespan of an entry placed in the L1 cache.

Parameters:
l1Lifespan -

setL1OnRehash

@Deprecated
public void setL1OnRehash(boolean l1OnRehash)
Deprecated. 

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

Parameters:
l1OnRehash -

setConsistentHashClass

@Deprecated
public void setConsistentHashClass(String consistentHashClass)
Deprecated. 

Fully qualified name of class providing consistent hash algorithm

Parameters:
consistentHashClass -

setHashFunctionClass

@Deprecated
public void setHashFunctionClass(String hashFunctionClass)
Deprecated. 

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. 

Number of cluster-wide replicas for each cache entry.

Parameters:
numOwners -

setRehashEnabled

@Deprecated
public void setRehashEnabled(boolean rehashEnabled)
Deprecated. 

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. 


setUseAsyncMarshalling

@Deprecated
public void setUseAsyncMarshalling(boolean useAsyncMarshalling)
Deprecated. 

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. 

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. 

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()

isUseReplQueue

public boolean isUseReplQueue()

getReplQueueMaxElements

public int getReplQueueMaxElements()

getReplQueueInterval

public long getReplQueueInterval()

getReplQueueClass

public String getReplQueueClass()

isExposeJmxStatistics

public boolean isExposeJmxStatistics()

isInvocationBatchingEnabled

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

isIndexingEnabled

public boolean isIndexingEnabled()

isIndexLocalOnly

public boolean isIndexLocalOnly()

isFetchInMemoryState

public boolean isFetchInMemoryState()

isAlwaysProvideInMemoryState

public boolean isAlwaysProvideInMemoryState()

getLockAcquisitionTimeout

public long getLockAcquisitionTimeout()

getSyncReplTimeout

public long getSyncReplTimeout()

getCacheMode

public Configuration.CacheMode getCacheMode()

getIsolationLevel

public IsolationLevel getIsolationLevel()

getTransactionManagerLookupClass

public String getTransactionManagerLookupClass()

getTransactionManagerLookup

public TransactionManagerLookup getTransactionManagerLookup()

getCacheLoaderManagerConfig

public CacheLoaderManagerConfig getCacheLoaderManagerConfig()

isSyncCommitPhase

public boolean isSyncCommitPhase()

isSyncRollbackPhase

public boolean isSyncRollbackPhase()

isUseEagerLocking

public boolean isUseEagerLocking()

isEagerLockSingleNode

public boolean isEagerLockSingleNode()

getCacheStopTimeout

public int getCacheStopTimeout()

getStateRetrievalTimeout

public long getStateRetrievalTimeout()

getStateRetrievalInitialRetryWaitTime

public long getStateRetrievalInitialRetryWaitTime()

getStateRetrievalRetryWaitTimeIncreaseFactor

public int getStateRetrievalRetryWaitTimeIncreaseFactor()

getStateRetrievalNumRetries

public int getStateRetrievalNumRetries()

getStateRetrievalMaxNonProgressingLogWrites

public int getStateRetrievalMaxNonProgressingLogWrites()

getStateRetrievalLogFlushTimeout

public long getStateRetrievalLogFlushTimeout()

isUseLazyDeserialization

public boolean isUseLazyDeserialization()

isL1CacheEnabled

public boolean isL1CacheEnabled()

getL1Lifespan

public long getL1Lifespan()

isL1OnRehash

public boolean isL1OnRehash()

getConsistentHashClass

public String getConsistentHashClass()

getHashFunctionClass

public String getHashFunctionClass()

getNumOwners

public int getNumOwners()

isRehashEnabled

public boolean isRehashEnabled()

getRehashWaitTime

public long getRehashWaitTime()

accept

public void accept(ConfigurationBeanVisitor v)

equals

public boolean equals(Object o)
Overrides:
equals in class Object

hashCode

public int hashCode()
Overrides:
hashCode in class Object

clone

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

isUsingCacheLoaders

public boolean isUsingCacheLoaders()

getCustomInterceptors

public List<CustomInterceptorConfig> getCustomInterceptors()
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 cutom interceptors, never null

setCustomInterceptors

@Deprecated
public void setCustomInterceptors(List<CustomInterceptorConfig> customInterceptors)
Deprecated. 

See Also:
getCustomInterceptors()

assertValid

public void assertValid()
                 throws ConfigurationException
Throws:
ConfigurationException

isOnePhaseCommit

public boolean isOnePhaseCommit()


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