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- 
reconnectFutIgniteFuture<?> 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- 
loginTimeoutint loginTimeout Login timeout.
- 
propsorg.apache.ignite.internal.jdbc.thin.ConnectionPropertiesImpl props Connection properties.
 
- 
 
- 
Class org.apache.ignite.IgniteSpringBean extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialization Methods- 
readExternalpublic void readExternal(ObjectInput in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeExternalpublic 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- 
enumValuesMap<String,Integer> enumValues Enum names to ordinals mapping.
- 
idMapperBinaryIdMapper idMapper ID mapper.
- 
isEnumboolean isEnum Enum flag.
- 
nameMapperBinaryNameMapper nameMapper Name mapper.
- 
serializerBinarySerializer serializer Serializer.
- 
typeNameString 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- 
_notNullFieldsSet<String> _notNullFields Fields that must have non-null value. NB: DO NOT remove underscore to avoid clashes with QueryEntityEx.
- 
aliasesMap<String,String> aliases Aliases.
- 
defaultFieldValuesMap<String,Object> defaultFieldValues Fields default values.
- 
fieldsLinkedHashMap<String,String> fields Fields available for query. A map from field name to type name.
- 
fieldsPrecisionMap<String,Integer> fieldsPrecision Precision(Maximum length) for fields.
- 
fieldsScaleMap<String,Integer> fieldsScale Scale for fields.
- 
idxsCollection<QueryIndex> idxs Collection of query indexes.
- 
keyFieldNameString keyFieldName Key name. Can be used in field list to denote the key as a whole.
- 
keyFieldsSet<String> keyFields Set of field names that belong to the key.
- 
keyTypeString keyType Key type.
- 
tableNameString tableName Table name.
- 
valTypeString valType Value type.
- 
valueFieldNameString 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- 
fieldsLinkedHashMap<String,Boolean> fields 
- 
inlineSizeint inlineSize 
- 
nameString name Index name.
- 
typeQueryIndexType type 
 
- 
 
 
- 
- 
Package org.apache.ignite.cache.affinity- 
Class org.apache.ignite.cache.affinity.AffinityKey extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialization Methods- 
readExternalpublic void readExternal(ObjectInput in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeExternalpublic void writeExternal(ObjectOutput out) throws IOException - Throws:
- IOException
 
 
- 
 
- 
Class org.apache.ignite.cache.affinity.AffinityUuid extends AffinityKey<IgniteUuid> implements Serializable- serialVersionUID:
- 0L
 - 
Serialization Methods- 
readExternalpublic void readExternal(ObjectInput in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeExternalpublic 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- 
attrNamesString[] attrNames Attribute names.
 
- 
 
- 
Class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeColocatedBackupFilter extends Object implements Serializable- serialVersionUID:
- 1L
 - 
Serialized Fields- 
attrNameString attrName Attribute name.
 
- 
 
- 
Class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
affinityBackupFilterIgniteBiPredicate<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).
- 
backupFilterIgniteBiPredicate<ClusterNode,ClusterNode> backupFilter Optional backup filter. First node is primary, second node is a node being tested.
- 
exclNeighborsboolean exclNeighbors Exclude neighbors flag.
- 
maskint mask Mask to use in calculation when partitions count is power of 2.
- 
partsint 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- 
readExternalpublic void readExternal(ObjectInput in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeExternalpublic void writeExternal(ObjectOutput out) throws IOException - Throws:
- IOException
 
 
- 
 
- 
Class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory extends Object implements Serializable- 
Serialized Fields- 
batchSizeint batchSize 
- 
maxMemSizelong maxMemSize 
- 
maxSizeint 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- 
readExternalpublic void readExternal(ObjectInput in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeExternalpublic 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- 
readExternalpublic void readExternal(ObjectInput in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeExternalpublic 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- 
readExternalpublic void readExternal(ObjectInput in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeExternalpublic 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- 
compComparator<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- 
autoUnsubscribeboolean autoUnsubscribe Automatic unsubscription flag.
- 
includeExpiredboolean includeExpired Whether to notify aboutEventType.EXPIREDevents.
- 
initQryQuery<javax.cache.Cache.Entry<K,V>> initQry Initial query.
- 
rmtFilterFactoryjavax.cache.configuration.Factory<? extends javax.cache.event.CacheEntryEventFilter<K,V>> rmtFilterFactory Remote filter factory.
- 
timeIntervallong 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- 
locLsnrjavax.cache.event.CacheEntryUpdatedListener<K,V> locLsnr Local listener.
- 
rmtFilterCacheEntryEventSerializableFilter<K,V> rmtFilter Remote filter.
 
- 
 
- 
Class org.apache.ignite.cache.query.ContinuousQueryWithTransformer extends AbstractContinuousQuery<K,V> implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
locLsnrContinuousQueryWithTransformer.EventListener<T> locLsnr Local listener of transformed event
- 
rmtTransFactoryjavax.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.
- 
filterIgniteBiPredicate<K,V> filter Cache entries filter. Applies remotely to a query result cursor.
- 
idxName@Nullable String idxName Index name.
- 
limitint limit Limit
- 
part@Nullable Integer part Partition to run IndexQuery over.
- 
valTypeString 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- 
locboolean loc Local flag.
- 
pageSizeint 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- 
filterIgniteBiPredicate<K,V> filter 
- 
partInteger part 
 
- 
 
- 
Class org.apache.ignite.cache.query.SpiQuery extends Query<javax.cache.Cache.Entry<K,V>> implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
argsObject[] args Deprecated.Arguments.
 
- 
 
- 
Class org.apache.ignite.cache.query.SqlFieldsQuery extends Query<List<?>> implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
argsObject[] args Arguments.
- 
collocatedboolean collocated Collocation flag.
- 
distributedJoinsboolean distributedJoins 
- 
enforceJoinOrderboolean enforceJoinOrder 
- 
lazyboolean lazy Deprecated.UseSqlFieldsQuery.setPageSize(int)instead.Lazy mode is default since Ignite v.2.8.
- 
partsint[] parts Partitions for query
- 
qryInitiatorIdString qryInitiatorId Query's originator string (client host+port, user name, job name or any user's information about query initiator).
- 
replicatedOnlyboolean replicatedOnly 
- 
schemaString schema Schema.
- 
sqlString sql SQL Query.
- 
timeoutint timeout Query timeout in millis.
- 
updateBatchSizeint 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- 
aliasString alias Deprecated.Table alias
- 
argsObject[] args Deprecated.Arguments.
- 
distributedJoinsboolean distributedJoins Deprecated.
- 
partsint[] parts Deprecated.Partitions for query
- 
replicatedOnlyboolean replicatedOnly Deprecated.
- 
sqlString sql Deprecated.SQL clause.
- 
timeoutint timeout Deprecated.Timeout in millis.
- 
typeString 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- 
appCtxObject appCtx Application context.
- 
connUrlString connUrl Connection URL.
- 
createTblQryString createTblQry Query to create table.
- 
dataSrcBeanString dataSrcBean Name of data source bean.
- 
delQryString delQry Query to delete entries.
- 
initSchemaboolean initSchema Flag for schema initialization.
- 
insertQryString insertQry Query to insert entries.
- 
loadQryString loadQry Query to load entry.
- 
passwdString passwd Password for database access.
- 
updateQryString updateQry Query to update entry.
- 
userString user User name for database access.
 
- 
 
- 
Class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
batchSizeint batchSize Maximum batch size for writeAll and deleteAll operations.
- 
dataSrcBeanString dataSrcBean Name of data source bean.
- 
dataSrcFactoryjavax.cache.configuration.Factory<DataSource> dataSrcFactory Data source factory.
- 
dialectJdbcDialect dialect Database dialect.
- 
hasherJdbcTypeHasher hasher Hash calculator.
- 
maxPoolSizeint maxPoolSize Max workers thread count. These threads are responsible for load cache.
- 
maxWrtAttemptsint maxWrtAttempts Maximum write attempts in case of database error.
- 
parallelLoadCacheMinThresholdint parallelLoadCacheMinThreshold Parallel load cache minimum threshold. If0then load sequentially.
- 
sqlEscapeAllboolean sqlEscapeAll Flag indicating that table and field names should be escaped in all SQL queries created by JDBC POJO store.
- 
transformerJdbcTypesTransformer transformer Types transformer.
- 
typesJdbcType[] types Types that store could process.
 
- 
 
- 
Class org.apache.ignite.cache.store.jdbc.JdbcType extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
cacheNameString cacheName Cache name.
- 
dbSchemaString dbSchema Schema name in database.
- 
dbTblString dbTbl Table name in database.
- 
hasherJdbcTypeHasher hasher Custom type hasher.
- 
keyFieldsJdbcTypeField[] keyFields List of fields descriptors for key object.
- 
keyTypeString keyType Key class used to store key in cache.
- 
valFldsJdbcTypeField[] valFlds List of fields descriptors for value object.
- 
valTypeString 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- 
fetchSizeint fetchSize Fetch size.
- 
maxParamsCntint 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- 
atomicityModeCacheAtomicityMode atomicityMode Atomicity mode.
- 
backupsint backups Backups.
- 
cacheModeCacheMode cacheMode Cache mode.
- 
cpOnReadboolean cpOnRead Copy on read.
- 
dataRegionNameString dataRegionName Data region name.
- 
dfltLockTimeoutlong dfltLockTimeout Default lock timeout.
- 
eagerTtlboolean eagerTtl Eager TTL flag.
- 
expiryPlcjavax.cache.expiry.ExpiryPolicy expiryPlc Expiry policy.
- 
grpNameString grpName Group name.
- 
keyCfgCacheKeyConfiguration[] keyCfg Key config.
- 
maxConcurrentAsyncOperationsint maxConcurrentAsyncOperations Max concurrent async operations.
- 
maxQryIteratorsCntint maxQryIteratorsCnt Max query iterators count.
- 
nameString name Cache name.
- 
onheapCacheEnabledboolean onheapCacheEnabled Onheap cache enabled.
- 
partLossPlcPartitionLossPolicy partLossPlc Partition loss policy.
- 
qryDetailMetricsSizeint qryDetailMetricsSize Query detail metrics size.
- 
qryEntitiesQueryEntity[] qryEntities Query entities.
- 
qryParallelismint qryParallelism Query parallelism.
- 
readFromBackupboolean readFromBackup Read from backup.
- 
rebalanceBatchesPrefetchCntlong rebalanceBatchesPrefetchCnt Rebalance batches prefetch count.
- 
rebalanceBatchSizeint rebalanceBatchSize Rebalance batch size.
- 
rebalanceDelaylong rebalanceDelay Rebalance delay.
- 
rebalanceModeCacheRebalanceMode rebalanceMode Rebalance mode.
- 
rebalanceOrderint rebalanceOrder Rebalance order.
- 
rebalanceThrottlelong rebalanceThrottle Rebalance throttle.
- 
rebalanceTimeoutlong rebalanceTimeout Rebalance timeout.
- 
sqlEscapeAllboolean sqlEscapeAll Sql escape all.
- 
sqlIdxMaxInlineSizeint sqlIdxMaxInlineSize Sql index max inline size.
- 
sqlSchemaString sqlSchema Sql schema.
- 
statisticsEnabledboolean statisticsEnabled Statistics enabled.
- 
writeSynchronizationModeCacheWriteSynchronizationMode 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- 
argsObject[] 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- 
balancerComputeLoadBalancer 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- 
compactFooterboolean compactFooter Compact footer flag.
- 
idMapperBinaryIdMapper idMapper ID mapper.
- 
nameMapperBinaryNameMapper nameMapper Name mapper.
- 
serializerBinarySerializer serializer Serializer.
- 
typeCfgsCollection<BinaryTypeConfiguration> typeCfgs Types.
 
- 
 
- 
Class org.apache.ignite.configuration.CacheConfiguration extends javax.cache.configuration.MutableConfiguration<K,V> implements Serializable- serialVersionUID:
- 0L
 - 
Serialization Methods- 
writeReplaceprotected 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- 
affAffinityFunction aff Node group resolver.
- 
affMapperAffinityKeyMapper affMapper 
- 
atomicityModeCacheAtomicityMode atomicityMode Cache atomicity mode.
- 
backupsint backups Number of backups for cache.
- 
cacheModeCacheMode cacheMode Cache mode.
- 
cpOnReadboolean cpOnRead Copy on read flag.
- 
dfltLockTimeoutlong dfltLockTimeout Deprecated.Default lock timeout.
- 
diskPageCompressionDiskPageCompression diskPageCompression 
- 
diskPageCompressionLevelInteger diskPageCompressionLevel 
- 
eagerTtlboolean eagerTtl Eager ttl flag.
- 
encryptionEnabledboolean encryptionEnabled Flag indicating whether data must be encrypted. Iftruedata on the disk will be encrypted.- See Also:
- EncryptionSpi,- KeystoreEncryptionSpi
 
- 
evictFilterEvictionFilter<?,?> evictFilter Eviction filter.
- 
evictPlcEvictionPolicy evictPlc Deprecated.Cache eviction policy.
- 
evictPlcFactoryjavax.cache.configuration.Factory evictPlcFactory Cache eviction policy factory.
- 
evtsDisabledboolean evtsDisabled Events disabled.
- 
grpNameString grpName Cache group name.
- 
interceptorCacheInterceptor<K,V> interceptor 
- 
invalidateboolean invalidate Flag indicating whether this is invalidation-based cache.
- 
keyCfgCacheKeyConfiguration[] keyCfg Cache key configuration.
- 
loadPrevValboolean loadPrevVal 
- 
longQryWarnTimeoutlong longQryWarnTimeout Deprecated.
- 
maxConcurrentAsyncOpsint maxConcurrentAsyncOps Maximum number of concurrent asynchronous operations.
- 
maxQryIterCntint maxQryIterCnt Maximum number of query iterators that can be stored.
- 
memPlcNameString memPlcName Name ofDataRegionConfigurationfor this cache
- 
nameString name Cache name.
- 
nearCfgNearCacheConfiguration<K,V> nearCfg Near cache configuration.
- 
nodeFilterIgnitePredicate<ClusterNode> nodeFilter Node filter specifying nodes on which this cache should be deployed.
- 
onheapCacheboolean onheapCache 
- 
partLossPlcPartitionLossPolicy partLossPlc Partition loss policy.
- 
platformCfgPlatformCacheConfiguration platformCfg Platform cache configuration. Enables native cache in platforms (.NET, ...).
- 
pluginCfgsCachePluginConfiguration[] pluginCfgs Cache plugin configurations.
- 
qryDetailMetricsSzint qryDetailMetricsSz 
- 
qryEntitiesCollection<QueryEntity> qryEntities Query entities.
- 
qryParallelismint qryParallelism 
- 
readFromBackupboolean readFromBackup Flag indicating whether data can be read from backup. Iffalsealways get data from primary node (never from backup).
- 
rebalanceBatchesPrefetchCntlong rebalanceBatchesPrefetchCnt Deprecated.Rebalance batches prefetch count.
- 
rebalanceBatchSizeint rebalanceBatchSize Deprecated.Rebalance batch size.
- 
rebalanceDelaylong rebalanceDelay 
- 
rebalanceModeCacheRebalanceMode rebalanceMode Distributed cache rebalance mode.
- 
rebalanceOrderint rebalanceOrder Cache rebalance order.
- 
rebalancePoolSizeint rebalancePoolSize Deprecated.Rebalance thread pool size.
- 
rebalanceThrottlelong rebalanceThrottle Deprecated.Time in milliseconds to wait between rebalance messages to avoid overloading CPU.
- 
rebalanceTimeoutlong rebalanceTimeout Deprecated.Rebalance timeout.
- 
sqlEscapeAllboolean sqlEscapeAll 
- 
sqlFuncClsClass<?>[] sqlFuncCls 
- 
sqlIdxMaxInlineSizeint sqlIdxMaxInlineSize Maximum inline size for sql indexes.
- 
sqlOnheapCacheboolean sqlOnheapCache Use on-heap cache for rows for SQL queries.
- 
sqlOnheapCacheMaxSizeint sqlOnheapCacheMaxSize SQL on-heap cache max size.
- 
sqlSchemaString sqlSchema 
- 
storeConcurrentLoadAllThresholdint storeConcurrentLoadAllThreshold Threshold for concurrent loading of keys fromCacheStore.
- 
storeFactoryjavax.cache.configuration.Factory storeFactory 
- 
storeKeepBinaryBoolean storeKeepBinary 
- 
storeSesLsnrsjavax.cache.configuration.Factory<? extends CacheStoreSessionListener>[] storeSesLsnrs Cache store session listeners.
- 
tmLookupClsNameString tmLookupClsName Name of class implementing GridCacheTmLookup.
- 
topValidatorTopologyValidator topValidator Cache topology validator.
- 
writeBehindBatchSizeint writeBehindBatchSize Maximum batch size for write-behind cache store.
- 
writeBehindCoalescingboolean writeBehindCoalescing Write coalescing flag for write-behind cache store
- 
writeBehindEnabledboolean writeBehindEnabled Write-behind feature.
- 
writeBehindFlushFreqlong writeBehindFlushFreq Write-behind flush frequency in milliseconds.
- 
writeBehindFlushSizeint writeBehindFlushSize Maximum size of write-behind cache.
- 
writeBehindFlushThreadCntint writeBehindFlushThreadCnt Flush thread count for write-behind cache store.
- 
writeSyncCacheWriteSynchronizationMode 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- 
addrsString[] addrs Server addresses.
- 
asyncContinuationExecutorExecutor asyncContinuationExecutor Executor for async operations continuations.
- 
autoBinaryConfigurationEnabledboolean autoBinaryConfigurationEnabled Whether automatic binary configuration should be enabled.
- 
binaryCfgBinaryConfiguration binaryCfg Configuration for Ignite binary objects.
- 
clusterDiscoveryEnabledboolean clusterDiscoveryEnabled Whether cluster discovery should be enabled.
- 
eventListenersEventListener[] eventListeners 
- 
heartbeatEnabledboolean heartbeatEnabled Whether heartbeats should be enabled.
- 
heartbeatIntervallong heartbeatInterval Heartbeat interval, in milliseconds.
- 
loggerIgniteLogger logger Logger.
- 
partitionAwarenessEnabledboolean partitionAwarenessEnabled Whether partition awareness should be enabled.
- 
partitionAwarenessMapperFactoryClientPartitionAwarenessMapperFactory 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.
- 
rcvBufSizeint rcvBufSize Receive buffer size. 0 means system default.
- 
reconnectThrottlingPeriodlong reconnectThrottlingPeriod Reconnect throttling period (in milliseconds). There are no more thanreconnectThrottlingRetriesattempts to reconnect will be made withinreconnectThrottlingPeriodin case of connection loss. Throttling is disabled if eitherreconnectThrottlingRetriesorreconnectThrottlingPeriodis 0.
- 
reconnectThrottlingRetriesint reconnectThrottlingRetries Reconnect throttling retries. SeereconnectThrottlingPeriod.
- 
retryLimitint retryLimit Retry limit.
- 
retryPolicyClientRetryPolicy retryPolicy Retry policy.
- 
sndBufSizeint sndBufSize Send buffer size. 0 means system default.
- 
sslClientCertKeyStorePathString sslClientCertKeyStorePath Ssl client certificate key store path.
- 
sslClientCertKeyStorePwdString sslClientCertKeyStorePwd Ssl client certificate key store password.
- 
sslClientCertKeyStoreTypeString sslClientCertKeyStoreType Ssl client certificate key store type.
- 
sslCtxFactoryjavax.cache.configuration.Factory<SSLContext> sslCtxFactory Ssl context factory.
- 
sslKeyAlgorithmString sslKeyAlgorithm Ssl key algorithm.
- 
sslModeSslMode sslMode Ssl mode.
- 
sslProtoSslProtocol sslProto Ssl protocol.
- 
sslTrustAllboolean sslTrustAll Flag indicating if certificate validation errors should be ignored.
- 
sslTrustCertKeyStorePathString sslTrustCertKeyStorePath Ssl trust certificate key store path.
- 
sslTrustCertKeyStorePwdString sslTrustCertKeyStorePwd Ssl trust certificate key store password.
- 
sslTrustCertKeyStoreTypeString sslTrustCertKeyStoreType Ssl trust certificate key store type.
- 
tcpNoDelayboolean tcpNoDelay Tcp no delay.
- 
timeoutint timeout Timeout. 0 means infinite.
- 
txCfgClientTransactionConfiguration txCfg Tx config.
- 
userAttrsMap<String,String> userAttrs User attributes.
- 
userNameString userName User name.
- 
userPwdString userPwd User password.
 
- 
 
- 
Class org.apache.ignite.configuration.ClientTransactionConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
dfltConcurrencyTransactionConcurrency dfltConcurrency Cache concurrency.
- 
dfltIsolationTransactionIsolation dfltIsolation Transaction isolation.
- 
dfltTxTimeoutlong dfltTxTimeout Default transaction timeout.
 
- 
 
- 
Class org.apache.ignite.configuration.CollectionConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
atomicityModeCacheAtomicityMode atomicityMode Cache atomicity mode.
- 
backupsint backups Number of backups.
- 
cacheModeCacheMode cacheMode Cache mode.
- 
collocatedboolean collocated Collocated flag.
- 
grpNameString grpName Group name.
- 
nodeFilterIgnitePredicate<ClusterNode> nodeFilter Node filter specifying nodes on which this cache should be deployed.
- 
offHeapMaxMemlong offHeapMaxMem Deprecated.Off-heap memory size.
 
- 
 
- 
Class org.apache.ignite.configuration.DataRegionConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
cdcEnabledboolean cdcEnabled Change Data Capture enabled flag.
- 
checkpointPageBufSizelong checkpointPageBufSize Temporary buffer size for checkpoints in bytes.
- 
emptyPagesPoolSizeint emptyPagesPoolSize Minimum number of empty pages in reuse lists.
- 
evictionThresholddouble 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.
- 
initSizelong initSize Data region start size.
- 
lazyMemoryAllocationboolean lazyMemoryAllocation Iftrue, memory forDataRegionwill be allocated only on the creation of the first cache belonged to thisDataRegion. Default istrue.
- 
maxSizelong maxSize Data region maximum size in memory.
- 
memoryAllocator@Nullable MemoryAllocator memoryAllocator Memory allocator.
- 
metricsEnabledboolean metricsEnabled Flag to enable the memory metrics collection for this data region.
- 
metricsRateTimeIntervallong 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.
- 
metricsSubIntervalCountint 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.
- 
nameString name Data region name.
- 
pageEvictionModeDataPageEvictionMode pageEvictionMode An algorithm for memory pages eviction (persistence is disabled).
- 
pageReplacementModePageReplacementMode pageReplacementMode An algorithm for memory pages replacement (persistence is enabled).
- 
persistenceEnabledboolean persistenceEnabled Flag to enable Ignite Native Persistence.
- 
swapPathString 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- 
alwaysWriteFullPagesboolean alwaysWriteFullPages Always write full pages.
- 
cdcWalDirMaxSizelong cdcWalDirMaxSize Change Data Capture directory size limit.
- 
cdcWalPathString cdcWalPath Change Data Capture path.
- 
checkpointFreqlong checkpointFreq Checkpoint frequency.
- 
checkpointReadLockTimeoutLong checkpointReadLockTimeout Timeout for checkpoint read lock acquisition.
- 
checkpointThreadsint checkpointThreads 
- 
checkpointWriteOrderCheckpointWriteOrder checkpointWriteOrder Checkpoint write order.
- 
concLvlint concLvl Concurrency level.
- 
dataRegionsDataRegionConfiguration[] dataRegions Data regions.
- 
defragmentationThreadPoolSizeint defragmentationThreadPoolSize Maximum number of partitions which can be defragmented at the same time.
- 
dfltDataRegConfDataRegionConfiguration dfltDataRegConf Configuration of default data region.
- 
dfltWarmUpCfg@Nullable WarmUpConfiguration dfltWarmUpCfg Default warm-up configuration.
- 
encCfgEncryptionConfiguration encCfg Encryption configuration.
- 
fileIOFactoryorg.apache.ignite.internal.processors.cache.persistence.file.FileIOFactory fileIOFactory Factory to provide I/O interface for data storage files
- 
lockWaitTimelong lockWaitTime Lock wait time, in milliseconds.
- 
maxWalArchiveSizelong maxWalArchiveSize Maximum size of wal archive folder, in bytes.
- 
memoryAllocator@Nullable MemoryAllocator memoryAllocator Default memory allocator for all data regions.
- 
metricsEnabledboolean metricsEnabled Deprecated.Will be removed in upcoming releases.Metrics enabled flag.
- 
metricsRateTimeIntervallong metricsRateTimeInterval Time interval (in milliseconds) for rate-based metrics.
- 
metricsSubIntervalCntint 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. 
- 
minWalArchiveSizelong minWalArchiveSize Minimum size of wal archive folder, in bytes.
- 
pageSizeint pageSize Memory page size.
- 
storagePathString storagePath Directory where index and partition files are stored.
- 
sysDataRegConfSystemDataRegionConfiguration sysDataRegConf Configuration of default data region.
- 
walArchivePathString walArchivePath WAL archive path.
- 
walAutoArchiveAfterInactivitylong walAutoArchiveAfterInactivity Time interval (in milliseconds) for running auto archiving for incompletely WAL segment
- 
walBuffSizeint walBuffSize WAl buffer size.
- 
walCompactionEnabledboolean walCompactionEnabled Flag to enable WAL compaction. If true, system filters and compresses WAL archive in background. Compressed WAL archive gets automatically decompressed on demand.
- 
walCompactionLevelint walCompactionLevel ZIP level to WAL compaction.
- 
walFlushFreqlong walFlushFreq Wal flush frequency in milliseconds.
- 
walForceArchiveTimeoutlong walForceArchiveTimeout Time interval (in milliseconds) after last log of data change for force archiving of incompletely WAL segment.
- 
walFsyncDelaylong walFsyncDelay Wal fsync delay.
- 
walHistSizeint walHistSize Number of checkpoints to keep
- 
walModeWALMode walMode Wal mode.
- 
walPageCompressionDiskPageCompression walPageCompression Compression algorithm for WAL page snapshot records.
- 
walPageCompressionLevelInteger walPageCompressionLevel Compression level for WAL page snapshot records.
- 
walPathString walPath Directory where WAL is stored (work directory)
- 
walRecordIterBuffSizeint walRecordIterBuffSize Wal record iterator buffer size.
- 
walSegmentsint walSegments Number of work WAL segments.
- 
walSegmentSizeint walSegmentSize Size of one WAL segment in bytes. 64 Mb is used by default. Maximum value is 2Gb
- 
walTlbSizeint walTlbSize WAl thread local buffer size.
- 
writeThrottlingEnabledboolean 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- 
reencryptionBatchSizeint reencryptionBatchSize The number of pages that is scanned during re-encryption under checkpoint lock.
- 
reencryptionRateLimitdouble reencryptionRateLimit Re-encryption rate limit in megabytes per second (set0for unlimited scanning).
 
- 
 
- 
Class org.apache.ignite.configuration.IgniteReflectionFactory extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
clsClass<? extends T> cls Component class
- 
propsMap<String,Serializable> props Properties
- 
singletonboolean 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- 
concLvlint concLvl Deprecated.Concurrency level.
- 
dfltMemPlcNameString dfltMemPlcName Deprecated.A name of the memory policy that defines the default memory region.
- 
dfltMemPlcSizelong dfltMemPlcSize Deprecated.Size of memory (in bytes) to use for default DataRegion.
- 
memPlcsMemoryPolicyConfiguration[] memPlcs Deprecated.Memory policies.
- 
pageSizeint pageSize Deprecated.Memory page size.
- 
sysCacheInitSizelong sysCacheInitSize Deprecated.Size of a memory chunk reserved for system cache initially.
- 
sysCacheMaxSizelong sysCacheMaxSize Deprecated.Maximum size of system cache.
 
- 
 
- 
Class org.apache.ignite.configuration.MemoryPolicyConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
emptyPagesPoolSizeint emptyPagesPoolSize Deprecated.Minimum number of empty pages in reuse lists.
- 
evictionThresholddouble 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.
- 
initialSizelong initialSize Deprecated.Memory policy start size.
- 
maxSizelong maxSize Deprecated.Memory policy maximum size.
- 
metricsEnabledboolean metricsEnabled Deprecated.Flag to enable the memory metrics collection for this memory policy.
- 
nameString name Deprecated.Memory policy name.
- 
pageEvictionModeDataPageEvictionMode pageEvictionMode Deprecated.An algorithm for memory pages eviction.
- 
rateTimeIntervallong 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.
- 
subIntervalsint 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.
- 
swapFilePathString 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- 
nearEvictPlcEvictionPolicy<K,V> nearEvictPlc Deprecated.Near cache eviction policy.
- 
nearEvictPlcFactoryjavax.cache.configuration.Factory nearEvictPlcFactory Near cache eviction policy factory.
- 
nearStartSizeint 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- 
alwaysWriteFullPagesboolean alwaysWriteFullPages Deprecated.Always write full pages.
- 
checkpointingFreqlong checkpointingFreq Deprecated.Checkpointing frequency.
- 
checkpointingPageBufSizelong checkpointingPageBufSize Deprecated.
- 
checkpointingThreadsint checkpointingThreads Deprecated.
- 
checkpointWriteOrderCheckpointWriteOrder checkpointWriteOrder Deprecated.Checkpoint write order.
- 
fileIOFactoryorg.apache.ignite.internal.processors.cache.persistence.file.FileIOFactory fileIOFactory Deprecated.Factory to provide I/O interface for files
- 
lockWaitTimelong lockWaitTime Deprecated.Lock wait time, in milliseconds.
- 
metricsEnabledboolean metricsEnabled Deprecated.Metrics enabled flag.
- 
persistenceStorePathString persistenceStorePath Deprecated.
- 
rateTimeIntervallong rateTimeInterval Deprecated.Time interval (in milliseconds) for rate-based metrics.
- 
subIntervalsint 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. 
- 
walArchivePathString walArchivePath Deprecated.WAL archive path.
- 
walAutoArchiveAfterInactivitylong walAutoArchiveAfterInactivity Deprecated.Time interval (in milliseconds) for running auto archiving for incompletely WAL segment
- 
walBuffSizeint walBuffSize Deprecated.WAl buffer size.
- 
walFlushFreqlong walFlushFreq Deprecated.Wal flush frequency in milliseconds.
- 
walFsyncDelaylong walFsyncDelay Deprecated.Wal fsync delay.
- 
walHistSizeint walHistSize Deprecated.Number of checkpoints to keep
- 
walModeWALMode walMode Deprecated.Wal mode.
- 
walRecordIterBuffSizeint walRecordIterBuffSize Deprecated.Wal record iterator buffer size.
- 
walSegmentsint walSegments Deprecated.Number of work WAL segments.
- 
walSegmentSizeint walSegmentSize Deprecated.Size of one WAL segment in bytes. 64 Mb is used by default. Maximum value is 2Gb
- 
walStorePathString walStorePath Deprecated.Directory where WAL is stored (work directory)
- 
writeThrottlingEnabledboolean 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- 
initSizelong initSize Initial size in bytes of a memory chunk reserved for system cache.
- 
maxSizelong 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- 
dfltConcurrencyTransactionConcurrency dfltConcurrency Cache concurrency.
- 
dfltIsolationTransactionIsolation dfltIsolation Transaction isolation.
- 
dfltTxTimeoutlong dfltTxTimeout Default transaction timeout.
- 
pessimisticTxLogLingerint pessimisticTxLogLinger Deprecated.Pessimistic tx log linger.
- 
pessimisticTxLogSizeint pessimisticTxLogSize Deprecated.Pessimistic tx log size.
- 
tmLookupClsNameString tmLookupClsName Name of class implementing GridCacheTmLookup.
- 
txAwareQueriesEnabledboolean txAwareQueriesEnabled When set to true, Ignite will execute SQL and scan queries in transaction aware mode. Default isfalse.
- 
txManagerFactoryjavax.cache.configuration.Factory txManagerFactory javax.transaction.TransactionManagerfactory.
- 
txSerEnabledboolean txSerEnabled Default transaction serializable flag.
- 
txTimeoutOnPartitionMapExchangelong txTimeoutOnPartitionMapExchange Transaction timeout on partition map exchange. Volatile in order to be changed dynamically.
- 
useJtaSyncboolean useJtaSync Whether to use JTAjavax.transaction.Synchronizationinstead ofjavax.transaction.xa.XAResource.
 
- 
 
 
- 
- 
Package org.apache.ignite.events- 
Class org.apache.ignite.events.BaselineChangedEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
baselineNodesCollection<BaselineNode> baselineNodes Baseline nodes.
 
- 
 
- 
Class org.apache.ignite.events.BaselineConfigurationChangedEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
autoAdjustEnabledboolean autoAdjustEnabled 
- 
autoAdjustTimeoutlong autoAdjustTimeout 
 
- 
 
- 
Class org.apache.ignite.events.CacheConsistencyViolationEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
cacheNameString cacheName Cache name.
- 
entriesMap<Object,CacheConsistencyViolationEvent.EntriesInfo> entries Represents original values of entries.
- 
repairedMap<Object,Object> repaired Repaired entries.
- 
strategyReadRepairStrategy strategy Strategy.
 
- 
 
- 
Class org.apache.ignite.events.CacheEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
cacheNameString cacheName Cache name.
- 
cloClsNameString cloClsName Closure class name.
- 
evtNode@Nullable ClusterNode evtNode Event node.
- 
hasNewValboolean hasNewVal Flag indicating whether new value is present in case if we don't have it in deserialized form.
- 
hasOldValboolean hasOldVal Flag indicating whether old value is present in case if we don't have it in deserialized form.
- 
keyObject key Cache entry.
- 
lockIdObject lockId Lock ID.
- 
nearboolean near Flag indicating whether event happened onnearorpartitionedcache.
- 
newValObject newVal New value.
- 
oldValObject oldVal Old value.
- 
partint part Partition for the event.
- 
subjIdUUID subjId Subject ID.
- 
taskNameString taskName Task name if update was initiated within task execution.
- 
txLblString txLbl Transaction label.
- 
xidIgniteUuid xid Transaction Id.
 
- 
 
- 
Class org.apache.ignite.events.CacheObjectTransformedEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
originalbyte[] original Original cache object bytes.
- 
restoreboolean restore Restore operation.
- 
transformedbyte[] transformed Transformed cache object bytes.
 
- 
 
- 
Class org.apache.ignite.events.CacheQueryExecutedEvent extends EventAdapter implements Serializable- serialVersionUID:
- 3738753361235304496L
 - 
Serialized Fields- 
argsObject[] args Query arguments.
- 
cacheNameString cacheName Cache name.
- 
clauseString clause Clause.
- 
clsNameString clsName Class name.
- 
contQryFilterCacheEntryEventSerializableFilter<K,V> contQryFilter Continuous query filter.
- 
qryTypeString qryType Query type.
- 
scanQryFilterIgniteBiPredicate<K,V> scanQryFilter Scan query filter.
- 
subjIdUUID subjId Security subject ID.
- 
taskNameString taskName Task name.
 
- 
 
- 
Class org.apache.ignite.events.CacheQueryReadEvent extends EventAdapter implements Serializable- serialVersionUID:
- -1984731272984397445L
 - 
Serialized Fields- 
argsObject[] args Query arguments.
- 
cacheNameString cacheName Cache name.
- 
clauseString clause Clause.
- 
clsNameString clsName Class name.
- 
contQryFilterCacheEntryEventSerializableFilter<K,V> contQryFilter Continuous query filter.
- 
keyK key Key.
- 
oldValV oldVal Old value.
- 
qryTypeString qryType Query type.
- 
rowObject row Result row.
- 
scanQryFilterIgniteBiPredicate<K,V> scanQryFilter Scan query filter.
- 
subjIdUUID subjId Security subject ID.
- 
taskNameString taskName Task name.
- 
valV val Value.
 
- 
 
- 
Class org.apache.ignite.events.CacheRebalancingEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
cacheNameString cacheName Cache name.
- 
discoEvtTypeint discoEvtType Discovery event type.
- 
discoNodeClusterNode discoNode Discovery node.
- 
discoTslong discoTs Discovery event time.
- 
partint part Partition for the event.
 
- 
 
- 
Class org.apache.ignite.events.CheckpointEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
cpKeyString cpKey 
 
- 
 
- 
Class org.apache.ignite.events.ClusterActivationEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
baselineNodesCollection<BaselineNode> baselineNodes Deprecated.Baseline nodes.
 
- 
 
- 
Class org.apache.ignite.events.ClusterStateChangeEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
baselineNodesCollection<? extends BaselineNode> baselineNodes Baseline nodes of current baseline topology.
- 
prevStateClusterState prevState Previous cluster state.
- 
stateClusterState state Current cluster state.
 
- 
 
- 
Class org.apache.ignite.events.ClusterStateChangeStartedEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
prevStateClusterState prevState Previous cluster state.
- 
stateClusterState state New cluster state.
- 
subjIdUUID 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- 
aliasString alias 
 
- 
 
- 
Class org.apache.ignite.events.DiscoveryEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
evtNodeClusterNode evtNode 
- 
msgTemplateString msgTemplate Template to generateDiscoveryEvent.message()lazily. Will be joined withDiscoveryEvent.eventNode()converted to string.
- 
topSnapshotCollection<ClusterNode> topSnapshot Collection of nodes corresponding to topology version.
- 
topVerlong topVer Topology version.
 
- 
 
- 
Class org.apache.ignite.events.EventAdapter extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
idIgniteUuid id 
- 
locIdlong locId 
- 
msgString msg 
- 
nodeClusterNode node 
- 
tstamplong tstamp 
- 
typeint type 
 
- 
 
- 
Class org.apache.ignite.events.JobEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
jobIdIgniteUuid jobId 
- 
resPlcComputeJobResultPolicy resPlc 
- 
sesIdIgniteUuid sesId 
- 
taskClsNameString taskClsName 
- 
taskNameString taskName 
- 
taskNodeClusterNode taskNode 
- 
taskSubjIdUUID taskSubjId 
 
- 
 
- 
Class org.apache.ignite.events.NodeValidationFailedEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
evtNodeClusterNode evtNode The node that attempted to join cluster.
- 
resIgniteNodeValidationResult res Validation result.
 
- 
 
- 
Class org.apache.ignite.events.PageReplacementStartedEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
dataRegionNameString dataRegionName 
 
- 
 
- 
Class org.apache.ignite.events.SnapshotEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
snpNameString 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- 
internalboolean internal 
- 
sesIdIgniteUuid sesId 
- 
subjIdUUID subjId 
- 
taskClsNameString taskClsName 
- 
taskNameString taskName 
 
- 
 
- 
Class org.apache.ignite.events.TransactionStateChangedEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
txTransaction tx Tx.
 
- 
 
- 
Class org.apache.ignite.events.WalSegmentArchivedEvent extends EventAdapter implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
absWalSegmentIdxlong absWalSegmentIdx Absolute WAL segment file index.
- 
archiveFileFile 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- 
readExternalpublic void readExternal(ObjectInput in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeExternalpublic 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- 
readExternalpublic void readExternal(ObjectInput in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeExternalpublic void writeExternal(ObjectOutput out) throws IOException - Throws:
- IOException
 
 
- 
 
- 
Class org.apache.ignite.lang.IgniteUuid extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialization Methods- 
readExternalpublic void readExternal(ObjectInput in) throws IOException - Throws:
- IOException
 
- 
writeExternalpublic 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- 
keepGoingboolean keepGoing 
- 
nodeIdUUID nodeId 
 
- 
 
 
- 
- 
Package org.apache.ignite.platform.dotnet- 
Class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialization Methods- 
readExternalpublic void readExternal(ObjectInput in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeExternalpublic 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- 
nativeFactoryObject nativeFactory 
 
- 
 
 
- 
- 
Package org.apache.ignite.plugin- 
Class org.apache.ignite.plugin.PluginNotFoundException extends IgniteException implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
nameString 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- 
readObjectprivate void readObject(ObjectInputStream in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeObjectprivate void writeObject(ObjectOutputStream out) throws IOException - Throws:
- IOException
 
 
- 
- 
Serialized Fields- 
cachePermissionsMap<String,Collection<SecurityPermission>> cachePermissions Cache permissions.
- 
dfltAllowAllboolean dfltAllowAll Default allow all.
- 
systemPermissionsCollection<SecurityPermission> systemPermissions System permissions.
- 
taskPermissionsMap<String,Collection<SecurityPermission>> taskPermissions Task permissions.
 
- 
 
- 
Class org.apache.ignite.plugin.security.SecurityCredentials extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialization Methods- 
readExternalpublic void readExternal(ObjectInput in) throws IOException, ClassNotFoundException - Throws:
- IOException
- ClassNotFoundException
 
- 
writeExternalpublic 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- 
affKeyObject affKey Affinity key.
- 
cacheNameString cacheName Cache name.
- 
interceptorsServiceCallInterceptor[] interceptors Interceptor.
- 
isStatisticsEnabledboolean isStatisticsEnabled Enables or disables service statistics.
- 
maxPerNodeCntint maxPerNodeCnt Max per-node count.
- 
nameString name Service name.
- 
nodeFilterIgnitePredicate<ClusterNode> nodeFilter Node filter.
- 
svcService svc Service instance.
- 
totalCntint totalCnt Total count.
 
- 
 
- 
Class org.apache.ignite.services.ServiceDeploymentException extends IgniteException implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
cfgsCollection<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- 
deltaint 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- 
connectCntlong connectCnt 
- 
nodeIdUUID nodeId 
- 
rcvCntlong rcvCnt 
 
- 
 
- 
Class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2 extends HandshakeMessage implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
connIdxint 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- 
nodeIdBytesbyte[] nodeIdBytes 
 
- 
 
- 
Class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage extends Object implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
rcvCntlong 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.
- 
kKey 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- 
includedScopesSet<Scope> includedScopes Set ofScopethat 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.
- 
samplingRatedouble 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- 
cipherSuitesString[] cipherSuites Enabled cipher suites.
- 
protoString proto SSL protocol.
- 
protocolsString[] protocols Enabled protocols.
- 
sslCtxAtomicReference<SSLContext> sslCtx Cached instance of anSSLContext.
 
- 
 
- 
Class org.apache.ignite.ssl.SslContextFactory extends AbstractSslContextFactory implements Serializable- serialVersionUID:
- 0L
 - 
Serialized Fields- 
keyAlgorithmString keyAlgorithm Key manager algorithm.
- 
keyStoreFilePathString keyStoreFilePath Path to key store file
- 
keyStorePwdchar[] keyStorePwd Key store password
- 
keyStoreTypeString keyStoreType Key store type.
- 
trustMgrsTrustManager[] trustMgrs Trust managers.
- 
trustStoreFilePathString trustStoreFilePath Path to trust store.
- 
trustStorePwdchar[] trustStorePwd Trust store password
- 
trustStoreTypeString trustStoreType Trust store type.
 
- 
 
 
- 
- 
Package org.apache.ignite.startup- 
Class org.apache.ignite.startup.BasicWarmupClosure extends Object implements Serializable- serialVersionUID:
- 9175346848249957458L
 - 
Serialized Fields- 
discoveryPortint discoveryPort Warmup discovery port.
- 
gridCntint gridCnt Grid count.
- 
iterCntint iterCnt Per thread iteration count.
- 
keyRangeint keyRange Key range.
- 
threadCntint threadCnt Warmup thread count.
- 
warmupMethodsString[] 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- 
appNameString appName Application name
- 
bannerSpecString bannerSpec Banner icon url spec
- 
closeActAction closeAct Close action.
- 
closeBtnJButton closeBtn Close button.
- 
copyrightString copyright Copyright.
- 
gbcGridBagConstraints gbc Grid bag constraints.
- 
releaseLocalDate release Release date.
- 
verString 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- 
igniteInstanceNamesCollection<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
 
 
-