public class CacheConfiguration<K,V> extends javax.cache.configuration.MutableConfiguration<K,V>
IgniteConfiguration.getCacheConfiguration()
method. It defines all configuration
parameters required to start a cache within grid instance. You can have multiple caches
configured with different names within one grid.
Cache configuration is set on IgniteConfiguration.setCacheConfiguration(CacheConfiguration...)
method. This adapter is a simple bean and
can be configured from Spring XML files (or other DI frameworks).
Note that absolutely all configuration properties are optional, so users should only change what they need.
Modifier and Type | Class and Description |
---|---|
static class |
CacheConfiguration.IgniteAllNodesPredicate
Filter that accepts all nodes.
|
Modifier and Type | Field and Description |
---|---|
static IgnitePredicate<ClusterNode> |
ALL_NODES
Filter that accepts all nodes.
|
static int |
DFLT_BACKUPS
Default number of backups.
|
static CacheAtomicityMode |
DFLT_CACHE_ATOMICITY_MODE
Default atomicity mode.
|
static CacheMode |
DFLT_CACHE_MODE
Default caching mode.
|
static int |
DFLT_CACHE_SIZE
Default cache size to use with eviction policy.
|
static int |
DFLT_CONCURRENT_LOAD_ALL_THRESHOLD
Default threshold for concurrent loading of keys from
CacheStore . |
static boolean |
DFLT_COPY_ON_READ
Default value for 'copyOnRead' flag.
|
static boolean |
DFLT_EAGER_TTL
Default value for eager ttl flag.
|
static boolean |
DFLT_EVENTS_DISABLED
Default value for events disabled flag.
|
static boolean |
DFLT_INVALIDATE
Default value for 'invalidate' flag that indicates if this is invalidation-based cache.
|
static boolean |
DFLT_LOAD_PREV_VAL
Default value for load previous value flag.
|
static long |
DFLT_LOCK_TIMEOUT
Default lock timeout.
|
static long |
DFLT_LONG_QRY_WARN_TIMEOUT
Deprecated.
|
static int |
DFLT_MAX_CONCURRENT_ASYNC_OPS
Default value for 'maxConcurrentAsyncOps'.
|
static int |
DFLT_MAX_QUERY_ITERATOR_CNT
Default maximum number of query iterators that can be stored.
|
static int |
DFLT_NEAR_START_SIZE
Initial default near cache size.
|
static PartitionLossPolicy |
DFLT_PARTITION_LOSS_POLICY
Default partition loss policy.
|
static int |
DFLT_QRY_DETAIL_METRICS_SIZE
Default number of queries detail metrics to collect.
|
static int |
DFLT_QUERY_PARALLELISM
Default query parallelism.
|
static boolean |
DFLT_READ_FROM_BACKUP
Default value for 'readFromBackup' flag.
|
static int |
DFLT_REBALANCE_BATCH_SIZE
Default rebalance batch size in bytes.
|
static long |
DFLT_REBALANCE_BATCHES_PREFETCH_COUNT
Default rebalance batches prefetch count.
|
static CacheRebalanceMode |
DFLT_REBALANCE_MODE
Default rebalance mode for distributed cache.
|
static int |
DFLT_REBALANCE_THREAD_POOL_SIZE
Deprecated.
|
static long |
DFLT_REBALANCE_THROTTLE
Time in milliseconds to wait between rebalance messages to avoid overloading CPU.
|
static long |
DFLT_REBALANCE_TIMEOUT
Default rebalance timeout (ms).
|
static int |
DFLT_SQL_INDEX_MAX_INLINE_SIZE
Default maximum inline size for sql indexes.
|
static int |
DFLT_SQL_ONHEAP_CACHE_MAX_SIZE
Default SQL on-heap cache size.
|
static Boolean |
DFLT_STORE_KEEP_BINARY
Default value for keep binary in store behavior .
|
static int |
DFLT_WRITE_BEHIND_BATCH_SIZE
Default batch size for write-behind cache store.
|
static boolean |
DFLT_WRITE_BEHIND_COALESCING
Default write coalescing for write-behind cache store.
|
static int |
DFLT_WRITE_BEHIND_CRITICAL_SIZE
Default critical size used when flush size is not specified.
|
static boolean |
DFLT_WRITE_BEHIND_ENABLED
Default value for 'writeBehindEnabled' flag.
|
static long |
DFLT_WRITE_BEHIND_FLUSH_FREQUENCY
Default flush frequency for write-behind cache store in milliseconds.
|
static int |
DFLT_WRITE_BEHIND_FLUSH_SIZE
Default flush size for write-behind cache store.
|
static int |
DFLT_WRITE_FROM_BEHIND_FLUSH_THREAD_CNT
Default count of flush threads for write-behind cache store.
|
static int |
MAX_PARTITIONS_COUNT
Maximum number of partitions.
|
Constructor and Description |
---|
CacheConfiguration()
Empty constructor (all values are initialized to their defaults).
|
CacheConfiguration(javax.cache.configuration.CompleteConfiguration<K,V> cfg)
Copy constructor.
|
CacheConfiguration(String name) |
Modifier and Type | Method and Description |
---|---|
javax.cache.configuration.MutableConfiguration<K,V> |
addCacheEntryListenerConfiguration(javax.cache.configuration.CacheEntryListenerConfiguration<K,V> cacheEntryLsnrCfg) |
CacheConfiguration<K,V> |
clearQueryEntities()
Clear query entities.
|
AffinityFunction |
getAffinity()
Gets key topology resolver to provide mapping from keys to nodes.
|
AffinityKeyMapper |
getAffinityMapper()
Affinity key mapper used to provide custom affinity key for any given key.
|
CacheAtomicityMode |
getAtomicityMode()
Gets cache atomicity mode.
|
int |
getBackups()
Gets number of nodes used to back up single partition for
CacheMode.PARTITIONED cache. |
Iterable<javax.cache.configuration.CacheEntryListenerConfiguration<K,V>> |
getCacheEntryListenerConfigurations() |
CacheMode |
getCacheMode()
Gets caching mode to use.
|
javax.cache.configuration.Factory<CacheStore<? super K,? super V>> |
getCacheStoreFactory()
Gets factory for underlying persistent storage for read-through and write-through operations.
|
javax.cache.configuration.Factory<? extends CacheStoreSessionListener>[] |
getCacheStoreSessionListenerFactories()
Gets cache store session listener factories.
|
@Nullable String |
getDataRegionName() |
long |
getDefaultLockTimeout()
Gets default lock acquisition timeout.
|
EvictionFilter<K,V> |
getEvictionFilter()
Gets eviction filter to specify which entries should not be evicted
(except explicit evict by calling
IgniteCache.localEvict(Collection) ). |
@Nullable EvictionPolicy<K,V> |
getEvictionPolicy()
Deprecated.
Use
getEvictionPolicyFactory() instead. |
@Nullable javax.cache.configuration.Factory<EvictionPolicy<? super K,? super V>> |
getEvictionPolicyFactory()
Gets cache eviction policy factory.
|
String |
getGroupName()
Gets the cache group name.
|
Class<?>[] |
getIndexedTypes()
Array of key and value type pairs to be indexed (thus array length must be always even).
|
@Nullable CacheInterceptor<K,V> |
getInterceptor()
Gets cache interceptor.
|
CacheKeyConfiguration[] |
getKeyConfiguration()
Gets cache key configuration.
|
long |
getLongQueryWarningTimeout()
Deprecated.
Use
IgniteConfiguration.getLongQueryWarningTimeout() instead. |
int |
getMaxConcurrentAsyncOperations()
Gets maximum number of allowed concurrent asynchronous operations.
|
int |
getMaxQueryIteratorsCount()
Gets maximum number of query iterators that can be stored.
|
String |
getMemoryPolicyName()
Deprecated.
Use
getDataRegionName() (String)} instead. |
String |
getName()
Cache name or
null if not provided, then this will be considered a default
cache which can be accessed via Ignite.cache(String) method. |
NearCacheConfiguration<K,V> |
getNearConfiguration() |
IgnitePredicate<ClusterNode> |
getNodeFilter()
Gets filter which determines on what nodes the cache should be started.
|
PartitionLossPolicy |
getPartitionLossPolicy()
Gets partition loss policy.
|
CachePluginConfiguration[] |
getPluginConfigurations()
Gets array of cache plugin configurations.
|
int |
getQueryDetailMetricsSize()
Gets size of queries detail metrics that will be stored in memory for monitoring purposes.
|
Collection<QueryEntity> |
getQueryEntities()
Gets a collection of configured query entities.
|
int |
getQueryParallelism()
Defines a hint to query execution engine on desired degree of parallelism within a single node.
|
long |
getRebalanceBatchesPrefetchCount()
To gain better rebalancing performance supplier node can provide more than one batch at rebalancing start and
provide one new to each next demand request.
|
int |
getRebalanceBatchSize()
Gets size (in number bytes) to be loaded within a single rebalance message.
|
long |
getRebalanceDelay()
Gets delay in milliseconds upon a node joining or leaving topology (or crash) after which rebalancing
should be started automatically.
|
CacheRebalanceMode |
getRebalanceMode()
Gets rebalance mode for distributed cache.
|
int |
getRebalanceOrder()
Gets cache rebalance order.
|
int |
getRebalanceThreadPoolSize()
Deprecated.
|
long |
getRebalanceThrottle()
Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network.
|
long |
getRebalanceTimeout()
Gets rebalance timeout (ms).
|
@Nullable Class<?>[] |
getSqlFunctionClasses()
Gets classes with methods annotated by
QuerySqlFunction
to be used as user-defined functions from SQL queries. |
int |
getSqlIndexMaxInlineSize()
Gets maximum inline size for sql indexes.
|
int |
getSqlOnheapCacheMaxSize()
Gets maximum SQL on-heap cache.
|
@Nullable String |
getSqlSchema()
Gets custom name of the sql schema.
|
int |
getStoreConcurrentLoadAllThreshold()
Gets the threshold used in cases when values for multiple keys are being loaded from an underlying
CacheStore in parallel. |
TopologyValidator |
getTopologyValidator()
Gets topology validator.
|
String |
getTransactionManagerLookupClassName()
Deprecated.
Use
TransactionConfiguration.getTxManagerFactory() instead. |
int |
getWriteBehindBatchSize()
Maximum batch size for write-behind cache store operations.
|
boolean |
getWriteBehindCoalescing()
Write coalescing flag for write-behind cache store operations.
|
long |
getWriteBehindFlushFrequency()
Frequency with which write-behind cache is flushed to the cache store in milliseconds.
|
int |
getWriteBehindFlushSize()
Maximum size of the write-behind cache.
|
int |
getWriteBehindFlushThreadCount()
Number of threads that will perform cache flushing.
|
CacheWriteSynchronizationMode |
getWriteSynchronizationMode()
Gets write synchronization mode.
|
boolean |
isCopyOnRead()
Gets the flag indicating whether a copy of the value stored in the on-heap cache
(see
isOnheapCacheEnabled() should be created for a cache operation return the value. |
boolean |
isEagerTtl()
Gets flag indicating whether expired cache entries will be eagerly removed from cache.
|
boolean |
isEncryptionEnabled()
Gets flag indicating whether data must be encrypted.
|
Boolean |
isEventsDisabled()
Checks whether events are disabled for this cache.
|
boolean |
isInvalidate()
Invalidation flag.
|
boolean |
isLoadPreviousValue()
Gets flag indicating whether value should be loaded from store if it is not in the cache
for following cache operations:
IgniteCache.putIfAbsent(Object, Object)
IgniteCache.replace(Object, Object)
IgniteCache.replace(Object, Object, Object)
IgniteCache.remove(Object, Object)
IgniteCache.getAndPut(Object, Object)
IgniteCache.getAndRemove(Object)
IgniteCache.getAndReplace(Object, Object)
IgniteCache.getAndPutIfAbsent(Object, Object)
|
boolean |
isOnheapCacheEnabled()
Checks if the on-heap cache is enabled for the off-heap based page memory.
|
boolean |
isReadFromBackup()
Gets flag indicating whether data can be read from backup.
|
boolean |
isSqlEscapeAll()
If
true all the SQL table and field names will be escaped with double quotes like
({@code "tableName"." |
boolean |
isSqlOnheapCacheEnabled()
Gets whether SQL on-heap cache is enabled.
|
Boolean |
isStoreKeepBinary()
Flag indicating that
CacheStore implementation
is working with binary objects instead of Java objects. |
boolean |
isWriteBehindEnabled()
Flag indicating whether Ignite should use write-behind behaviour for the cache store.
|
javax.cache.configuration.MutableConfiguration<K,V> |
removeCacheEntryListenerConfiguration(javax.cache.configuration.CacheEntryListenerConfiguration<K,V> cacheEntryLsnrCfg) |
CacheConfiguration<K,V> |
setAffinity(AffinityFunction aff)
Sets affinity for cache keys.
|
CacheConfiguration<K,V> |
setAffinityMapper(AffinityKeyMapper affMapper)
Sets custom affinity mapper.
|
CacheConfiguration<K,V> |
setAtomicityMode(CacheAtomicityMode atomicityMode)
Sets cache atomicity mode.
|
CacheConfiguration<K,V> |
setBackups(int backups)
Sets number of nodes used to back up single partition for
CacheMode.PARTITIONED cache. |
CacheConfiguration<K,V> |
setCacheLoaderFactory(javax.cache.configuration.Factory<? extends javax.cache.integration.CacheLoader<K,V>> factory) |
CacheConfiguration<K,V> |
setCacheMode(CacheMode cacheMode)
Sets caching mode.
|
CacheConfiguration<K,V> |
setCacheStoreFactory(javax.cache.configuration.Factory<? extends CacheStore<? super K,? super V>> storeFactory)
Sets factory for persistent storage for cache data.
|
CacheConfiguration<K,V> |
setCacheStoreSessionListenerFactories(javax.cache.configuration.Factory<? extends CacheStoreSessionListener>... storeSesLsnrs)
Cache store session listener factories.
|
CacheConfiguration<K,V> |
setCacheWriterFactory(javax.cache.configuration.Factory<? extends javax.cache.integration.CacheWriter<? super K,? super V>> factory) |
CacheConfiguration<K,V> |
setCopyOnRead(boolean cpOnRead)
Sets copy on read flag.
|
CacheConfiguration<K,V> |
setDataRegionName(@Nullable String dataRegionName)
Sets a name of
DataRegionConfiguration for this cache. |
CacheConfiguration<K,V> |
setDefaultLockTimeout(long dfltLockTimeout)
Sets default lock timeout in milliseconds.
|
CacheConfiguration<K,V> |
setEagerTtl(boolean eagerTtl)
Sets eager ttl flag.
|
CacheConfiguration<K,V> |
setEncryptionEnabled(boolean encryptionEnabled)
Sets encrypted flag.
|
CacheConfiguration<K,V> |
setEventsDisabled(boolean evtsDisabled)
Sets events disabled flag.
|
CacheConfiguration<K,V> |
setEvictionFilter(EvictionFilter<K,V> evictFilter)
Sets eviction filter.
|
CacheConfiguration<K,V> |
setEvictionPolicy(@Nullable EvictionPolicy evictPlc)
Deprecated.
Use
setEvictionPolicyFactory(Factory) instead. |
CacheConfiguration<K,V> |
setEvictionPolicyFactory(@Nullable javax.cache.configuration.Factory<? extends EvictionPolicy<? super K,? super V>> evictPlcFactory)
Sets cache eviction policy factory.
|
CacheConfiguration<K,V> |
setExpiryPolicyFactory(javax.cache.configuration.Factory<? extends javax.cache.expiry.ExpiryPolicy> factory) |
CacheConfiguration<K,V> |
setGroupName(String grpName)
Sets the cache group name.
|
CacheConfiguration<K,V> |
setIndexedTypes(Class<?>... indexedTypes)
Array of key and value type pairs to be indexed (thus array length must be always even).
|
CacheConfiguration<K,V> |
setInterceptor(CacheInterceptor<K,V> interceptor)
Sets cache interceptor.
|
CacheConfiguration<K,V> |
setInvalidate(boolean invalidate)
Sets invalidation flag for near cache entries in this transaction.
|
CacheConfiguration<K,V> |
setKeyConfiguration(CacheKeyConfiguration... cacheKeyCfg)
Sets cache key configuration.
|
CacheConfiguration<K,V> |
setLoadPreviousValue(boolean loadPrevVal)
Sets flag indicating whether value should be loaded from store if it is not in the cache
for following cache operations:
IgniteCache.putIfAbsent(Object, Object)
IgniteCache.replace(Object, Object)
IgniteCache.replace(Object, Object, Object)
IgniteCache.remove(Object, Object)
IgniteCache.getAndPut(Object, Object)
IgniteCache.getAndRemove(Object)
IgniteCache.getAndReplace(Object, Object)
IgniteCache.getAndPutIfAbsent(Object, Object)
When not set, default value is DFLT_LOAD_PREV_VAL . |
CacheConfiguration<K,V> |
setLongQueryWarningTimeout(long longQryWarnTimeout)
Deprecated.
Use
IgniteConfiguration.setLongQueryWarningTimeout(long) instead. |
CacheConfiguration<K,V> |
setManagementEnabled(boolean enabled) |
CacheConfiguration<K,V> |
setMaxConcurrentAsyncOperations(int maxConcurrentAsyncOps)
Sets maximum number of concurrent asynchronous operations.
|
CacheConfiguration<K,V> |
setMaxQueryIteratorsCount(int maxQryIterCnt)
Sets maximum number of query iterators that can be stored.
|
CacheConfiguration<K,V> |
setMemoryPolicyName(String memPlcName)
Deprecated.
Use
setDataRegionName(String) instead. |
CacheConfiguration<K,V> |
setName(String name)
Sets cache name.
|
CacheConfiguration<K,V> |
setNearConfiguration(NearCacheConfiguration<K,V> nearCfg)
Sets the near cache configuration to use on all cache nodes.
|
CacheConfiguration<K,V> |
setNodeFilter(IgnitePredicate<ClusterNode> nodeFilter)
Sets filter which determines on what nodes the cache should be started.
|
CacheConfiguration<K,V> |
setOnheapCacheEnabled(boolean onheapCache)
Configures on-heap cache for the off-heap based page memory.
|
CacheConfiguration<K,V> |
setPartitionLossPolicy(PartitionLossPolicy partLossPlc)
Sets partition loss policy.
|
CacheConfiguration<K,V> |
setPluginConfigurations(CachePluginConfiguration... pluginCfgs)
Sets cache plugin configurations.
|
CacheConfiguration<K,V> |
setQueryDetailMetricsSize(int qryDetailMetricsSz)
Sets size of queries detail metrics that will be stored in memory for monitoring purposes.
|
CacheConfiguration<K,V> |
setQueryEntities(Collection<QueryEntity> qryEntities)
Sets query entities configuration.
|
CacheConfiguration<K,V> |
setQueryParallelism(int qryParallelism)
Sets query parallelism.
|
CacheConfiguration<K,V> |
setReadFromBackup(boolean readFromBackup)
Sets read from backup flag.
|
CacheConfiguration<K,V> |
setReadThrough(boolean isReadThrough) |
CacheConfiguration<K,V> |
setRebalanceBatchesPrefetchCount(long rebalanceBatchesCnt)
To gain better rebalancing performance supplier node can provide more than one batch at rebalancing start and
provide one new to each next demand request.
|
CacheConfiguration<K,V> |
setRebalanceBatchSize(int rebalanceBatchSize)
Sets rebalance batch size.
|
CacheConfiguration<K,V> |
setRebalanceDelay(long rebalanceDelay)
Sets rebalance delay (see
getRebalanceDelay() for more information). |
CacheConfiguration<K,V> |
setRebalanceMode(CacheRebalanceMode rebalanceMode)
Sets cache rebalance mode.
|
CacheConfiguration<K,V> |
setRebalanceOrder(int rebalanceOrder)
Sets cache rebalance order.
|
CacheConfiguration<K,V> |
setRebalanceThreadPoolSize(int rebalancePoolSize)
Deprecated.
|
CacheConfiguration<K,V> |
setRebalanceThrottle(long rebalanceThrottle)
Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network.
|
CacheConfiguration<K,V> |
setRebalanceTimeout(long rebalanceTimeout)
Sets rebalance timeout (ms).
|
CacheConfiguration<K,V> |
setSqlEscapeAll(boolean sqlEscapeAll)
If
true all the SQL table and field names will be escaped with double quotes like
({@code "tableName"." |
CacheConfiguration<K,V> |
setSqlFunctionClasses(Class<?>... cls)
Sets classes with methods annotated by
QuerySqlFunction
to be used as user-defined functions from SQL queries. |
CacheConfiguration<K,V> |
setSqlIndexMaxInlineSize(int sqlIdxMaxInlineSize)
Sets maximum inline size for sql indexes.
|
CacheConfiguration<K,V> |
setSqlOnheapCacheEnabled(boolean sqlOnheapCache)
Sets whether SQL on-heap cache is enabled.
|
CacheConfiguration<K,V> |
setSqlOnheapCacheMaxSize(int sqlOnheapCacheMaxSize)
Sets maximum SQL on-heap cache.
|
CacheConfiguration<K,V> |
setSqlSchema(String sqlSchema)
Sets sql schema to be used for current cache.
|
CacheConfiguration<K,V> |
setStatisticsEnabled(boolean enabled) |
CacheConfiguration<K,V> |
setStoreByValue(boolean isStoreByVal) |
CacheConfiguration<K,V> |
setStoreConcurrentLoadAllThreshold(int storeConcurrentLoadAllThreshold)
Sets the concurrent load-all threshold used for cases when keys' values are being loaded from
CacheStore
in parallel. |
CacheConfiguration<K,V> |
setStoreKeepBinary(boolean storeKeepBinary)
Sets keep binary in store flag.
|
CacheConfiguration<K,V> |
setTopologyValidator(TopologyValidator topValidator)
Sets topology validator.
|
CacheConfiguration<K,V> |
setTransactionManagerLookupClassName(String tmLookupClsName)
Deprecated.
|
CacheConfiguration<K,V> |
setTypes(Class<K> keyType,
Class<V> valType) |
CacheConfiguration<K,V> |
setWriteBehindBatchSize(int writeBehindBatchSize)
Sets maximum batch size for write-behind cache.
|
CacheConfiguration<K,V> |
setWriteBehindCoalescing(boolean writeBehindCoalescing)
Sets write coalescing flag for write-behind cache.
|
CacheConfiguration<K,V> |
setWriteBehindEnabled(boolean writeBehindEnabled)
Sets flag indicating whether write-behind is enabled.
|
CacheConfiguration<K,V> |
setWriteBehindFlushFrequency(long writeBehindFlushFreq)
Sets write-behind flush frequency.
|
CacheConfiguration<K,V> |
setWriteBehindFlushSize(int writeBehindFlushSize)
Sets write-behind flush size.
|
CacheConfiguration<K,V> |
setWriteBehindFlushThreadCount(int writeBehindFlushThreadCnt)
Sets flush thread count for write-behind cache.
|
CacheConfiguration<K,V> |
setWriteSynchronizationMode(CacheWriteSynchronizationMode writeSync)
Sets write synchronization mode.
|
CacheConfiguration<K,V> |
setWriteThrough(boolean isWriteThrough) |
String |
toString() |
protected Object |
writeReplace()
Creates a copy of current configuration and removes all cache entry listeners.
|
public static final int MAX_PARTITIONS_COUNT
@Deprecated public static final int DFLT_REBALANCE_THREAD_POOL_SIZE
public static final long DFLT_REBALANCE_TIMEOUT
public static final long DFLT_REBALANCE_BATCHES_PREFETCH_COUNT
public static final long DFLT_REBALANCE_THROTTLE
public static final int DFLT_BACKUPS
public static final CacheMode DFLT_CACHE_MODE
public static final CacheAtomicityMode DFLT_CACHE_ATOMICITY_MODE
public static final long DFLT_LOCK_TIMEOUT
public static final int DFLT_CACHE_SIZE
public static final int DFLT_SQL_INDEX_MAX_INLINE_SIZE
public static final int DFLT_NEAR_START_SIZE
public static final boolean DFLT_INVALIDATE
public static final CacheRebalanceMode DFLT_REBALANCE_MODE
public static final int DFLT_REBALANCE_BATCH_SIZE
public static final boolean DFLT_EAGER_TTL
public static final int DFLT_MAX_CONCURRENT_ASYNC_OPS
public static final boolean DFLT_WRITE_BEHIND_ENABLED
public static final int DFLT_WRITE_BEHIND_FLUSH_SIZE
public static final int DFLT_WRITE_BEHIND_CRITICAL_SIZE
public static final long DFLT_WRITE_BEHIND_FLUSH_FREQUENCY
public static final int DFLT_WRITE_FROM_BEHIND_FLUSH_THREAD_CNT
public static final int DFLT_WRITE_BEHIND_BATCH_SIZE
public static final boolean DFLT_WRITE_BEHIND_COALESCING
public static final int DFLT_MAX_QUERY_ITERATOR_CNT
public static final boolean DFLT_LOAD_PREV_VAL
public static final boolean DFLT_READ_FROM_BACKUP
public static final IgnitePredicate<ClusterNode> ALL_NODES
@Deprecated public static final long DFLT_LONG_QRY_WARN_TIMEOUT
public static final int DFLT_QRY_DETAIL_METRICS_SIZE
public static final Boolean DFLT_STORE_KEEP_BINARY
public static final int DFLT_CONCURRENT_LOAD_ALL_THRESHOLD
CacheStore
.public static final PartitionLossPolicy DFLT_PARTITION_LOSS_POLICY
public static final int DFLT_QUERY_PARALLELISM
public static final boolean DFLT_EVENTS_DISABLED
public static final int DFLT_SQL_ONHEAP_CACHE_MAX_SIZE
public static final boolean DFLT_COPY_ON_READ
public CacheConfiguration()
public CacheConfiguration(String name)
name
- Cache name.public String getGroupName()
setAffinity(AffinityFunction)
, setNodeFilter(IgnitePredicate)
, cacheMode
,
setTopologyValidator(TopologyValidator)
, setPartitionLossPolicy(PartitionLossPolicy)
,
setDataRegionName(String)
.
Grouping caches reduces overall overhead, since internal data structures are shared.public CacheConfiguration<K,V> setGroupName(String grpName)
setAffinity(AffinityFunction)
, setNodeFilter(IgnitePredicate)
, cacheMode
,
setTopologyValidator(TopologyValidator)
, setPartitionLossPolicy(PartitionLossPolicy)
,
setDataRegionName(String)
.
Grouping caches reduces overall overhead, since internal data structures are shared.grpName
- Cache group name.this
for chaining.public String getName()
null
if not provided, then this will be considered a default
cache which can be accessed via Ignite.cache(String)
method. Otherwise, if name
is provided, the cache will be accessed via Ignite.cache(String)
method.public CacheConfiguration<K,V> setName(String name)
name
- Cache name. Can not be null or empty.this
for chaining.@Nullable public @Nullable String getDataRegionName()
DataRegionConfiguration
name.@Deprecated public String getMemoryPolicyName()
getDataRegionName()
(String)} instead.public CacheConfiguration<K,V> setDataRegionName(@Nullable @Nullable String dataRegionName)
DataRegionConfiguration
for this cache.dataRegionName
- DataRegionConfiguration name. Can be null (default DataRegionConfiguration will be used)
but should not be empty.this
for chaining.@Deprecated public CacheConfiguration<K,V> setMemoryPolicyName(String memPlcName)
setDataRegionName(String)
instead.@Deprecated @Nullable public @Nullable EvictionPolicy<K,V> getEvictionPolicy()
getEvictionPolicyFactory()
instead.null
which means that evictions are disabled for cache.null
if evictions should be disabled.@Deprecated public CacheConfiguration<K,V> setEvictionPolicy(@Nullable @Nullable EvictionPolicy evictPlc)
setEvictionPolicyFactory(Factory)
instead.evictPlc
- Cache eviction policy.this
for chaining.@Nullable public @Nullable javax.cache.configuration.Factory<EvictionPolicy<? super K,? super V>> getEvictionPolicyFactory()
null
which means that evictions are disabled for cache.null
if evictions should be disabled
or if getEvictionPolicy()
should be used instead.public CacheConfiguration<K,V> setEvictionPolicyFactory(@Nullable @Nullable javax.cache.configuration.Factory<? extends EvictionPolicy<? super K,? super V>> evictPlcFactory)
Serializable
.evictPlcFactory
- Cache eviction policy factory.this
for chaining.public boolean isOnheapCacheEnabled()
public CacheConfiguration<K,V> setOnheapCacheEnabled(boolean onheapCache)
onheapCache
- True
if on-heap cache should be enabled.this
for chaining.public boolean isSqlOnheapCacheEnabled()
public CacheConfiguration<K,V> setSqlOnheapCacheEnabled(boolean sqlOnheapCache)
sqlOnheapCache
- Whether SQL onheap cache is enabled.this
for chaining.public int getSqlOnheapCacheMaxSize()
Zero or negative value stand for unlimited size.
Defaults to DFLT_SQL_ONHEAP_CACHE_MAX_SIZE
.
public CacheConfiguration<K,V> setSqlOnheapCacheMaxSize(int sqlOnheapCacheMaxSize)
Zero or negative value stand for unlimited size.
Defaults to DFLT_SQL_ONHEAP_CACHE_MAX_SIZE
.
this
for chaining.public NearCacheConfiguration<K,V> getNearConfiguration()
public CacheConfiguration<K,V> setNearConfiguration(NearCacheConfiguration<K,V> nearCfg)
nearCfg
- Near cache configuration.this
for chaining.public CacheWriteSynchronizationMode getWriteSynchronizationMode()
public CacheConfiguration<K,V> setWriteSynchronizationMode(CacheWriteSynchronizationMode writeSync)
Default synchronization mode is CacheWriteSynchronizationMode.PRIMARY_SYNC
.
writeSync
- Write synchronization mode.this
for chaining.public IgnitePredicate<ClusterNode> getNodeFilter()
public CacheConfiguration<K,V> setNodeFilter(IgnitePredicate<ClusterNode> nodeFilter)
nodeFilter
- Predicate specifying on which nodes the cache should be started.this
for chaining.public EvictionFilter<K,V> getEvictionFilter()
IgniteCache.localEvict(Collection)
).
If EvictionFilter.evictAllowed(Cache.Entry)
method
returns false
then eviction policy will not be notified and entry will
never be evicted.
If not provided, any entry may be evicted depending on
getEvictionPolicyFactory()
eviction policy} configuration.
null
.public CacheConfiguration<K,V> setEvictionFilter(EvictionFilter<K,V> evictFilter)
evictFilter
- Eviction filter.this
for chaining.public boolean isEagerTtl()
true
, Ignite
will create a single thread to clean up expired entries in background. When flag is
set to false
, expired entries will be removed on next entry access.
When not set, default value is DFLT_EAGER_TTL
.
Note that this flag only matters for entries expiring based on
ExpiryPolicy
and should not be confused with entry
evictions based on configured EvictionPolicy
.
public CacheConfiguration<K,V> setEagerTtl(boolean eagerTtl)
eagerTtl
- True
if Ignite should eagerly remove expired cache entries.this
for chaining.isEagerTtl()
public boolean isLoadPreviousValue()
IgniteCache.putIfAbsent(Object, Object)
IgniteCache.replace(Object, Object)
IgniteCache.replace(Object, Object, Object)
IgniteCache.remove(Object, Object)
IgniteCache.getAndPut(Object, Object)
IgniteCache.getAndRemove(Object)
IgniteCache.getAndReplace(Object, Object)
IgniteCache.getAndPutIfAbsent(Object, Object)
public CacheConfiguration<K,V> setLoadPreviousValue(boolean loadPrevVal)
IgniteCache.putIfAbsent(Object, Object)
IgniteCache.replace(Object, Object)
IgniteCache.replace(Object, Object, Object)
IgniteCache.remove(Object, Object)
IgniteCache.getAndPut(Object, Object)
IgniteCache.getAndRemove(Object)
IgniteCache.getAndReplace(Object, Object)
IgniteCache.getAndPutIfAbsent(Object, Object)
DFLT_LOAD_PREV_VAL
.loadPrevVal
- Load previous value flag.this
for chaining.public javax.cache.configuration.Factory<CacheStore<? super K,? super V>> getCacheStoreFactory()
public CacheConfiguration<K,V> setCacheStoreFactory(javax.cache.configuration.Factory<? extends CacheStore<? super K,? super V>> storeFactory)
storeFactory
- Cache store factory.this
for chaining.public Boolean isStoreKeepBinary()
CacheStore
implementation
is working with binary objects instead of Java objects.
Default value of this flag is DFLT_STORE_KEEP_BINARY
.
If set to false
, Ignite will deserialize keys and
values stored in binary format before they are passed
to cache store.
Note that setting this flag to false
can simplify
store implementation in some cases, but it can cause performance
degradation due to additional serializations and deserializations
of binary objects. You will also need to have key and value
classes on all nodes since binary will be deserialized when
store is called.
public CacheConfiguration<K,V> setStoreKeepBinary(boolean storeKeepBinary)
storeKeepBinary
- Keep binary in store flag.this
for chaining.public int getStoreConcurrentLoadAllThreshold()
CacheStore
in parallel. In the situation when several threads load the same or intersecting set of keys
and the total number of keys to load is less or equal to this threshold then there will be no a second call to
the storage in order to load a key from thread A if the same key is already being loaded by thread B.
The threshold should be controlled wisely. On the one hand if it's set to a big value then the interaction with
a storage during the load of missing keys will be minimal. On the other hand the big value may result in
significant performance degradation because it is needed to check for every key whether it's being loaded or not.
When not set, default value is DFLT_CONCURRENT_LOAD_ALL_THRESHOLD
.public CacheConfiguration<K,V> setStoreConcurrentLoadAllThreshold(int storeConcurrentLoadAllThreshold)
CacheStore
in parallel.storeConcurrentLoadAllThreshold
- The concurrent load-all threshold.this
for chaining.public AffinityFunction getAffinity()
public CacheConfiguration<K,V> setAffinity(AffinityFunction aff)
aff
- Cache key affinity.this
for chaining.public CacheMode getCacheMode()
CacheMode.PARTITIONED
mode will be used by default (defined by DFLT_CACHE_MODE
constant).True
if cache is local.public CacheConfiguration<K,V> setCacheMode(CacheMode cacheMode)
cacheMode
- Caching mode.this
for chaining.public CacheAtomicityMode getAtomicityMode()
Default value is defined by DFLT_CACHE_ATOMICITY_MODE
.
public CacheConfiguration<K,V> setAtomicityMode(CacheAtomicityMode atomicityMode)
atomicityMode
- Cache atomicity mode.this
for chaining.public int getBackups()
CacheMode.PARTITIONED
cache.
If not set, default value is DFLT_BACKUPS
.
public CacheConfiguration<K,V> setBackups(int backups)
CacheMode.PARTITIONED
cache.
If not set, default value is DFLT_BACKUPS
.
backups
- Number of backup nodes for one partition.this
for chaining.public long getDefaultLockTimeout()
DFLT_LOCK_TIMEOUT
which is 0
and means that lock acquisition will never timeout.public CacheConfiguration<K,V> setDefaultLockTimeout(long dfltLockTimeout)
DFLT_LOCK_TIMEOUT
.dfltLockTimeout
- Default lock timeout.this
for chaining.public boolean isInvalidate()
true
, values will be invalidated (nullified) upon commit in near cache.public CacheConfiguration<K,V> setInvalidate(boolean invalidate)
false
.invalidate
- Flag to set this cache into invalidation-based mode. Default value is false
.this
for chaining.@Deprecated public String getTransactionManagerLookupClassName()
TransactionConfiguration.getTxManagerFactory()
instead.@Deprecated public CacheConfiguration<K,V> setTransactionManagerLookupClassName(String tmLookupClsName)
TransactionConfiguration.setTxManagerFactory(Factory)
instead.TransactionManager
implementation, if any.tmLookupClsName
- Name of class implementing GridCacheTmLookup interface that is used to
receive JTA transaction manager.this
for chaining.public CacheConfiguration<K,V> setRebalanceMode(CacheRebalanceMode rebalanceMode)
rebalanceMode
- Rebalance mode.this
for chaining.public CacheRebalanceMode getRebalanceMode()
Default is defined by DFLT_REBALANCE_MODE
.
public int getRebalanceOrder()
SYNC
or ASYNC
rebalance modes only.
If cache rebalance order is positive, rebalancing for this cache will be started only when rebalancing for
all caches with smaller rebalance order will be completed.
Note that cache with order 0
does not participate in ordering. This means that cache with
rebalance order 0
will never wait for any other caches. All caches with order 0
will
be rebalanced right away concurrently with each other and ordered rebalance processes.
If not set, cache order is 0, i.e. rebalancing is not ordered.public CacheConfiguration<K,V> setRebalanceOrder(int rebalanceOrder)
rebalanceOrder
- Cache rebalance order.this
for chaining.getRebalanceOrder()
public int getRebalanceBatchSize()
DFLT_REBALANCE_BATCH_SIZE
.public CacheConfiguration<K,V> setRebalanceBatchSize(int rebalanceBatchSize)
rebalanceBatchSize
- Rebalance batch size.this
for chaining.public long getRebalanceBatchesPrefetchCount()
public CacheConfiguration<K,V> setRebalanceBatchesPrefetchCount(long rebalanceBatchesCnt)
rebalanceBatchesCnt
- batches count.this
for chaining.public int getMaxConcurrentAsyncOperations()
If not set, default value is DFLT_MAX_CONCURRENT_ASYNC_OPS
.
If user threads do not wait for asynchronous operations to complete, it is possible to overload a system. This property enables back-pressure control by limiting number of scheduled asynchronous cache operations.
0
if unlimited.public CacheConfiguration<K,V> setMaxConcurrentAsyncOperations(int maxConcurrentAsyncOps)
maxConcurrentAsyncOps
- Maximum number of concurrent asynchronous operations.this
for chaining.getMaxConcurrentAsyncOperations()
public int getSqlIndexMaxInlineSize()
IgniteSystemProperties.IGNITE_MAX_INDEX_PAYLOAD_SIZE
system property is used.
If not set, default value is DFLT_SQL_INDEX_MAX_INLINE_SIZE
.
public CacheConfiguration<K,V> setSqlIndexMaxInlineSize(int sqlIdxMaxInlineSize)
sqlIdxMaxInlineSize
- Maximum inline size for sql indexes.this
for chaining.public boolean isWriteBehindEnabled()
DFLT_WRITE_BEHIND_ENABLED
constant.True
if write-behind is enabled.public CacheConfiguration<K,V> setWriteBehindEnabled(boolean writeBehindEnabled)
writeBehindEnabled
- true
if write-behind is enabled.this
for chaining.public int getWriteBehindFlushSize()
DFLT_WRITE_BEHIND_FLUSH_SIZE
.
If this value is 0
, then flush is performed according to the flush frequency interval.
Note that you cannot set both, flush
size and flush frequency
, to 0
.public CacheConfiguration<K,V> setWriteBehindFlushSize(int writeBehindFlushSize)
writeBehindFlushSize
- Write-behind cache flush size.this
for chaining.getWriteBehindFlushSize()
public long getWriteBehindFlushFrequency()
If not provided, default value is DFLT_WRITE_BEHIND_FLUSH_FREQUENCY
.
If this value is 0
, then flush is performed according to the flush size.
Note that you cannot set both, flush
size and flush frequency
, to 0
.
public CacheConfiguration<K,V> setWriteBehindFlushFrequency(long writeBehindFlushFreq)
writeBehindFlushFreq
- Write-behind flush frequency in milliseconds.this
for chaining.getWriteBehindFlushFrequency()
public int getWriteBehindFlushThreadCount()
getWriteBehindFlushSize()
, or flush interval defined by
getWriteBehindFlushFrequency()
is elapsed.
If not provided, default value is DFLT_WRITE_FROM_BEHIND_FLUSH_THREAD_CNT
.public CacheConfiguration<K,V> setWriteBehindFlushThreadCount(int writeBehindFlushThreadCnt)
writeBehindFlushThreadCnt
- Count of flush threads.this
for chaining.getWriteBehindFlushThreadCount()
public int getWriteBehindBatchSize()
CacheWriter.writeAll(Collection)
or
CacheWriter.deleteAll(Collection)
methods.
If not provided, default value is DFLT_WRITE_BEHIND_BATCH_SIZE
.public CacheConfiguration<K,V> setWriteBehindBatchSize(int writeBehindBatchSize)
writeBehindBatchSize
- Maximum batch size.this
for chaining.getWriteBehindBatchSize()
public boolean getWriteBehindCoalescing()
DFLT_WRITE_BEHIND_COALESCING
.public CacheConfiguration<K,V> setWriteBehindCoalescing(boolean writeBehindCoalescing)
writeBehindCoalescing
- Write coalescing flag.this
for chaining.getWriteBehindCoalescing()
@Deprecated public int getRebalanceThreadPoolSize()
IgniteConfiguration.getRebalanceThreadPoolSize()
instead.@Deprecated public CacheConfiguration<K,V> setRebalanceThreadPoolSize(int rebalancePoolSize)
IgniteConfiguration.getRebalanceThreadPoolSize()
instead.rebalancePoolSize
- Size of rebalancing thread pool.this
for chaining.public long getRebalanceTimeout()
Default value is DFLT_REBALANCE_TIMEOUT
.
public CacheConfiguration<K,V> setRebalanceTimeout(long rebalanceTimeout)
rebalanceTimeout
- Rebalance timeout (ms).this
for chaining.public long getRebalanceDelay()
For better efficiency user should usually make sure that new nodes get placed on
the same place of consistent hash ring as the left nodes, and that nodes are
restarted before this delay expires. To place nodes on the same place in consistent hash ring,
use IgniteConfiguration.setConsistentId(Serializable)
to make sure that a node maps to the same hash ID event if restarted. As an example,
node IP address and port combination may be used in this case.
Default value is 0
which means that repartitioning and rebalancing will start
immediately upon node leaving topology. If -1
is returned, then rebalancing
will only be started manually by calling IgniteCache.rebalance()
method or
from management console.
0
to start rebalancing immediately, -1
to
start rebalancing manually, or positive value to specify delay in milliseconds
after which rebalancing should start automatically.public CacheConfiguration<K,V> setRebalanceDelay(long rebalanceDelay)
getRebalanceDelay()
for more information).rebalanceDelay
- Rebalance delay to set.this
for chaining.public long getRebalanceThrottle()
Value of 0
means that throttling is disabled. By default throttling is disabled -
the default is defined by DFLT_REBALANCE_THROTTLE
constant.
0
to disable throttling.public CacheConfiguration<K,V> setRebalanceThrottle(long rebalanceThrottle)
Value of 0
means that throttling is
disabled. By default throttling is disabled - the default is defined by DFLT_REBALANCE_THROTTLE
constant.
rebalanceThrottle
- Time in milliseconds to wait between rebalance messages to avoid overloading of CPU,
0
to disable throttling.this
for chaining.public AffinityKeyMapper getAffinityMapper()
If not provided, then default implementation will be used. The default behavior
is described in AffinityKeyMapper
documentation.
public CacheConfiguration<K,V> setAffinityMapper(AffinityKeyMapper affMapper)
AffinityKeyMapper
documentation.affMapper
- Affinity mapper.this
for chaining.public int getMaxQueryIteratorsCount()
Default value is DFLT_MAX_QUERY_ITERATOR_CNT
.
public CacheConfiguration<K,V> setMaxQueryIteratorsCount(int maxQryIterCnt)
maxQryIterCnt
- Maximum number of query iterators that can be stored.this
for chaining.@Nullable public @Nullable CacheInterceptor<K,V> getInterceptor()
public CacheConfiguration<K,V> setInterceptor(CacheInterceptor<K,V> interceptor)
interceptor
- Cache interceptor.this
for chaining.public boolean isReadFromBackup()
false
always get data from primary node (never from backup).
Default value is defined by DFLT_READ_FROM_BACKUP
.
true
if data can be read from backup node or false
if data always
should be read from primary node and never from backup.public CacheConfiguration<K,V> setReadFromBackup(boolean readFromBackup)
readFromBackup
- true
to allow reads from backups.this
for chaining.public boolean isCopyOnRead()
isOnheapCacheEnabled()
should be created for a cache operation return the value.
Also if this flag is set copies are created for values
passed to CacheInterceptor
and to CacheEntryProcessor
.
If the on-heap cache is disabled then this flag is of no use.public CacheConfiguration<K,V> setCopyOnRead(boolean cpOnRead)
cpOnRead
- Copy on get flag.this
for chaining.isCopyOnRead()
public CacheConfiguration<K,V> setSqlFunctionClasses(Class<?>... cls)
QuerySqlFunction
to be used as user-defined functions from SQL queries.cls
- One or more classes with SQL functions.this
for chaining.@Nullable public @Nullable Class<?>[] getSqlFunctionClasses()
QuerySqlFunction
to be used as user-defined functions from SQL queries.@Deprecated public long getLongQueryWarningTimeout()
IgniteConfiguration.getLongQueryWarningTimeout()
instead.@Deprecated public CacheConfiguration<K,V> setLongQueryWarningTimeout(long longQryWarnTimeout)
IgniteConfiguration.setLongQueryWarningTimeout(long)
instead.longQryWarnTimeout
- Timeout in milliseconds.this
for chaining.public int getQueryDetailMetricsSize()
0
then history will not be collected.
Note, larger number may lead to higher memory consumption.public CacheConfiguration<K,V> setQueryDetailMetricsSize(int qryDetailMetricsSz)
qryDetailMetricsSz
- Maximum number of latest queries metrics that will be stored in memory.this
for chaining.@Nullable public @Nullable String getSqlSchema()
null
will be returned and
quoted case sensitive name will be used as sql schema.null
.public CacheConfiguration<K,V> setSqlSchema(String sqlSchema)
cacheName
is used instead.
sqlSchema
could not be an empty string. Has to be "\"\""
instead.sqlSchema
- Schema name for current cache according to SQL ANSI-99. Should not be null
.this
for chaining.public boolean isSqlEscapeAll()
true
all the SQL table and field names will be escaped with double quotes like
("tableName"."fieldsName"
). This enforces case sensitivity for field names and
also allows having special characters in table and field names.public CacheConfiguration<K,V> setSqlEscapeAll(boolean sqlEscapeAll)
true
all the SQL table and field names will be escaped with double quotes like
("tableName"."fieldsName"
). This enforces case sensitivity for field names and
also allows having special characters in table and field names.sqlEscapeAll
- Flag value.this
for chaining.public Class<?>[] getIndexedTypes()
The same key class can occur multiple times for different value classes, but each value class must be unique because SQL table will be named as value class simple name.
To expose fields of these types onto SQL level and to index them you have to use annotations
from package org.apache.ignite.cache.query.annotations
.
public CacheConfiguration<K,V> setIndexedTypes(Class<?>... indexedTypes)
The same key class can occur multiple times for different value classes, but each value class must be unique because SQL table will be named as value class simple name.
To expose fields of these types onto SQL level and to index them you have to use annotations
from package org.apache.ignite.cache.query.annotations
.
indexedTypes
- Key and value type pairs.this
for chaining.public CachePluginConfiguration[] getPluginConfigurations()
public CacheConfiguration<K,V> setPluginConfigurations(CachePluginConfiguration... pluginCfgs)
pluginCfgs
- Cache plugin configurations.this
for chaining.public Collection<QueryEntity> getQueryEntities()
public PartitionLossPolicy getPartitionLossPolicy()
PartitionLossPolicy
public CacheConfiguration<K,V> setPartitionLossPolicy(PartitionLossPolicy partLossPlc)
partLossPlc
- Partition loss policy.this
for chaining.PartitionLossPolicy
public CacheConfiguration<K,V> setQueryEntities(Collection<QueryEntity> qryEntities)
qryEntities
- Query entities.this
for chaining.public CacheConfiguration<K,V> clearQueryEntities()
this
for chaining.public int getQueryParallelism()
As of Apache Ignite 1.9
this hint is only supported for SQL queries with the following restrictions:
Defaults to DFLT_QUERY_PARALLELISM
.
public CacheConfiguration<K,V> setQueryParallelism(int qryParallelism)
qryParallelism
- Query parallelism.this
for chaining.getQueryParallelism()
public TopologyValidator getTopologyValidator()
See TopologyValidator
for details.
public CacheConfiguration<K,V> setTopologyValidator(TopologyValidator topValidator)
See TopologyValidator
for details.
topValidator
- validator.this
for chaining.public javax.cache.configuration.Factory<? extends CacheStoreSessionListener>[] getCacheStoreSessionListenerFactories()
CacheStoreSessionListener
public CacheConfiguration<K,V> setCacheStoreSessionListenerFactories(javax.cache.configuration.Factory<? extends CacheStoreSessionListener>... storeSesLsnrs)
These listeners override global listeners provided in
IgniteConfiguration.setCacheStoreSessionListenerFactories(Factory[])
configuration property.
storeSesLsnrs
- Cache store session listener factories.this
for chaining.CacheStoreSessionListener
public Iterable<javax.cache.configuration.CacheEntryListenerConfiguration<K,V>> getCacheEntryListenerConfigurations()
public javax.cache.configuration.MutableConfiguration<K,V> addCacheEntryListenerConfiguration(javax.cache.configuration.CacheEntryListenerConfiguration<K,V> cacheEntryLsnrCfg)
public javax.cache.configuration.MutableConfiguration<K,V> removeCacheEntryListenerConfiguration(javax.cache.configuration.CacheEntryListenerConfiguration<K,V> cacheEntryLsnrCfg)
protected Object writeReplace()
public CacheConfiguration<K,V> setStatisticsEnabled(boolean enabled)
public CacheConfiguration<K,V> setManagementEnabled(boolean enabled)
public CacheConfiguration<K,V> setCacheLoaderFactory(javax.cache.configuration.Factory<? extends javax.cache.integration.CacheLoader<K,V>> factory)
public CacheConfiguration<K,V> setCacheWriterFactory(javax.cache.configuration.Factory<? extends javax.cache.integration.CacheWriter<? super K,? super V>> factory)
public CacheConfiguration<K,V> setExpiryPolicyFactory(javax.cache.configuration.Factory<? extends javax.cache.expiry.ExpiryPolicy> factory)
public CacheConfiguration<K,V> setReadThrough(boolean isReadThrough)
public CacheConfiguration<K,V> setWriteThrough(boolean isWriteThrough)
public CacheConfiguration<K,V> setStoreByValue(boolean isStoreByVal)
public Boolean isEventsDisabled()
public CacheConfiguration<K,V> setEventsDisabled(boolean evtsDisabled)
evtsDisabled
- Events disabled flag.this
for chaining.public CacheKeyConfiguration[] getKeyConfiguration()
public CacheConfiguration<K,V> setKeyConfiguration(CacheKeyConfiguration... cacheKeyCfg)
cacheKeyCfg
- Cache key configuration.public boolean isEncryptionEnabled()
True
if this cache persistent data is encrypted.public CacheConfiguration<K,V> setEncryptionEnabled(boolean encryptionEnabled)
encryptionEnabled
- True
if this cache persistent data should be encrypted.this
for chaining.
Follow @ApacheIgnite
Ignite Database and Caching Platform : ver. 2.7.2 Release Date : February 6 2019