Serialized Form
-
Package org.apache.ignite
-
Class org.apache.ignite.IgniteAuthenticationException extends IgniteCheckedException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.IgniteCacheRestartingException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.IgniteCheckedException extends Exception implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.IgniteClientDisconnectedException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
reconnectFut
IgniteFuture<?> reconnectFut
-
-
Class org.apache.ignite.IgniteDataStreamerTimeoutException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.IgniteDeploymentException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.IgniteException extends RuntimeException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.IgniteIllegalStateException extends IllegalStateException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.IgniteInterruptedException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.IgniteJdbcThinDataSource extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
loginTimeout
int loginTimeout
Login timeout. -
props
org.apache.ignite.internal.jdbc.thin.ConnectionPropertiesImpl props
Connection properties.
-
-
Class org.apache.ignite.IgniteSpringBean extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
-
Package org.apache.ignite.binary
-
Class org.apache.ignite.binary.BinaryInvalidTypeException extends BinaryObjectException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.binary.BinaryObjectException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.binary.BinaryTypeConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
enumValues
Map<String,Integer> enumValues
Enum names to ordinals mapping. -
idMapper
BinaryIdMapper idMapper
ID mapper. -
isEnum
boolean isEnum
Enum flag. -
nameMapper
BinaryNameMapper nameMapper
Name mapper. -
serializer
BinarySerializer serializer
Serializer. -
typeName
String typeName
Class name.
-
-
-
Package org.apache.ignite.cache
-
Class org.apache.ignite.cache.CacheExistsException extends javax.cache.CacheException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.CacheInterceptorAdapter extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.CacheKeyConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.CachePartialUpdateException extends javax.cache.CacheException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.CacheServerNotFoundException extends javax.cache.CacheException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.QueryEntity extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
_notNullFields
Set<String> _notNullFields
Fields that must have non-null value. NB: DO NOT remove underscore to avoid clashes with QueryEntityEx. -
aliases
Map<String,String> aliases
Aliases. -
defaultFieldValues
Map<String,Object> defaultFieldValues
Fields default values. -
fields
LinkedHashMap<String,String> fields
Fields available for query. A map from field name to type name. -
fieldsPrecision
Map<String,Integer> fieldsPrecision
Precision(Maximum length) for fields. -
fieldsScale
Map<String,Integer> fieldsScale
Scale for fields. -
idxs
Collection<QueryIndex> idxs
Collection of query indexes. -
keyFieldName
String keyFieldName
Key name. Can be used in field list to denote the key as a whole. -
keyFields
Set<String> keyFields
Set of field names that belong to the key. -
keyType
String keyType
Key type. -
tableName
String tableName
Table name. -
valType
String valType
Value type. -
valueFieldName
String valueFieldName
Value name. Can be used in field list to denote the entire value.
-
-
Class org.apache.ignite.cache.QueryIndex extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
fields
LinkedHashMap<String,Boolean> fields
-
inlineSize
int inlineSize
-
name
String name
Index name. -
type
QueryIndexType type
-
-
-
Package org.apache.ignite.cache.affinity
-
Class org.apache.ignite.cache.affinity.AffinityKey extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
Class org.apache.ignite.cache.affinity.AffinityUuid extends AffinityKey<IgniteUuid> implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
-
Package org.apache.ignite.cache.affinity.rendezvous
-
Class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeAffinityBackupFilter extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attrNames
String[] attrNames
Attribute names.
-
-
Class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeColocatedBackupFilter extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attrName
String attrName
Attribute name.
-
-
Class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
affinityBackupFilter
IgniteBiPredicate<ClusterNode,List<ClusterNode>> affinityBackupFilter
Optional affinity backups filter. The first node is a node being tested, the second is a list of nodes that are already assigned for a given partition (the first node in the list is primary). -
backupFilter
IgniteBiPredicate<ClusterNode,ClusterNode> backupFilter
Optional backup filter. First node is primary, second node is a node being tested. -
exclNeighbors
boolean exclNeighbors
Exclude neighbors flag. -
mask
int mask
Mask to use in calculation when partitions count is power of 2. -
parts
int parts
Number of partitions.
-
-
-
Package org.apache.ignite.cache.eviction
-
Class org.apache.ignite.cache.eviction.AbstractEvictionPolicy extends Object implements Serializable
- serialVersionUID:
- 4358725333474509598L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
Class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory extends Object implements Serializable
-
Serialized Fields
-
batchSize
int batchSize
-
maxMemSize
long maxMemSize
-
maxSize
int maxSize
-
-
-
-
Package org.apache.ignite.cache.eviction.fifo
-
Class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy extends AbstractEvictionPolicy<K,V> implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
Class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyFactory extends AbstractEvictionPolicyFactory<FifoEvictionPolicy<K,V>> implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.cache.eviction.lru
-
Class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy extends AbstractEvictionPolicy<K,V> implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
Class org.apache.ignite.cache.eviction.lru.LruEvictionPolicyFactory extends AbstractEvictionPolicyFactory<LruEvictionPolicy<K,V>> implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.cache.eviction.sorted
-
Class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy extends AbstractEvictionPolicy<K,V> implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
Class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory extends AbstractEvictionPolicyFactory<SortedEvictionPolicy<K,V>> implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
comp
Comparator<EvictableEntry<K,V>> comp
Comparator.
-
-
-
Package org.apache.ignite.cache.jta.jndi
-
Class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory extends Object implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.cache.jta.websphere
-
Class org.apache.ignite.cache.jta.websphere.WebSphereLibertyTmFactory extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.jta.websphere.WebSphereTmFactory extends Object implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.cache.query
-
Class org.apache.ignite.cache.query.AbstractContinuousQuery extends Query<javax.cache.Cache.Entry<K,V>> implements Serializable
-
Serialized Fields
-
autoUnsubscribe
boolean autoUnsubscribe
Automatic unsubscription flag. -
includeExpired
boolean includeExpired
Whether to notify aboutEventType.EXPIRED
events. -
initQry
Query<javax.cache.Cache.Entry<K,V>> initQry
Initial query. -
rmtFilterFactory
javax.cache.configuration.Factory<? extends javax.cache.event.CacheEntryEventFilter<K,V>> rmtFilterFactory
Remote filter factory. -
timeInterval
long timeInterval
Time interval.
-
-
-
Class org.apache.ignite.cache.query.CacheEntryEventAdapter extends javax.cache.event.CacheEntryEvent<K,V> implements Serializable
-
Class org.apache.ignite.cache.query.CacheQueryEntryEvent extends CacheEntryEventAdapter<K,V> implements Serializable
-
Class org.apache.ignite.cache.query.ContinuousQuery extends AbstractContinuousQuery<K,V> implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
locLsnr
javax.cache.event.CacheEntryUpdatedListener<K,V> locLsnr
Local listener. -
rmtFilter
CacheEntryEventSerializableFilter<K,V> rmtFilter
Remote filter.
-
-
Class org.apache.ignite.cache.query.ContinuousQueryWithTransformer extends AbstractContinuousQuery<K,V> implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
locLsnr
ContinuousQueryWithTransformer.EventListener<T> locLsnr
Local listener of transformed event -
rmtTransFactory
javax.cache.configuration.Factory<? extends IgniteClosure<javax.cache.event.CacheEntryEvent<? extends K,? extends V>,T>> rmtTransFactory
Remote transformer factory.
-
-
Class org.apache.ignite.cache.query.IndexQuery extends Query<javax.cache.Cache.Entry<K,V>> implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
criteria
@Nullable List<IndexQueryCriterion> criteria
Index query criteria. -
filter
IgniteBiPredicate<K,V> filter
Cache entries filter. Applies remotely to a query result cursor. -
idxName
@Nullable String idxName
Index name. -
limit
int limit
Limit -
part
@Nullable Integer part
Partition to run IndexQuery over. -
valType
String valType
Cache Value type. Describes a table within a cache that runs a query.
-
-
Class org.apache.ignite.cache.query.Query extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
loc
boolean loc
Local flag. -
pageSize
int pageSize
Page size.
-
-
Class org.apache.ignite.cache.query.QueryCancelledException extends IgniteCheckedException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.query.QueryRetryException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.query.ScanQuery extends Query<javax.cache.Cache.Entry<K,V>> implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
filter
IgniteBiPredicate<K,V> filter
-
part
Integer part
-
-
Class org.apache.ignite.cache.query.SpiQuery extends Query<javax.cache.Cache.Entry<K,V>> implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
args
Object[] args
Deprecated.Arguments.
-
-
Class org.apache.ignite.cache.query.SqlFieldsQuery extends Query<List<?>> implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
args
Object[] args
Arguments. -
collocated
boolean collocated
Collocation flag. -
distributedJoins
boolean distributedJoins
-
enforceJoinOrder
boolean enforceJoinOrder
-
lazy
boolean lazy
Deprecated.UseSqlFieldsQuery.setPageSize(int)
instead.Lazy mode is default since Ignite v.2.8. -
parts
int[] parts
Partitions for query -
qryInitiatorId
String qryInitiatorId
Query's originator string (client host+port, user name, job name or any user's information about query initiator). -
replicatedOnly
boolean replicatedOnly
-
schema
String schema
Schema. -
sql
String sql
SQL Query. -
timeout
int timeout
Query timeout in millis. -
updateBatchSize
int updateBatchSize
Update internal batch size. Default is 1 to prevent deadlock on update where keys sequence are different in several concurrent updates.
-
-
Class org.apache.ignite.cache.query.SqlQuery extends Query<javax.cache.Cache.Entry<K,V>> implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
alias
String alias
Deprecated.Table alias -
args
Object[] args
Deprecated.Arguments. -
distributedJoins
boolean distributedJoins
Deprecated. -
parts
int[] parts
Deprecated.Partitions for query -
replicatedOnly
boolean replicatedOnly
Deprecated. -
sql
String sql
Deprecated.SQL clause. -
timeout
int timeout
Deprecated.Timeout in millis. -
type
String type
Deprecated.
-
-
Class org.apache.ignite.cache.query.TextQuery extends Query<javax.cache.Cache.Entry<K,V>> implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.cache.store.jdbc
-
Class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
appCtx
Object appCtx
Application context. -
connUrl
String connUrl
Connection URL. -
createTblQry
String createTblQry
Query to create table. -
dataSrcBean
String dataSrcBean
Name of data source bean. -
delQry
String delQry
Query to delete entries. -
initSchema
boolean initSchema
Flag for schema initialization. -
insertQry
String insertQry
Query to insert entries. -
loadQry
String loadQry
Query to load entry. -
passwd
String passwd
Password for database access. -
updateQry
String updateQry
Query to update entry. -
user
String user
User name for database access.
-
-
Class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
batchSize
int batchSize
Maximum batch size for writeAll and deleteAll operations. -
dataSrcBean
String dataSrcBean
Name of data source bean. -
dataSrcFactory
javax.cache.configuration.Factory<DataSource> dataSrcFactory
Data source factory. -
dialect
JdbcDialect dialect
Database dialect. -
hasher
JdbcTypeHasher hasher
Hash calculator. -
maxPoolSize
int maxPoolSize
Max workers thread count. These threads are responsible for load cache. -
maxWrtAttempts
int maxWrtAttempts
Maximum write attempts in case of database error. -
parallelLoadCacheMinThreshold
int parallelLoadCacheMinThreshold
Parallel load cache minimum threshold. If0
then load sequentially. -
sqlEscapeAll
boolean sqlEscapeAll
Flag indicating that table and field names should be escaped in all SQL queries created by JDBC POJO store. -
transformer
JdbcTypesTransformer transformer
Types transformer. -
types
JdbcType[] types
Types that store could process.
-
-
Class org.apache.ignite.cache.store.jdbc.JdbcType extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
cacheName
String cacheName
Cache name. -
dbSchema
String dbSchema
Schema name in database. -
dbTbl
String dbTbl
Table name in database. -
hasher
JdbcTypeHasher hasher
Custom type hasher. -
keyFields
JdbcTypeField[] keyFields
List of fields descriptors for key object. -
keyType
String keyType
Key class used to store key in cache. -
valFlds
JdbcTypeField[] valFlds
List of fields descriptors for value object. -
valType
String valType
Value class used to store value in cache.
-
-
Class org.apache.ignite.cache.store.jdbc.JdbcTypeDefaultHasher extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.store.jdbc.JdbcTypeField extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.store.jdbc.JdbcTypesDefaultTransformer extends Object implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.cache.store.jdbc.dialect
-
Class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
fetchSize
int fetchSize
Fetch size. -
maxParamsCnt
int maxParamsCnt
Max query parameters count.
-
-
Class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect extends BasicJdbcDialect implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.store.jdbc.dialect.H2Dialect extends BasicJdbcDialect implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect extends BasicJdbcDialect implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.store.jdbc.dialect.OracleDialect extends BasicJdbcDialect implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect extends BasicJdbcDialect implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.cdc
-
Package org.apache.ignite.client
-
Class org.apache.ignite.client.ClientAuthenticationException extends ClientException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientAuthorizationException extends ClientException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientCacheConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
atomicityMode
CacheAtomicityMode atomicityMode
Atomicity mode. -
backups
int backups
Backups. -
cacheMode
CacheMode cacheMode
Cache mode. -
cpOnRead
boolean cpOnRead
Copy on read. -
dataRegionName
String dataRegionName
Data region name. -
dfltLockTimeout
long dfltLockTimeout
Default lock timeout. -
eagerTtl
boolean eagerTtl
Eager TTL flag. -
expiryPlc
javax.cache.expiry.ExpiryPolicy expiryPlc
Expiry policy. -
grpName
String grpName
Group name. -
keyCfg
CacheKeyConfiguration[] keyCfg
Key config. -
maxConcurrentAsyncOperations
int maxConcurrentAsyncOperations
Max concurrent async operations. -
maxQryIteratorsCnt
int maxQryIteratorsCnt
Max query iterators count. -
name
String name
Cache name. -
onheapCacheEnabled
boolean onheapCacheEnabled
Onheap cache enabled. -
partLossPlc
PartitionLossPolicy partLossPlc
Partition loss policy. -
qryDetailMetricsSize
int qryDetailMetricsSize
Query detail metrics size. -
qryEntities
QueryEntity[] qryEntities
Query entities. -
qryParallelism
int qryParallelism
Query parallelism. -
readFromBackup
boolean readFromBackup
Read from backup. -
rebalanceBatchesPrefetchCnt
long rebalanceBatchesPrefetchCnt
Rebalance batches prefetch count. -
rebalanceBatchSize
int rebalanceBatchSize
Rebalance batch size. -
rebalanceDelay
long rebalanceDelay
Rebalance delay. -
rebalanceMode
CacheRebalanceMode rebalanceMode
Rebalance mode. -
rebalanceOrder
int rebalanceOrder
Rebalance order. -
rebalanceThrottle
long rebalanceThrottle
Rebalance throttle. -
rebalanceTimeout
long rebalanceTimeout
Rebalance timeout. -
sqlEscapeAll
boolean sqlEscapeAll
Sql escape all. -
sqlIdxMaxInlineSize
int sqlIdxMaxInlineSize
Sql index max inline size. -
sqlSchema
String sqlSchema
Sql schema. -
statisticsEnabled
boolean statisticsEnabled
Statistics enabled. -
writeSynchronizationMode
CacheWriteSynchronizationMode writeSynchronizationMode
Write synchronization mode.
-
-
Class org.apache.ignite.client.ClientConnectionException extends ClientException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientException extends RuntimeException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientFeatureNotSupportedByServerException extends ClientException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientReconnectedException extends ClientException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientRetryAllPolicy extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientRetryNonePolicy extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientRetryReadPolicy extends Object implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.cluster
-
Class org.apache.ignite.cluster.ClusterGroupEmptyException extends ClusterTopologyException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.cluster.ClusterTopologyException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.compute
-
Class org.apache.ignite.compute.ComputeExecutionRejectedException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.compute.ComputeJobAdapter extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
args
Object[] args
Job argument.
-
-
Class org.apache.ignite.compute.ComputeJobContinuationAdapter extends ComputeJobAdapter implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.compute.ComputeJobFailoverException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.compute.ComputeTaskAdapter extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.compute.ComputeTaskCancelledException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.compute.ComputeTaskSplitAdapter extends ComputeTaskAdapter<T,R> implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
balancer
ComputeLoadBalancer balancer
Load balancer.
-
-
Class org.apache.ignite.compute.ComputeTaskTimeoutException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.compute.ComputeUserUndeclaredException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.configuration
-
Class org.apache.ignite.configuration.BinaryConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
compactFooter
boolean compactFooter
Compact footer flag. -
idMapper
BinaryIdMapper idMapper
ID mapper. -
nameMapper
BinaryNameMapper nameMapper
Name mapper. -
serializer
BinarySerializer serializer
Serializer. -
typeCfgs
Collection<BinaryTypeConfiguration> typeCfgs
Types.
-
-
Class org.apache.ignite.configuration.CacheConfiguration extends javax.cache.configuration.MutableConfiguration<K,V> implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
writeReplace
protected Object writeReplace()
Creates a copy of current configuration and removes all cache entry listeners. They are executed only locally and should never be sent to remote nodes.
-
-
Serialized Fields
-
aff
AffinityFunction aff
Node group resolver. -
affMapper
AffinityKeyMapper affMapper
-
atomicityMode
CacheAtomicityMode atomicityMode
Cache atomicity mode. -
backups
int backups
Number of backups for cache. -
cacheMode
CacheMode cacheMode
Cache mode. -
cpOnRead
boolean cpOnRead
Copy on read flag. -
dfltLockTimeout
long dfltLockTimeout
Deprecated.Default lock timeout. -
diskPageCompression
DiskPageCompression diskPageCompression
-
diskPageCompressionLevel
Integer diskPageCompressionLevel
-
eagerTtl
boolean eagerTtl
Eager ttl flag. -
encryptionEnabled
boolean encryptionEnabled
Flag indicating whether data must be encrypted. Iftrue
data on the disk will be encrypted.- See Also:
EncryptionSpi
,KeystoreEncryptionSpi
-
evictFilter
EvictionFilter<?,?> evictFilter
Eviction filter. -
evictPlc
EvictionPolicy evictPlc
Deprecated.Cache eviction policy. -
evictPlcFactory
javax.cache.configuration.Factory evictPlcFactory
Cache eviction policy factory. -
evtsDisabled
boolean evtsDisabled
Events disabled. -
grpName
String grpName
Cache group name. -
interceptor
CacheInterceptor<K,V> interceptor
-
invalidate
boolean invalidate
Flag indicating whether this is invalidation-based cache. -
keyCfg
CacheKeyConfiguration[] keyCfg
Cache key configuration. -
loadPrevVal
boolean loadPrevVal
-
longQryWarnTimeout
long longQryWarnTimeout
Deprecated. -
maxConcurrentAsyncOps
int maxConcurrentAsyncOps
Maximum number of concurrent asynchronous operations. -
maxQryIterCnt
int maxQryIterCnt
Maximum number of query iterators that can be stored. -
memPlcName
String memPlcName
Name ofDataRegionConfiguration
for this cache -
name
String name
Cache name. -
nearCfg
NearCacheConfiguration<K,V> nearCfg
Near cache configuration. -
nodeFilter
IgnitePredicate<ClusterNode> nodeFilter
Node filter specifying nodes on which this cache should be deployed. -
onheapCache
boolean onheapCache
-
partLossPlc
PartitionLossPolicy partLossPlc
Partition loss policy. -
platformCfg
PlatformCacheConfiguration platformCfg
Platform cache configuration. Enables native cache in platforms (.NET, ...). -
pluginCfgs
CachePluginConfiguration[] pluginCfgs
Cache plugin configurations. -
qryDetailMetricsSz
int qryDetailMetricsSz
-
qryEntities
Collection<QueryEntity> qryEntities
Query entities. -
qryParallelism
int qryParallelism
-
readFromBackup
boolean readFromBackup
Flag indicating whether data can be read from backup. Iffalse
always get data from primary node (never from backup). -
rebalanceBatchesPrefetchCnt
long rebalanceBatchesPrefetchCnt
Deprecated.Rebalance batches prefetch count. -
rebalanceBatchSize
int rebalanceBatchSize
Deprecated.Rebalance batch size. -
rebalanceDelay
long rebalanceDelay
-
rebalanceMode
CacheRebalanceMode rebalanceMode
Distributed cache rebalance mode. -
rebalanceOrder
int rebalanceOrder
Cache rebalance order. -
rebalancePoolSize
int rebalancePoolSize
Deprecated.Rebalance thread pool size. -
rebalanceThrottle
long rebalanceThrottle
Deprecated.Time in milliseconds to wait between rebalance messages to avoid overloading CPU. -
rebalanceTimeout
long rebalanceTimeout
Deprecated.Rebalance timeout. -
sqlEscapeAll
boolean sqlEscapeAll
-
sqlFuncCls
Class<?>[] sqlFuncCls
-
sqlIdxMaxInlineSize
int sqlIdxMaxInlineSize
Maximum inline size for sql indexes. -
sqlOnheapCache
boolean sqlOnheapCache
Use on-heap cache for rows for SQL queries. -
sqlOnheapCacheMaxSize
int sqlOnheapCacheMaxSize
SQL on-heap cache max size. -
sqlSchema
String sqlSchema
-
storeConcurrentLoadAllThreshold
int storeConcurrentLoadAllThreshold
Threshold for concurrent loading of keys fromCacheStore
. -
storeFactory
javax.cache.configuration.Factory storeFactory
-
storeKeepBinary
Boolean storeKeepBinary
-
storeSesLsnrs
javax.cache.configuration.Factory<? extends CacheStoreSessionListener>[] storeSesLsnrs
Cache store session listeners. -
tmLookupClsName
String tmLookupClsName
Name of class implementing GridCacheTmLookup. -
topValidator
TopologyValidator topValidator
Cache topology validator. -
writeBehindBatchSize
int writeBehindBatchSize
Maximum batch size for write-behind cache store. -
writeBehindCoalescing
boolean writeBehindCoalescing
Write coalescing flag for write-behind cache store -
writeBehindEnabled
boolean writeBehindEnabled
Write-behind feature. -
writeBehindFlushFreq
long writeBehindFlushFreq
Write-behind flush frequency in milliseconds. -
writeBehindFlushSize
int writeBehindFlushSize
Maximum size of write-behind cache. -
writeBehindFlushThreadCnt
int writeBehindFlushThreadCnt
Flush thread count for write-behind cache store. -
writeSync
CacheWriteSynchronizationMode writeSync
Write synchronization mode.
-
-
Class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.configuration.ClientConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
addrs
String[] addrs
Server addresses. -
asyncContinuationExecutor
Executor asyncContinuationExecutor
Executor for async operations continuations. -
autoBinaryConfigurationEnabled
boolean autoBinaryConfigurationEnabled
Whether automatic binary configuration should be enabled. -
binaryCfg
BinaryConfiguration binaryCfg
Configuration for Ignite binary objects. -
clusterDiscoveryEnabled
boolean clusterDiscoveryEnabled
Whether cluster discovery should be enabled. -
eventListeners
EventListener[] eventListeners
-
heartbeatEnabled
boolean heartbeatEnabled
Whether heartbeats should be enabled. -
heartbeatInterval
long heartbeatInterval
Heartbeat interval, in milliseconds. -
logger
IgniteLogger logger
Logger. -
partitionAwarenessEnabled
boolean partitionAwarenessEnabled
Whether partition awareness should be enabled. -
partitionAwarenessMapperFactory
ClientPartitionAwarenessMapperFactory partitionAwarenessMapperFactory
This factory accepts as parameters a cache name and the number of cache partitions received from a server node and produces aClientPartitionAwarenessMapper
. This mapper function is used only for local calculations key to a partition and will not be passed to a server node. -
rcvBufSize
int rcvBufSize
Receive buffer size. 0 means system default. -
reconnectThrottlingPeriod
long reconnectThrottlingPeriod
Reconnect throttling period (in milliseconds). There are no more thanreconnectThrottlingRetries
attempts to reconnect will be made withinreconnectThrottlingPeriod
in case of connection loss. Throttling is disabled if eitherreconnectThrottlingRetries
orreconnectThrottlingPeriod
is 0. -
reconnectThrottlingRetries
int reconnectThrottlingRetries
Reconnect throttling retries. SeereconnectThrottlingPeriod
. -
retryLimit
int retryLimit
Retry limit. -
retryPolicy
ClientRetryPolicy retryPolicy
Retry policy. -
sndBufSize
int sndBufSize
Send buffer size. 0 means system default. -
sslClientCertKeyStorePath
String sslClientCertKeyStorePath
Ssl client certificate key store path. -
sslClientCertKeyStorePwd
String sslClientCertKeyStorePwd
Ssl client certificate key store password. -
sslClientCertKeyStoreType
String sslClientCertKeyStoreType
Ssl client certificate key store type. -
sslCtxFactory
javax.cache.configuration.Factory<SSLContext> sslCtxFactory
Ssl context factory. -
sslKeyAlgorithm
String sslKeyAlgorithm
Ssl key algorithm. -
sslMode
SslMode sslMode
Ssl mode. -
sslProto
SslProtocol sslProto
Ssl protocol. -
sslTrustAll
boolean sslTrustAll
Flag indicating if certificate validation errors should be ignored. -
sslTrustCertKeyStorePath
String sslTrustCertKeyStorePath
Ssl trust certificate key store path. -
sslTrustCertKeyStorePwd
String sslTrustCertKeyStorePwd
Ssl trust certificate key store password. -
sslTrustCertKeyStoreType
String sslTrustCertKeyStoreType
Ssl trust certificate key store type. -
tcpNoDelay
boolean tcpNoDelay
Tcp no delay. -
timeout
int timeout
Timeout. 0 means infinite. -
txCfg
ClientTransactionConfiguration txCfg
Tx config. -
userAttrs
Map<String,String> userAttrs
User attributes. -
userName
String userName
User name. -
userPwd
String userPwd
User password.
-
-
Class org.apache.ignite.configuration.ClientTransactionConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
dfltConcurrency
TransactionConcurrency dfltConcurrency
Cache concurrency. -
dfltIsolation
TransactionIsolation dfltIsolation
Transaction isolation. -
dfltTxTimeout
long dfltTxTimeout
Default transaction timeout.
-
-
Class org.apache.ignite.configuration.CollectionConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
atomicityMode
CacheAtomicityMode atomicityMode
Cache atomicity mode. -
backups
int backups
Number of backups. -
cacheMode
CacheMode cacheMode
Cache mode. -
collocated
boolean collocated
Collocated flag. -
grpName
String grpName
Group name. -
nodeFilter
IgnitePredicate<ClusterNode> nodeFilter
Node filter specifying nodes on which this cache should be deployed. -
offHeapMaxMem
long offHeapMaxMem
Deprecated.Off-heap memory size.
-
-
Class org.apache.ignite.configuration.DataRegionConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
cdcEnabled
boolean cdcEnabled
Change Data Capture enabled flag. -
checkpointPageBufSize
long checkpointPageBufSize
Temporary buffer size for checkpoints in bytes. -
emptyPagesPoolSize
int emptyPagesPoolSize
Minimum number of empty pages in reuse lists. -
evictionThreshold
double evictionThreshold
A threshold for memory pages eviction initiation. For instance, if the threshold is 0.9 it means that the page memory will start the eviction only after 90% data region is occupied. -
initSize
long initSize
Data region start size. -
lazyMemoryAllocation
boolean lazyMemoryAllocation
Iftrue
, memory forDataRegion
will be allocated only on the creation of the first cache belonged to thisDataRegion
. Default istrue
. -
maxSize
long maxSize
Data region maximum size in memory. -
memoryAllocator
@Nullable MemoryAllocator memoryAllocator
Memory allocator. -
metricsEnabled
boolean metricsEnabled
Flag to enable the memory metrics collection for this data region. -
metricsRateTimeInterval
long metricsRateTimeInterval
Time interval (in milliseconds) forDataRegionMetrics.getAllocationRate()
andDataRegionMetrics.getEvictionRate()
monitoring purposes.For instance, after setting the interval to 60_000 milliseconds, subsequent calls to
DataRegionMetrics.getAllocationRate()
will return average allocation rate (pages per second) for the last minute. -
metricsSubIntervalCount
int metricsSubIntervalCount
Number of sub-intervals the wholeDataRegionConfiguration.setMetricsRateTimeInterval(long)
will be split into to calculateDataRegionMetrics.getAllocationRate()
andDataRegionMetrics.getEvictionRate()
rates (5 by default).Setting it to a bigger value will result in more precise calculation and smaller drops of
DataRegionMetrics.getAllocationRate()
metric when next sub-interval has to be recycled but introduces bigger calculation overhead. -
name
String name
Data region name. -
pageEvictionMode
DataPageEvictionMode pageEvictionMode
An algorithm for memory pages eviction (persistence is disabled). -
pageReplacementMode
PageReplacementMode pageReplacementMode
An algorithm for memory pages replacement (persistence is enabled). -
persistenceEnabled
boolean persistenceEnabled
Flag to enable Ignite Native Persistence. -
swapPath
String swapPath
An optional path to a memory mapped files directory for this data region. -
warmUpCfg
@Nullable WarmUpConfiguration warmUpCfg
Warm-up configuration.
-
-
Class org.apache.ignite.configuration.DataStorageConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
alwaysWriteFullPages
boolean alwaysWriteFullPages
Always write full pages. -
cdcWalDirMaxSize
long cdcWalDirMaxSize
Change Data Capture directory size limit. -
cdcWalPath
String cdcWalPath
Change Data Capture path. -
checkpointFreq
long checkpointFreq
Checkpoint frequency. -
checkpointReadLockTimeout
Long checkpointReadLockTimeout
Timeout for checkpoint read lock acquisition. -
checkpointThreads
int checkpointThreads
-
checkpointWriteOrder
CheckpointWriteOrder checkpointWriteOrder
Checkpoint write order. -
concLvl
int concLvl
Concurrency level. -
dataRegions
DataRegionConfiguration[] dataRegions
Data regions. -
defragmentationThreadPoolSize
int defragmentationThreadPoolSize
Maximum number of partitions which can be defragmented at the same time. -
dfltDataRegConf
DataRegionConfiguration dfltDataRegConf
Configuration of default data region. -
dfltWarmUpCfg
@Nullable WarmUpConfiguration dfltWarmUpCfg
Default warm-up configuration. -
encCfg
EncryptionConfiguration encCfg
Encryption configuration. -
fileIOFactory
org.apache.ignite.internal.processors.cache.persistence.file.FileIOFactory fileIOFactory
Factory to provide I/O interface for data storage files -
lockWaitTime
long lockWaitTime
Lock wait time, in milliseconds. -
maxWalArchiveSize
long maxWalArchiveSize
Maximum size of wal archive folder, in bytes. -
memoryAllocator
@Nullable MemoryAllocator memoryAllocator
Default memory allocator for all data regions. -
metricsEnabled
boolean metricsEnabled
Deprecated.Will be removed in upcoming releases.Metrics enabled flag. -
metricsRateTimeInterval
long metricsRateTimeInterval
Time interval (in milliseconds) for rate-based metrics. -
metricsSubIntervalCnt
int metricsSubIntervalCnt
Number of sub-intervals the wholeDataStorageConfiguration.setMetricsRateTimeInterval(long)
will be split into to calculate rate-based metrics.Setting it to a bigger value will result in more precise calculation and smaller drops of rate-based metrics when next sub-interval has to be recycled but introduces bigger calculation overhead.
-
minWalArchiveSize
long minWalArchiveSize
Minimum size of wal archive folder, in bytes. -
pageSize
int pageSize
Memory page size. -
storagePath
String storagePath
Directory where index and partition files are stored. -
sysDataRegConf
SystemDataRegionConfiguration sysDataRegConf
Configuration of default data region. -
walArchivePath
String walArchivePath
WAL archive path. -
walAutoArchiveAfterInactivity
long walAutoArchiveAfterInactivity
Time interval (in milliseconds) for running auto archiving for incompletely WAL segment -
walBuffSize
int walBuffSize
WAl buffer size. -
walCompactionEnabled
boolean walCompactionEnabled
Flag to enable WAL compaction. If true, system filters and compresses WAL archive in background. Compressed WAL archive gets automatically decompressed on demand. -
walCompactionLevel
int walCompactionLevel
ZIP level to WAL compaction. -
walFlushFreq
long walFlushFreq
Wal flush frequency in milliseconds. -
walForceArchiveTimeout
long walForceArchiveTimeout
Time interval (in milliseconds) after last log of data change for force archiving of incompletely WAL segment. -
walFsyncDelay
long walFsyncDelay
Wal fsync delay. -
walHistSize
int walHistSize
Number of checkpoints to keep -
walMode
WALMode walMode
Wal mode. -
walPageCompression
DiskPageCompression walPageCompression
Compression algorithm for WAL page snapshot records. -
walPageCompressionLevel
Integer walPageCompressionLevel
Compression level for WAL page snapshot records. -
walPath
String walPath
Directory where WAL is stored (work directory) -
walRecordIterBuffSize
int walRecordIterBuffSize
Wal record iterator buffer size. -
walSegments
int walSegments
Number of work WAL segments. -
walSegmentSize
int walSegmentSize
Size of one WAL segment in bytes. 64 Mb is used by default. Maximum value is 2Gb -
walTlbSize
int walTlbSize
WAl thread local buffer size. -
writeThrottlingEnabled
boolean writeThrottlingEnabled
If true, threads that generate dirty pages too fast during ongoing checkpoint will be throttled.
-
-
Class org.apache.ignite.configuration.EncryptionConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
reencryptionBatchSize
int reencryptionBatchSize
The number of pages that is scanned during re-encryption under checkpoint lock. -
reencryptionRateLimit
double reencryptionRateLimit
Re-encryption rate limit in megabytes per second (set0
for unlimited scanning).
-
-
Class org.apache.ignite.configuration.IgniteReflectionFactory extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
cls
Class<? extends T> cls
Component class -
props
Map<String,Serializable> props
Properties -
singleton
boolean singleton
Singletom mode
-
-
Class org.apache.ignite.configuration.LoadAllWarmUpConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.configuration.MemoryConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
concLvl
int concLvl
Deprecated.Concurrency level. -
dfltMemPlcName
String dfltMemPlcName
Deprecated.A name of the memory policy that defines the default memory region. -
dfltMemPlcSize
long dfltMemPlcSize
Deprecated.Size of memory (in bytes) to use for default DataRegion. -
memPlcs
MemoryPolicyConfiguration[] memPlcs
Deprecated.Memory policies. -
pageSize
int pageSize
Deprecated.Memory page size. -
sysCacheInitSize
long sysCacheInitSize
Deprecated.Size of a memory chunk reserved for system cache initially. -
sysCacheMaxSize
long sysCacheMaxSize
Deprecated.Maximum size of system cache.
-
-
Class org.apache.ignite.configuration.MemoryPolicyConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
emptyPagesPoolSize
int emptyPagesPoolSize
Deprecated.Minimum number of empty pages in reuse lists. -
evictionThreshold
double evictionThreshold
Deprecated.A threshold for memory pages eviction initiation. For instance, if the threshold is 0.9 it means that the page memory will start the eviction only after 90% memory region (defined by this policy) is occupied. -
initialSize
long initialSize
Deprecated.Memory policy start size. -
maxSize
long maxSize
Deprecated.Memory policy maximum size. -
metricsEnabled
boolean metricsEnabled
Deprecated.Flag to enable the memory metrics collection for this memory policy. -
name
String name
Deprecated.Memory policy name. -
pageEvictionMode
DataPageEvictionMode pageEvictionMode
Deprecated.An algorithm for memory pages eviction. -
rateTimeInterval
long rateTimeInterval
Deprecated.Time interval (in milliseconds) forMemoryMetrics.getAllocationRate()
andMemoryMetrics.getEvictionRate()
monitoring purposes.For instance, after setting the interval to 60_000 milliseconds, subsequent calls to
MemoryMetrics.getAllocationRate()
will return average allocation rate (pages per second) for the last minute. -
subIntervals
int subIntervals
Deprecated.Number of sub-intervals the wholeMemoryPolicyConfiguration.setRateTimeInterval(long)
will be split into to calculateMemoryMetrics.getAllocationRate()
andMemoryMetrics.getEvictionRate()
rates (5 by default).Setting it to a bigger value will result in more precise calculation and smaller drops of
MemoryMetrics.getAllocationRate()
metric when next sub-interval has to be recycled but introduces bigger calculation overhead. -
swapFilePath
String swapFilePath
Deprecated.An optional path to a memory mapped file for this memory policy.
-
-
Class org.apache.ignite.configuration.NearCacheConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
nearEvictPlc
EvictionPolicy<K,V> nearEvictPlc
Deprecated.Near cache eviction policy. -
nearEvictPlcFactory
javax.cache.configuration.Factory nearEvictPlcFactory
Near cache eviction policy factory. -
nearStartSize
int nearStartSize
Default near cache start size.
-
-
Class org.apache.ignite.configuration.NoOpWarmUpConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.configuration.PersistentStoreConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
alwaysWriteFullPages
boolean alwaysWriteFullPages
Deprecated.Always write full pages. -
checkpointingFreq
long checkpointingFreq
Deprecated.Checkpointing frequency. -
checkpointingPageBufSize
long checkpointingPageBufSize
Deprecated. -
checkpointingThreads
int checkpointingThreads
Deprecated. -
checkpointWriteOrder
CheckpointWriteOrder checkpointWriteOrder
Deprecated.Checkpoint write order. -
fileIOFactory
org.apache.ignite.internal.processors.cache.persistence.file.FileIOFactory fileIOFactory
Deprecated.Factory to provide I/O interface for files -
lockWaitTime
long lockWaitTime
Deprecated.Lock wait time, in milliseconds. -
metricsEnabled
boolean metricsEnabled
Deprecated.Metrics enabled flag. -
persistenceStorePath
String persistenceStorePath
Deprecated. -
rateTimeInterval
long rateTimeInterval
Deprecated.Time interval (in milliseconds) for rate-based metrics. -
subIntervals
int subIntervals
Deprecated.Number of sub-intervals the wholePersistentStoreConfiguration.setRateTimeInterval(long)
will be split into to calculate rate-based metrics.Setting it to a bigger value will result in more precise calculation and smaller drops of rate-based metrics when next sub-interval has to be recycled but introduces bigger calculation overhead.
-
walArchivePath
String walArchivePath
Deprecated.WAL archive path. -
walAutoArchiveAfterInactivity
long walAutoArchiveAfterInactivity
Deprecated.Time interval (in milliseconds) for running auto archiving for incompletely WAL segment -
walBuffSize
int walBuffSize
Deprecated.WAl buffer size. -
walFlushFreq
long walFlushFreq
Deprecated.Wal flush frequency in milliseconds. -
walFsyncDelay
long walFsyncDelay
Deprecated.Wal fsync delay. -
walHistSize
int walHistSize
Deprecated.Number of checkpoints to keep -
walMode
WALMode walMode
Deprecated.Wal mode. -
walRecordIterBuffSize
int walRecordIterBuffSize
Deprecated.Wal record iterator buffer size. -
walSegments
int walSegments
Deprecated.Number of work WAL segments. -
walSegmentSize
int walSegmentSize
Deprecated.Size of one WAL segment in bytes. 64 Mb is used by default. Maximum value is 2Gb -
walStorePath
String walStorePath
Deprecated.Directory where WAL is stored (work directory) -
writeThrottlingEnabled
boolean writeThrottlingEnabled
Deprecated.If true, threads that generate dirty pages too fast during ongoing checkpoint will be throttled.
-
-
Class org.apache.ignite.configuration.PlatformCacheConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.configuration.SystemDataRegionConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
initSize
long initSize
Initial size in bytes of a memory chunk reserved for system cache. -
maxSize
long maxSize
Maximum size in bytes of a memory chunk reserved for system cache.
-
-
Class org.apache.ignite.configuration.TransactionConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
dfltConcurrency
TransactionConcurrency dfltConcurrency
Cache concurrency. -
dfltIsolation
TransactionIsolation dfltIsolation
Transaction isolation. -
dfltTxTimeout
long dfltTxTimeout
Default transaction timeout. -
pessimisticTxLogLinger
int pessimisticTxLogLinger
Deprecated.Pessimistic tx log linger. -
pessimisticTxLogSize
int pessimisticTxLogSize
Deprecated.Pessimistic tx log size. -
tmLookupClsName
String tmLookupClsName
Name of class implementing GridCacheTmLookup. -
txAwareQueriesEnabled
boolean txAwareQueriesEnabled
When set to true, Ignite will execute SQL and scan queries in transaction aware mode. Default isfalse
. -
txManagerFactory
javax.cache.configuration.Factory txManagerFactory
javax.transaction.TransactionManager
factory. -
txSerEnabled
boolean txSerEnabled
Default transaction serializable flag. -
txTimeoutOnPartitionMapExchange
long txTimeoutOnPartitionMapExchange
Transaction timeout on partition map exchange. Volatile in order to be changed dynamically. -
useJtaSync
boolean useJtaSync
Whether to use JTAjavax.transaction.Synchronization
instead ofjavax.transaction.xa.XAResource
.
-
-
-
Package org.apache.ignite.events
-
Class org.apache.ignite.events.BaselineChangedEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
baselineNodes
Collection<BaselineNode> baselineNodes
Baseline nodes.
-
-
Class org.apache.ignite.events.BaselineConfigurationChangedEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
autoAdjustEnabled
boolean autoAdjustEnabled
-
autoAdjustTimeout
long autoAdjustTimeout
-
-
Class org.apache.ignite.events.CacheConsistencyViolationEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
cacheName
String cacheName
Cache name. -
entries
Map<Object,CacheConsistencyViolationEvent.EntriesInfo> entries
Represents original values of entries. -
repaired
Map<Object,Object> repaired
Repaired entries. -
strategy
ReadRepairStrategy strategy
Strategy.
-
-
Class org.apache.ignite.events.CacheEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
cacheName
String cacheName
Cache name. -
cloClsName
String cloClsName
Closure class name. -
evtNode
@Nullable ClusterNode evtNode
Event node. -
hasNewVal
boolean hasNewVal
Flag indicating whether new value is present in case if we don't have it in deserialized form. -
hasOldVal
boolean hasOldVal
Flag indicating whether old value is present in case if we don't have it in deserialized form. -
key
Object key
Cache entry. -
lockId
Object lockId
Lock ID. -
near
boolean near
Flag indicating whether event happened onnear
orpartitioned
cache. -
newVal
Object newVal
New value. -
oldVal
Object oldVal
Old value. -
part
int part
Partition for the event. -
subjId
UUID subjId
Subject ID. -
taskName
String taskName
Task name if update was initiated within task execution. -
txLbl
String txLbl
Transaction label. -
xid
IgniteUuid xid
Transaction Id.
-
-
Class org.apache.ignite.events.CacheObjectTransformedEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
original
byte[] original
Original cache object bytes. -
restore
boolean restore
Restore operation. -
transformed
byte[] transformed
Transformed cache object bytes.
-
-
Class org.apache.ignite.events.CacheQueryExecutedEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 3738753361235304496L
-
Serialized Fields
-
args
Object[] args
Query arguments. -
cacheName
String cacheName
Cache name. -
clause
String clause
Clause. -
clsName
String clsName
Class name. -
contQryFilter
CacheEntryEventSerializableFilter<K,V> contQryFilter
Continuous query filter. -
qryType
String qryType
Query type. -
scanQryFilter
IgniteBiPredicate<K,V> scanQryFilter
Scan query filter. -
subjId
UUID subjId
Security subject ID. -
taskName
String taskName
Task name.
-
-
Class org.apache.ignite.events.CacheQueryReadEvent extends EventAdapter implements Serializable
- serialVersionUID:
- -1984731272984397445L
-
Serialized Fields
-
args
Object[] args
Query arguments. -
cacheName
String cacheName
Cache name. -
clause
String clause
Clause. -
clsName
String clsName
Class name. -
contQryFilter
CacheEntryEventSerializableFilter<K,V> contQryFilter
Continuous query filter. -
key
K key
Key. -
oldVal
V oldVal
Old value. -
qryType
String qryType
Query type. -
row
Object row
Result row. -
scanQryFilter
IgniteBiPredicate<K,V> scanQryFilter
Scan query filter. -
subjId
UUID subjId
Security subject ID. -
taskName
String taskName
Task name. -
val
V val
Value.
-
-
Class org.apache.ignite.events.CacheRebalancingEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
cacheName
String cacheName
Cache name. -
discoEvtType
int discoEvtType
Discovery event type. -
discoNode
ClusterNode discoNode
Discovery node. -
discoTs
long discoTs
Discovery event time. -
part
int part
Partition for the event.
-
-
Class org.apache.ignite.events.CheckpointEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
cpKey
String cpKey
-
-
Class org.apache.ignite.events.ClusterActivationEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
baselineNodes
Collection<BaselineNode> baselineNodes
Deprecated.Baseline nodes.
-
-
Class org.apache.ignite.events.ClusterStateChangeEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
baselineNodes
Collection<? extends BaselineNode> baselineNodes
Baseline nodes of current baseline topology. -
prevState
ClusterState prevState
Previous cluster state. -
state
ClusterState state
Current cluster state.
-
-
Class org.apache.ignite.events.ClusterStateChangeStartedEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
prevState
ClusterState prevState
Previous cluster state. -
state
ClusterState state
New cluster state. -
subjId
UUID subjId
Security subject ID.
-
-
Class org.apache.ignite.events.ClusterTagUpdatedEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.events.DeploymentEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
alias
String alias
-
-
Class org.apache.ignite.events.DiscoveryEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
evtNode
ClusterNode evtNode
-
msgTemplate
String msgTemplate
Template to generateDiscoveryEvent.message()
lazily. Will be joined withDiscoveryEvent.eventNode()
converted to string. -
topSnapshot
Collection<ClusterNode> topSnapshot
Collection of nodes corresponding to topology version. -
topVer
long topVer
Topology version.
-
-
Class org.apache.ignite.events.EventAdapter extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
id
IgniteUuid id
-
locId
long locId
-
msg
String msg
-
node
ClusterNode node
-
tstamp
long tstamp
-
type
int type
-
-
Class org.apache.ignite.events.JobEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
jobId
IgniteUuid jobId
-
resPlc
ComputeJobResultPolicy resPlc
-
sesId
IgniteUuid sesId
-
taskClsName
String taskClsName
-
taskName
String taskName
-
taskNode
ClusterNode taskNode
-
taskSubjId
UUID taskSubjId
-
-
Class org.apache.ignite.events.NodeValidationFailedEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
evtNode
ClusterNode evtNode
The node that attempted to join cluster. -
res
IgniteNodeValidationResult res
Validation result.
-
-
Class org.apache.ignite.events.PageReplacementStartedEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
dataRegionName
String dataRegionName
-
-
Class org.apache.ignite.events.SnapshotEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
snpName
String snpName
-
-
Class org.apache.ignite.events.SqlQueryExecutionEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.events.TaskEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
internal
boolean internal
-
sesId
IgniteUuid sesId
-
subjId
UUID subjId
-
taskClsName
String taskClsName
-
taskName
String taskName
-
-
Class org.apache.ignite.events.TransactionStateChangedEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
tx
Transaction tx
Tx.
-
-
Class org.apache.ignite.events.WalSegmentArchivedEvent extends EventAdapter implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
absWalSegmentIdx
long absWalSegmentIdx
Absolute WAL segment file index. -
archiveFile
File archiveFile
Destination archive file. This file is completed and closed archive segment
-
-
Class org.apache.ignite.events.WalSegmentCompactedEvent extends WalSegmentArchivedEvent implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.lang
-
Class org.apache.ignite.lang.IgniteBiTuple extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
Class org.apache.ignite.lang.IgniteFutureCancelledException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.lang.IgniteFutureTimeoutException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.lang.IgniteProductVersion extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
Class org.apache.ignite.lang.IgniteUuid extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException
- Throws:
IOException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
-
Package org.apache.ignite.marshaller
-
Class org.apache.ignite.marshaller.IgniteMarshallerClassFilter extends Object implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.messaging
-
Class org.apache.ignite.messaging.MessagingListenActor extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
keepGoing
boolean keepGoing
-
nodeId
UUID nodeId
-
-
-
Package org.apache.ignite.platform.dotnet
-
Class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
Class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactoryNative extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
nativeFactory
Object nativeFactory
-
-
-
Package org.apache.ignite.plugin
-
Class org.apache.ignite.plugin.PluginNotFoundException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
name
String name
Plugin name.
-
-
Class org.apache.ignite.plugin.PluginValidationException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.plugin.extensions.communication
-
Package org.apache.ignite.plugin.platform
-
Package org.apache.ignite.plugin.security
-
Class org.apache.ignite.plugin.security.SecurityBasicPermissionSet extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readObject
private void readObject(ObjectInputStream in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeObject
private void writeObject(ObjectOutputStream out) throws IOException
- Throws:
IOException
-
-
Serialized Fields
-
cachePermissions
Map<String,Collection<SecurityPermission>> cachePermissions
Cache permissions. -
dfltAllowAll
boolean dfltAllowAll
Default allow all. -
systemPermissions
Collection<SecurityPermission> systemPermissions
System permissions. -
taskPermissions
Map<String,Collection<SecurityPermission>> taskPermissions
Task permissions.
-
-
Class org.apache.ignite.plugin.security.SecurityCredentials extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException
- Throws:
IOException
ClassNotFoundException
-
writeExternal
public void writeExternal(ObjectOutput out) throws IOException
- Throws:
IOException
-
-
Class org.apache.ignite.plugin.security.SecurityException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.plugin.segmentation
-
Package org.apache.ignite.services
-
Class org.apache.ignite.services.ServiceConfiguration extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
affKey
Object affKey
Affinity key. -
cacheName
String cacheName
Cache name. -
interceptors
ServiceCallInterceptor[] interceptors
Interceptor. -
isStatisticsEnabled
boolean isStatisticsEnabled
Enables or disables service statistics. -
maxPerNodeCnt
int maxPerNodeCnt
Max per-node count. -
name
String name
Service name. -
nodeFilter
IgnitePredicate<ClusterNode> nodeFilter
Node filter. -
svc
Service svc
Service instance. -
totalCnt
int totalCnt
Total count.
-
-
Class org.apache.ignite.services.ServiceDeploymentException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
cfgs
Collection<ServiceConfiguration> cfgs
-
-
-
Package org.apache.ignite.spi
-
Class org.apache.ignite.spi.IgniteSpiException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.spi.IgniteSpiMultiException extends IgniteSpiException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.spi.IgniteSpiOperationTimeoutException extends IgniteCheckedException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.spi.IgniteSpiVersionCheckException extends IgniteSpiException implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.spi.collision.jobstealing
-
Class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
delta
int delta
Delta.
-
-
-
Package org.apache.ignite.spi.communication.tcp.messages
-
Class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
connectCnt
long connectCnt
-
nodeId
UUID nodeId
-
rcvCnt
long rcvCnt
-
-
Class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2 extends HandshakeMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
connIdx
int connIdx
-
-
Class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
nodeIdBytes
byte[] nodeIdBytes
-
-
Class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
rcvCnt
long rcvCnt
-
-
-
Package org.apache.ignite.spi.discovery
-
Package org.apache.ignite.spi.encryption.keystore
-
Class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionKey extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
digest
@org.jetbrains.annotations.Nullable byte[] digest
Key digest. -
k
Key k
Encryption key.
-
-
-
Package org.apache.ignite.spi.tracing
-
Class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.spi.tracing.TracingConfigurationParameters extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
includedScopes
Set<Scope> includedScopes
Set ofScope
that defines which sub-traces will be included in a given trace. In other words, if the child's span scope is equal to parent's scope or it belongs to the parent's span included scopes, then the given child span will be attached to the current trace, otherwise it'll be skipped. SeeSpan.isChainable(Scope)
for more details. -
samplingRate
double samplingRate
Number between 0 and 1 that more or less reflects the probability of sampling a specific trace. 0 and 1 have special meaning here, 0 means never 1 means always. Default value is 0 (never).
-
-
-
Package org.apache.ignite.ssl
-
Class org.apache.ignite.ssl.AbstractSslContextFactory extends Object implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
cipherSuites
String[] cipherSuites
Enabled cipher suites. -
proto
String proto
SSL protocol. -
protocols
String[] protocols
Enabled protocols. -
sslCtx
AtomicReference<SSLContext> sslCtx
Cached instance of anSSLContext
.
-
-
Class org.apache.ignite.ssl.SslContextFactory extends AbstractSslContextFactory implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
keyAlgorithm
String keyAlgorithm
Key manager algorithm. -
keyStoreFilePath
String keyStoreFilePath
Path to key store file -
keyStorePwd
char[] keyStorePwd
Key store password -
keyStoreType
String keyStoreType
Key store type. -
trustMgrs
TrustManager[] trustMgrs
Trust managers. -
trustStoreFilePath
String trustStoreFilePath
Path to trust store. -
trustStorePwd
char[] trustStorePwd
Trust store password -
trustStoreType
String trustStoreType
Trust store type.
-
-
-
Package org.apache.ignite.startup
-
Class org.apache.ignite.startup.BasicWarmupClosure extends Object implements Serializable
- serialVersionUID:
- 9175346848249957458L
-
Serialized Fields
-
discoveryPort
int discoveryPort
Warmup discovery port. -
gridCnt
int gridCnt
Grid count. -
iterCnt
int iterCnt
Per thread iteration count. -
keyRange
int keyRange
Key range. -
threadCnt
int threadCnt
Warmup thread count. -
warmupMethods
String[] warmupMethods
Methods to warmup.
-
-
-
Package org.apache.ignite.startup.cmdline
-
Class org.apache.ignite.startup.cmdline.AboutDialog extends JDialog implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
appName
String appName
Application name -
bannerSpec
String bannerSpec
Banner icon url spec -
closeAct
Action closeAct
Close action. -
closeBtn
JButton closeBtn
Close button. -
copyright
String copyright
Copyright. -
gbc
GridBagConstraints gbc
Grid bag constraints. -
release
LocalDate release
Release date. -
ver
String ver
Version.
-
-
-
Package org.apache.ignite.startup.servlet
-
Class org.apache.ignite.startup.servlet.ServletStartup extends javax.servlet.http.HttpServlet implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
igniteInstanceNames
Collection<String> igniteInstanceNames
-
-
-
Package org.apache.ignite.stream
-
Class org.apache.ignite.stream.StreamTransformer extends Object implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.stream.StreamVisitor extends Object implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.transactions
-
Class org.apache.ignite.transactions.TransactionDeadlockException extends TransactionException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.transactions.TransactionException extends IgniteException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.transactions.TransactionHeuristicException extends TransactionException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.transactions.TransactionOptimisticException extends TransactionException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.transactions.TransactionRollbackException extends TransactionException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.ignite.transactions.TransactionTimeoutException extends TransactionException implements Serializable
- serialVersionUID:
- 0L
-