Serialized Form
-
Package org.apache.ignite
-
Exception org.apache.ignite.IgniteAuthenticationException
class IgniteAuthenticationException extends org.apache.ignite.IgniteCheckedException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.IgniteCacheRestartingException
class IgniteCacheRestartingException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.IgniteCheckedException
class IgniteCheckedException extends Exception implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.IgniteClientDisconnectedException
class IgniteClientDisconnectedException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
reconnectFut
org.apache.ignite.lang.IgniteFuture<?> reconnectFut
-
-
Exception org.apache.ignite.IgniteDataStreamerTimeoutException
class IgniteDataStreamerTimeoutException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.IgniteDeploymentException
class IgniteDeploymentException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.IgniteException
class IgniteException extends RuntimeException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.IgniteIllegalStateException
class IgniteIllegalStateException extends IllegalStateException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.IgniteInterruptedException
class IgniteInterruptedException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.IgniteJdbcThinDataSource
class IgniteJdbcThinDataSource extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
loginTimeout
int loginTimeout
-
props
org.apache.ignite.internal.jdbc.thin.ConnectionPropertiesImpl props
-
-
Class org.apache.ignite.IgniteSpringBean
class IgniteSpringBean extends Object implements Externalizable- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
- Throws:
IOExceptionClassNotFoundException
-
writeExternal
- Throws:
IOException
-
-
-
Package org.apache.ignite.client
-
Exception org.apache.ignite.client.ClientAuthenticationException
class ClientAuthenticationException extends org.apache.ignite.client.ClientException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.client.ClientAuthorizationException
class ClientAuthorizationException extends org.apache.ignite.client.ClientException implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientCacheConfiguration
class ClientCacheConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
atomicityMode
org.apache.ignite.cache.CacheAtomicityMode atomicityMode
-
backups
int backups
-
cacheMode
org.apache.ignite.cache.CacheMode cacheMode
-
cpOnRead
boolean cpOnRead
-
dataRegionName
String dataRegionName
-
dfltLockTimeout
long dfltLockTimeout
-
eagerTtl
boolean eagerTtl
-
expiryPlc
javax.cache.expiry.ExpiryPolicy expiryPlc
-
grpName
String grpName
-
keyCfg
org.apache.ignite.cache.CacheKeyConfiguration[] keyCfg
-
maxConcurrentAsyncOperations
int maxConcurrentAsyncOperations
-
maxQryIteratorsCnt
int maxQryIteratorsCnt
-
name
String name
-
onheapCacheEnabled
boolean onheapCacheEnabled
-
partLossPlc
org.apache.ignite.cache.PartitionLossPolicy partLossPlc
-
qryDetailMetricsSize
int qryDetailMetricsSize
-
qryEntities
org.apache.ignite.cache.QueryEntity[] qryEntities
-
qryParallelism
int qryParallelism
-
readFromBackup
boolean readFromBackup
-
rebalanceBatchesPrefetchCnt
long rebalanceBatchesPrefetchCnt
-
rebalanceBatchSize
int rebalanceBatchSize
-
rebalanceDelay
long rebalanceDelay
-
rebalanceMode
org.apache.ignite.cache.CacheRebalanceMode rebalanceMode
-
rebalanceOrder
int rebalanceOrder
-
rebalanceThrottle
long rebalanceThrottle
-
rebalanceTimeout
long rebalanceTimeout
-
sqlEscapeAll
boolean sqlEscapeAll
-
sqlIdxMaxInlineSize
int sqlIdxMaxInlineSize
-
sqlSchema
String sqlSchema
-
statisticsEnabled
boolean statisticsEnabled
-
writeSynchronizationMode
org.apache.ignite.cache.CacheWriteSynchronizationMode writeSynchronizationMode
-
-
Exception org.apache.ignite.client.ClientConnectionException
class ClientConnectionException extends org.apache.ignite.client.ClientException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.client.ClientException
class ClientException extends RuntimeException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.client.ClientFeatureNotSupportedByServerException
class ClientFeatureNotSupportedByServerException extends org.apache.ignite.client.ClientException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.client.ClientReconnectedException
class ClientReconnectedException extends org.apache.ignite.client.ClientException implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientRetryAllPolicy
class ClientRetryAllPolicy extends Object implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientRetryNonePolicy
class ClientRetryNonePolicy extends Object implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.client.ClientRetryReadPolicy
class ClientRetryReadPolicy extends Object implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.client.IgniteClientConnectionException
class IgniteClientConnectionException extends IgniteException implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
endpoint
@Nullable String endpoint
The endpoint that caused the exception.
-
-
Exception org.apache.ignite.client.IgniteClientFeatureNotSupportedByServerException
class IgniteClientFeatureNotSupportedByServerException extends IgniteException implements Serializable- serialVersionUID:
- 0L
-
-
Package org.apache.ignite.compute
-
Exception org.apache.ignite.compute.ComputeException
class ComputeException extends IgniteException implements Serializable -
Exception org.apache.ignite.compute.ComputeExecutionRejectedException
class ComputeExecutionRejectedException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.compute.ComputeJobFailoverException
class ComputeJobFailoverException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.compute.ComputeTaskAdapter
class ComputeTaskAdapter extends Object implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.compute.ComputeTaskCancelledException
class ComputeTaskCancelledException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.compute.ComputeTaskSplitAdapter
class ComputeTaskSplitAdapter extends org.apache.ignite.compute.ComputeTaskAdapter<T extends Object,R extends Object> implements Serializable - serialVersionUID:
- 0L
-
Serialized Fields
-
balancer
org.apache.ignite.compute.ComputeLoadBalancer balancer
-
-
Exception org.apache.ignite.compute.ComputeTaskTimeoutException
class ComputeTaskTimeoutException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.compute.ComputeUserUndeclaredException
class ComputeUserUndeclaredException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.compute.NodeNotFoundException
class NodeNotFoundException extends ComputeException implements Serializable
-
-
Package org.apache.ignite.configuration
-
Class org.apache.ignite.configuration.BinaryConfiguration
class BinaryConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
compactFooter
boolean compactFooter
-
idMapper
org.apache.ignite.binary.BinaryIdMapper idMapper
-
nameMapper
org.apache.ignite.binary.BinaryNameMapper nameMapper
-
serializer
org.apache.ignite.binary.BinarySerializer serializer
-
typeCfgs
Collection<org.apache.ignite.binary.BinaryTypeConfiguration> typeCfgs
-
-
Class org.apache.ignite.configuration.CacheConfiguration
class CacheConfiguration extends javax.cache.configuration.MutableConfiguration<K extends Object,V extends Object> implements Serializable - serialVersionUID:
- 0L
-
Serialization Methods
-
writeReplace
-
-
Serialized Fields
-
aff
org.apache.ignite.cache.affinity.AffinityFunction aff
-
affMapper
org.apache.ignite.cache.affinity.AffinityKeyMapper affMapper
-
atomicityMode
org.apache.ignite.cache.CacheAtomicityMode atomicityMode
-
backups
int backups
-
cacheMode
org.apache.ignite.cache.CacheMode cacheMode
-
cpOnRead
boolean cpOnRead
-
dfltLockTimeout
long dfltLockTimeout
Deprecated. -
diskPageCompression
org.apache.ignite.configuration.DiskPageCompression diskPageCompression
-
diskPageCompressionLevel
Integer diskPageCompressionLevel
-
eagerTtl
boolean eagerTtl
-
encryptionEnabled
boolean encryptionEnabled
-
evictFilter
org.apache.ignite.cache.eviction.EvictionFilter<?,
?> evictFilter -
evictPlc
org.apache.ignite.cache.eviction.EvictionPolicy evictPlc
Deprecated. -
evictPlcFactory
javax.cache.configuration.Factory evictPlcFactory
-
evtsDisabled
boolean evtsDisabled
-
grpName
String grpName
-
interceptor
org.apache.ignite.cache.CacheInterceptor<K extends Object,
V extends Object> interceptor -
invalidate
boolean invalidate
-
keyCfg
org.apache.ignite.cache.CacheKeyConfiguration[] keyCfg
-
loadPrevVal
boolean loadPrevVal
-
longQryWarnTimeout
long longQryWarnTimeout
Deprecated. -
maxConcurrentAsyncOps
int maxConcurrentAsyncOps
-
maxQryIterCnt
int maxQryIterCnt
-
memPlcName
String memPlcName
-
name
String name
-
nearCfg
org.apache.ignite.configuration.NearCacheConfiguration<K extends Object,
V extends Object> nearCfg -
nodeFilter
org.apache.ignite.lang.IgnitePredicate<org.apache.ignite.cluster.ClusterNode> nodeFilter
-
onheapCache
boolean onheapCache
-
partLossPlc
org.apache.ignite.cache.PartitionLossPolicy partLossPlc
-
platformCfg
org.apache.ignite.configuration.PlatformCacheConfiguration platformCfg
-
pluginCfgs
org.apache.ignite.plugin.CachePluginConfiguration[] pluginCfgs
-
qryDetailMetricsSz
int qryDetailMetricsSz
-
qryEntities
Collection<org.apache.ignite.cache.QueryEntity> qryEntities
-
qryParallelism
int qryParallelism
-
readFromBackup
boolean readFromBackup
-
rebalanceBatchesPrefetchCnt
long rebalanceBatchesPrefetchCnt
Deprecated. -
rebalanceBatchSize
int rebalanceBatchSize
Deprecated. -
rebalanceDelay
long rebalanceDelay
-
rebalanceMode
org.apache.ignite.cache.CacheRebalanceMode rebalanceMode
-
rebalanceOrder
int rebalanceOrder
-
rebalancePoolSize
int rebalancePoolSize
Deprecated. -
rebalanceThrottle
long rebalanceThrottle
Deprecated. -
rebalanceTimeout
long rebalanceTimeout
Deprecated. -
sqlEscapeAll
boolean sqlEscapeAll
-
sqlFuncCls
Class<?>[] sqlFuncCls
-
sqlIdxMaxInlineSize
int sqlIdxMaxInlineSize
-
sqlOnheapCache
boolean sqlOnheapCache
-
sqlOnheapCacheMaxSize
int sqlOnheapCacheMaxSize
-
sqlSchema
String sqlSchema
-
storeConcurrentLoadAllThreshold
int storeConcurrentLoadAllThreshold
-
storeFactory
javax.cache.configuration.Factory storeFactory
-
storeKeepBinary
Boolean storeKeepBinary
-
storeSesLsnrs
javax.cache.configuration.Factory<? extends org.apache.ignite.cache.store.CacheStoreSessionListener>[] storeSesLsnrs
-
tmLookupClsName
String tmLookupClsName
-
topValidator
org.apache.ignite.configuration.TopologyValidator topValidator
-
writeBehindBatchSize
int writeBehindBatchSize
-
writeBehindCoalescing
boolean writeBehindCoalescing
-
writeBehindEnabled
boolean writeBehindEnabled
-
writeBehindFlushFreq
long writeBehindFlushFreq
-
writeBehindFlushSize
int writeBehindFlushSize
-
writeBehindFlushThreadCnt
int writeBehindFlushThreadCnt
-
writeSync
org.apache.ignite.cache.CacheWriteSynchronizationMode writeSync
-
-
Class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
class IgniteAllNodesPredicate extends Object implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.configuration.ClientConfiguration
class ClientConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
addrs
String[] addrs
-
asyncContinuationExecutor
Executor asyncContinuationExecutor
-
autoBinaryConfigurationEnabled
boolean autoBinaryConfigurationEnabled
-
binaryCfg
org.apache.ignite.configuration.BinaryConfiguration binaryCfg
-
clusterDiscoveryEnabled
boolean clusterDiscoveryEnabled
-
eventListeners
EventListener[] eventListeners
-
heartbeatEnabled
boolean heartbeatEnabled
-
heartbeatInterval
long heartbeatInterval
-
logger
org.apache.ignite.IgniteLogger logger
-
partitionAwarenessEnabled
boolean partitionAwarenessEnabled
-
partitionAwarenessMapperFactory
org.apache.ignite.client.ClientPartitionAwarenessMapperFactory partitionAwarenessMapperFactory
-
rcvBufSize
int rcvBufSize
-
reconnectThrottlingPeriod
long reconnectThrottlingPeriod
-
reconnectThrottlingRetries
int reconnectThrottlingRetries
-
retryLimit
int retryLimit
-
retryPolicy
org.apache.ignite.client.ClientRetryPolicy retryPolicy
-
sndBufSize
int sndBufSize
-
sslClientCertKeyStorePath
String sslClientCertKeyStorePath
-
sslClientCertKeyStorePwd
String sslClientCertKeyStorePwd
-
sslClientCertKeyStoreType
String sslClientCertKeyStoreType
-
sslCtxFactory
javax.cache.configuration.Factory<SSLContext> sslCtxFactory
-
sslKeyAlgorithm
String sslKeyAlgorithm
-
sslMode
org.apache.ignite.client.SslMode sslMode
-
sslProto
org.apache.ignite.client.SslProtocol sslProto
-
sslTrustAll
boolean sslTrustAll
-
sslTrustCertKeyStorePath
String sslTrustCertKeyStorePath
-
sslTrustCertKeyStorePwd
String sslTrustCertKeyStorePwd
-
sslTrustCertKeyStoreType
String sslTrustCertKeyStoreType
-
tcpNoDelay
boolean tcpNoDelay
-
timeout
int timeout
-
txCfg
org.apache.ignite.configuration.ClientTransactionConfiguration txCfg
-
userAttrs
Map<String,
String> userAttrs -
userName
String userName
-
userPwd
String userPwd
-
-
Class org.apache.ignite.configuration.ClientTransactionConfiguration
class ClientTransactionConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
dfltConcurrency
org.apache.ignite.transactions.TransactionConcurrency dfltConcurrency
-
dfltIsolation
org.apache.ignite.transactions.TransactionIsolation dfltIsolation
-
dfltTxTimeout
long dfltTxTimeout
-
-
Class org.apache.ignite.configuration.CollectionConfiguration
class CollectionConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
atomicityMode
org.apache.ignite.cache.CacheAtomicityMode atomicityMode
-
backups
int backups
-
cacheMode
org.apache.ignite.cache.CacheMode cacheMode
-
collocated
boolean collocated
-
grpName
String grpName
-
nodeFilter
org.apache.ignite.lang.IgnitePredicate<org.apache.ignite.cluster.ClusterNode> nodeFilter
-
offHeapMaxMem
long offHeapMaxMem
Deprecated.
-
-
Exception org.apache.ignite.configuration.ConfigurationChangeException
class ConfigurationChangeException extends RuntimeException implements Serializable -
Exception org.apache.ignite.configuration.ConfigurationListenOnlyException
class ConfigurationListenOnlyException extends RuntimeException implements Serializable -
Exception org.apache.ignite.configuration.ConfigurationNodeAlreadyExistException
class ConfigurationNodeAlreadyExistException extends ConfigurationNodeModificationException implements Serializable- serialVersionUID:
- 4545533114006120896L
-
Exception org.apache.ignite.configuration.ConfigurationNodeDoesNotExistException
class ConfigurationNodeDoesNotExistException extends ConfigurationNodeModificationException implements Serializable- serialVersionUID:
- 4545533114006120896L
-
Exception org.apache.ignite.configuration.ConfigurationNodeModificationException
class ConfigurationNodeModificationException extends IllegalArgumentException implements Serializable- serialVersionUID:
- 4149783684472013922L
-
Exception org.apache.ignite.configuration.ConfigurationNodeRemovedException
class ConfigurationNodeRemovedException extends ConfigurationNodeModificationException implements Serializable- serialVersionUID:
- 2493615156271124701L
-
Exception org.apache.ignite.configuration.ConfigurationReadOnlyException
class ConfigurationReadOnlyException extends RuntimeException implements Serializable -
Exception org.apache.ignite.configuration.ConfigurationWrongPolymorphicTypeIdException
class ConfigurationWrongPolymorphicTypeIdException extends RuntimeException implements Serializable -
Class org.apache.ignite.configuration.DataRegionConfiguration
class DataRegionConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
cdcEnabled
boolean cdcEnabled
-
checkpointPageBufSize
long checkpointPageBufSize
-
emptyPagesPoolSize
int emptyPagesPoolSize
-
evictionThreshold
double evictionThreshold
-
initSize
long initSize
-
lazyMemoryAllocation
boolean lazyMemoryAllocation
-
maxSize
long maxSize
-
memoryAllocator
org.apache.ignite.mem.MemoryAllocator memoryAllocator
-
metricsEnabled
boolean metricsEnabled
-
metricsRateTimeInterval
long metricsRateTimeInterval
-
metricsSubIntervalCount
int metricsSubIntervalCount
-
name
String name
-
pageEvictionMode
org.apache.ignite.configuration.DataPageEvictionMode pageEvictionMode
-
pageReplacementMode
org.apache.ignite.configuration.PageReplacementMode pageReplacementMode
-
persistenceEnabled
boolean persistenceEnabled
-
swapPath
String swapPath
-
warmUpCfg
org.apache.ignite.configuration.WarmUpConfiguration warmUpCfg
-
-
Class org.apache.ignite.configuration.DataStorageConfiguration
class DataStorageConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
alwaysWriteFullPages
boolean alwaysWriteFullPages
-
cdcWalDirMaxSize
long cdcWalDirMaxSize
-
cdcWalPath
String cdcWalPath
-
checkpointFreq
long checkpointFreq
-
checkpointReadLockTimeout
Long checkpointReadLockTimeout
-
checkpointThreads
int checkpointThreads
-
checkpointWriteOrder
org.apache.ignite.configuration.CheckpointWriteOrder checkpointWriteOrder
-
concLvl
int concLvl
-
dataRegions
org.apache.ignite.configuration.DataRegionConfiguration[] dataRegions
-
defragmentationThreadPoolSize
int defragmentationThreadPoolSize
-
dfltDataRegConf
org.apache.ignite.configuration.DataRegionConfiguration dfltDataRegConf
-
dfltWarmUpCfg
org.apache.ignite.configuration.WarmUpConfiguration dfltWarmUpCfg
-
encCfg
org.apache.ignite.configuration.EncryptionConfiguration encCfg
-
fileIOFactory
org.apache.ignite.internal.processors.cache.persistence.file.FileIOFactory fileIOFactory
-
lockWaitTime
long lockWaitTime
-
maxWalArchiveSize
long maxWalArchiveSize
-
memoryAllocator
org.apache.ignite.mem.MemoryAllocator memoryAllocator
-
metricsEnabled
boolean metricsEnabled
Deprecated. -
metricsRateTimeInterval
long metricsRateTimeInterval
-
metricsSubIntervalCnt
int metricsSubIntervalCnt
-
minWalArchiveSize
long minWalArchiveSize
-
pageSize
int pageSize
-
storagePath
String storagePath
-
sysDataRegConf
org.apache.ignite.configuration.SystemDataRegionConfiguration sysDataRegConf
-
walArchivePath
String walArchivePath
-
walAutoArchiveAfterInactivity
long walAutoArchiveAfterInactivity
-
walBuffSize
int walBuffSize
-
walCompactionEnabled
boolean walCompactionEnabled
-
walCompactionLevel
int walCompactionLevel
-
walFlushFreq
long walFlushFreq
-
walForceArchiveTimeout
long walForceArchiveTimeout
-
walFsyncDelay
long walFsyncDelay
-
walHistSize
int walHistSize
-
walMode
org.apache.ignite.configuration.WALMode walMode
-
walPageCompression
org.apache.ignite.configuration.DiskPageCompression walPageCompression
-
walPageCompressionLevel
Integer walPageCompressionLevel
-
walPath
String walPath
-
walRecordIterBuffSize
int walRecordIterBuffSize
-
walSegments
int walSegments
-
walSegmentSize
int walSegmentSize
-
walTlbSize
int walTlbSize
-
writeThrottlingEnabled
boolean writeThrottlingEnabled
-
-
Class org.apache.ignite.configuration.EncryptionConfiguration
class EncryptionConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
reencryptionBatchSize
int reencryptionBatchSize
-
reencryptionRateLimit
double reencryptionRateLimit
-
-
Class org.apache.ignite.configuration.IgniteReflectionFactory
class IgniteReflectionFactory extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
cls
Class<? extends T extends Object> cls
-
props
Map<String,
Serializable> props -
singleton
boolean singleton
-
-
Class org.apache.ignite.configuration.LoadAllWarmUpConfiguration
class LoadAllWarmUpConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.configuration.MemoryConfiguration
class MemoryConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
concLvl
int concLvl
Deprecated. -
dfltMemPlcName
String dfltMemPlcName
Deprecated. -
dfltMemPlcSize
long dfltMemPlcSize
Deprecated. -
memPlcs
org.apache.ignite.configuration.MemoryPolicyConfiguration[] memPlcs
Deprecated. -
pageSize
int pageSize
Deprecated. -
sysCacheInitSize
long sysCacheInitSize
Deprecated. -
sysCacheMaxSize
long sysCacheMaxSize
Deprecated.
-
-
Class org.apache.ignite.configuration.MemoryPolicyConfiguration
class MemoryPolicyConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
emptyPagesPoolSize
int emptyPagesPoolSize
Deprecated. -
evictionThreshold
double evictionThreshold
Deprecated. -
initialSize
long initialSize
Deprecated. -
maxSize
long maxSize
Deprecated. -
metricsEnabled
boolean metricsEnabled
Deprecated. -
name
String name
Deprecated. -
pageEvictionMode
org.apache.ignite.configuration.DataPageEvictionMode pageEvictionMode
Deprecated. -
rateTimeInterval
long rateTimeInterval
Deprecated. -
subIntervals
int subIntervals
Deprecated. -
swapFilePath
String swapFilePath
Deprecated.
-
-
Class org.apache.ignite.configuration.NearCacheConfiguration
class NearCacheConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.configuration.NoOpWarmUpConfiguration
class NoOpWarmUpConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.configuration.PersistentStoreConfiguration
class PersistentStoreConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
alwaysWriteFullPages
boolean alwaysWriteFullPages
Deprecated. -
checkpointingFreq
long checkpointingFreq
Deprecated. -
checkpointingPageBufSize
long checkpointingPageBufSize
Deprecated. -
checkpointingThreads
int checkpointingThreads
Deprecated. -
checkpointWriteOrder
org.apache.ignite.configuration.CheckpointWriteOrder checkpointWriteOrder
Deprecated. -
fileIOFactory
org.apache.ignite.internal.processors.cache.persistence.file.FileIOFactory fileIOFactory
Deprecated. -
lockWaitTime
long lockWaitTime
Deprecated. -
metricsEnabled
boolean metricsEnabled
Deprecated. -
persistenceStorePath
String persistenceStorePath
Deprecated. -
rateTimeInterval
long rateTimeInterval
Deprecated. -
subIntervals
int subIntervals
Deprecated. -
walArchivePath
String walArchivePath
Deprecated. -
walAutoArchiveAfterInactivity
long walAutoArchiveAfterInactivity
Deprecated. -
walBuffSize
int walBuffSize
Deprecated. -
walFlushFreq
long walFlushFreq
Deprecated. -
walFsyncDelay
long walFsyncDelay
Deprecated. -
walHistSize
int walHistSize
Deprecated. -
walMode
org.apache.ignite.configuration.WALMode walMode
Deprecated. -
walRecordIterBuffSize
int walRecordIterBuffSize
Deprecated. -
walSegments
int walSegments
Deprecated. -
walSegmentSize
int walSegmentSize
Deprecated. -
walStorePath
String walStorePath
Deprecated. -
writeThrottlingEnabled
boolean writeThrottlingEnabled
Deprecated.
-
-
Class org.apache.ignite.configuration.PlatformCacheConfiguration
class PlatformCacheConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.configuration.SystemDataRegionConfiguration
class SystemDataRegionConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
initSize
long initSize
-
maxSize
long maxSize
-
-
Class org.apache.ignite.configuration.TransactionConfiguration
class TransactionConfiguration extends Object implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
dfltConcurrency
org.apache.ignite.transactions.TransactionConcurrency dfltConcurrency
-
dfltIsolation
org.apache.ignite.transactions.TransactionIsolation dfltIsolation
-
dfltTxTimeout
long dfltTxTimeout
-
pessimisticTxLogLinger
int pessimisticTxLogLinger
Deprecated. -
pessimisticTxLogSize
int pessimisticTxLogSize
Deprecated. -
tmLookupClsName
String tmLookupClsName
-
txAwareQueriesEnabled
boolean txAwareQueriesEnabled
-
txManagerFactory
javax.cache.configuration.Factory txManagerFactory
-
txSerEnabled
boolean txSerEnabled
-
txTimeoutOnPartitionMapExchange
long txTimeoutOnPartitionMapExchange
-
useJtaSync
boolean useJtaSync
-
-
-
Package org.apache.ignite.configuration.validation
-
Exception org.apache.ignite.configuration.validation.ConfigurationValidationException
class ConfigurationValidationException extends RuntimeException implements Serializable-
Serialized Fields
-
issues
Collection<ValidationIssue> issues
Collection of configuration validation issues.
-
-
-
-
Package org.apache.ignite.deployment.version
-
Exception org.apache.ignite.deployment.version.VersionParseException
class VersionParseException extends RuntimeException implements Serializable-
Serialized Fields
-
rawVersion
String rawVersion
-
-
-
-
Package org.apache.ignite.example.compute
-
Class org.apache.ignite.example.compute.ComputeWithCustomResultMarshallerExample.WordInfoResult
class WordInfoResult extends Object implements Serializable- serialVersionUID:
- -6036698690089270464L
-
Serialized Fields
-
length
int length
Length. -
word
String word
Word.
-
-
-
Package org.apache.ignite.lang
-
Exception org.apache.ignite.lang.ClusterInitFailureException
class ClusterInitFailureException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.ClusterNotInitializedException
class ClusterNotInitializedException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.ColumnAlreadyExistsException
class ColumnAlreadyExistsException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.ColumnNotFoundException
class ColumnNotFoundException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.CursorClosedException
class CursorClosedException extends IgniteException implements Serializable -
Class org.apache.ignite.lang.IgniteBiTuple
class IgniteBiTuple extends Object implements Externalizable- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
- Throws:
IOExceptionClassNotFoundException
-
writeExternal
- Throws:
IOException
-
-
Exception org.apache.ignite.lang.IgniteCheckedException
class IgniteCheckedException extends Exception implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
code
int code
Error code that contains information about the error group and code, where the code is unique within the group. The code structure is as follows: +------------+--------------+ | 16 bits | 16 bits | +------------+--------------+ | Group Code | Error Code | +------------+--------------+ -
errorPrefix
String errorPrefix
Prefix for error message. -
groupName
String groupName
Name of the error group. -
traceId
UUID traceId
Unique identifier of the exception that helps locating the error message in a log file.
-
-
Exception org.apache.ignite.lang.IgniteException
class IgniteException extends RuntimeException implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
code
int code
Error code that contains information about the error group and code, where the code is unique within the group. The code structure is as follows: +------------+--------------+ | 16 bits | 16 bits | +------------+--------------+ | Group Code | Error Code | +------------+--------------+ -
errorPrefix
String errorPrefix
Prefix for error message. -
groupName
String groupName
Name of the error group. -
traceId
UUID traceId
Unique identifier of the exception that helps locate the error message in a log file.Not
finalbecause it gets accessed via reflection when creating a copy.
-
-
Exception org.apache.ignite.lang.IgniteFutureCancelledException
class IgniteFutureCancelledException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.ignite.lang.IgniteFutureTimeoutException
class IgniteFutureTimeoutException extends org.apache.ignite.IgniteException implements Serializable- serialVersionUID:
- 0L
-
Class org.apache.ignite.lang.IgniteProductVersion
class IgniteProductVersion extends Object implements Externalizable- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
- Throws:
IOExceptionClassNotFoundException
-
writeExternal
- Throws:
IOException
-
-
Class org.apache.ignite.lang.IgniteUuid
class IgniteUuid extends Object implements Externalizable- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Exception org.apache.ignite.lang.IndexAlreadyExistsException
class IndexAlreadyExistsException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.IndexNotFoundException
class IndexNotFoundException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.MarshallerException
class MarshallerException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.NodeNotStartedException
class NodeNotStartedException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.NodeStartException
class NodeStartException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.SchemaNotFoundException
class SchemaNotFoundException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.TableAlreadyExistsException
class TableAlreadyExistsException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.TableNotFoundException
class TableNotFoundException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.UnexpectedNullValueException
class UnexpectedNullValueException extends IgniteException implements Serializable -
Exception org.apache.ignite.lang.UnsupportedPartitionTypeException
class UnsupportedPartitionTypeException extends IgniteException implements Serializable- serialVersionUID:
- 6875586826126580903L
-
-
Package org.apache.ignite.marshalling
-
Exception org.apache.ignite.marshalling.MarshallingException
class MarshallingException extends IgniteException implements Serializable- serialVersionUID:
- -4170221560474770629L
-
Exception org.apache.ignite.marshalling.UnmarshallingException
class UnmarshallingException extends IgniteException implements Serializable- serialVersionUID:
- -8131613381875542450L
-
Exception org.apache.ignite.marshalling.UnsupportedObjectTypeMarshallingException
class UnsupportedObjectTypeMarshallingException extends IgniteException implements Serializable- serialVersionUID:
- -8131613381875542450L
-
-
Package org.apache.ignite.migrationtools.cli.persistence.calls
-
Exception org.apache.ignite.migrationtools.cli.persistence.calls.MigrateCacheCall.InvalidProgressFileException
class InvalidProgressFileException extends Exception implements Serializable
-
-
Package org.apache.ignite.migrationtools.config.loader
-
Class org.apache.ignite.migrationtools.config.loader.CustomBeanFactory
class CustomBeanFactory extends org.springframework.beans.factory.support.DefaultListableBeanFactory implements Serializable-
Serialized Fields
-
propertyTracker
org.apache.commons.collections4.MultiValuedMap<Object,
org.apache.commons.lang3.tuple.Pair<PropertyDescriptor, org.springframework.beans.factory.config.BeanDefinition>> propertyTracker
-
-
-
-
Package org.apache.ignite.migrationtools.persistence
-
Class org.apache.ignite.migrationtools.persistence.MigrationKernal
class MigrationKernal extends org.apache.ignite.internal.IgniteKernal implements Externalizable-
Serialization Methods
-
readExternal
- Throws:
IOExceptionClassNotFoundException
-
writeExternal
- Throws:
IOException
-
-
-
Class org.apache.ignite.migrationtools.persistence.MigrationKernalContext
class MigrationKernalContext extends org.apache.ignite.internal.GridKernalContextImpl implements Externalizable-
Serialization Methods
-
readExternal
- Throws:
IOExceptionClassNotFoundException
-
writeExternal
- Throws:
IOException
-
-
-
-
Package org.apache.ignite.migrationtools.persistence.exceptions
-
Exception org.apache.ignite.migrationtools.persistence.exceptions.MigrateCacheException
class MigrateCacheException extends Exception implements Serializable
-
-
Package org.apache.ignite.migrationtools.persistence.mappers
-
Exception org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor.RecordMappingException
class RecordMappingException extends Exception implements Serializable -
Exception org.apache.ignite.migrationtools.persistence.mappers.RecordAndTableSchemaMismatchException
class RecordAndTableSchemaMismatchException extends Exception implements Serializable-
Serialized Fields
-
additionalColumnsInRecord
Collection<String> additionalColumnsInRecord
-
missingColumnsInRecord
Collection<String> missingColumnsInRecord
-
-
-
-
Package org.apache.ignite.migrationtools.sql
-
Exception org.apache.ignite.migrationtools.sql.FieldNameConflictException
class FieldNameConflictException extends RuntimeException implements Serializable
-
-
Package org.apache.ignite.network
-
Class org.apache.ignite.network.NodeMetadata
class NodeMetadata extends Object implements Serializable- serialVersionUID:
- 3216463261002854096L
-
Serialized Fields
-
httpPort
int httpPort
-
httpsPort
int httpsPort
-
restHost
String restHost
-
-
-
Package org.apache.ignite.security.exception
-
Exception org.apache.ignite.security.exception.InvalidCredentialsException
class InvalidCredentialsException extends IgniteException implements Serializable -
Exception org.apache.ignite.security.exception.UnsupportedAuthenticationTypeException
class UnsupportedAuthenticationTypeException extends IgniteException implements Serializable
-
-
Package org.apache.ignite.sql
-
Exception org.apache.ignite.sql.NoRowSetExpectedException
class NoRowSetExpectedException extends SqlException implements Serializable -
Exception org.apache.ignite.sql.SqlBatchException
class SqlBatchException extends SqlException implements Serializable-
Serialized Fields
-
updCntrs
long[] updCntrs
-
-
-
Exception org.apache.ignite.sql.SqlException
class SqlException extends IgniteException implements Serializable
-
-
Package org.apache.ignite.table
-
Exception org.apache.ignite.table.DataStreamerException
class DataStreamerException extends IgniteException implements Serializable- serialVersionUID:
- -7516813059448101081L
-
Serialized Fields
-
failedItems
Set<?> failedItems
-
-
Class org.apache.ignite.table.QualifiedName
class QualifiedName extends Object implements Serializable- serialVersionUID:
- -7016402388810709149L
-
-
Package org.apache.ignite.table.criteria
-
Exception org.apache.ignite.table.criteria.CriteriaException
class CriteriaException extends IgniteException implements Serializable
-
-
Package org.apache.ignite.table.partition
-
Package org.apache.ignite.tx
-
Exception org.apache.ignite.tx.IncompatibleSchemaException
class IncompatibleSchemaException extends TransactionException implements Serializable -
Exception org.apache.ignite.tx.MismatchingTransactionOutcomeException
class MismatchingTransactionOutcomeException extends TransactionException implements Serializable -
Exception org.apache.ignite.tx.TransactionException
class TransactionException extends IgniteException implements Serializable
-