Index

A B C D E F G H I J K L M N O P Q R S T U V W Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

ABORT - Enum constant in enum class org.apache.ignite.migrationtools.cli.persistence.params.MigrationMode
Abort the migration.
AbstractConfiguration - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation marks a class as an abstract configuration schema.
AbstractSchemaColumnsProcessor - Class in org.apache.ignite.migrationtools.persistence.mappers
Provides a mapping layer between Ignite 2 Tuples (created from Binary Objects) and a Ignite 3 table schema.
AbstractSchemaColumnsProcessor(ClientSchema, Map<String, String>, TypeConverterFactory, boolean) - Constructor for class org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor
Constructor.
AbstractSchemaColumnsProcessor.RecordMappingException - Exception in org.apache.ignite.migrationtools.persistence.mappers
RecordMappingException.
AbstractSchemaColumnsProcessor.WrapperClass - Class in org.apache.ignite.migrationtools.persistence.mappers
WrapperClass.
accept(CriteriaVisitor<C>, C) - Method in class org.apache.ignite.table.criteria.Column
Accept the visitor with the given context.
accept(CriteriaVisitor<C>, C) - Method in interface org.apache.ignite.table.criteria.Criteria
Accept the visitor with the given context.
accept(CriteriaVisitor<C>, C) - Method in class org.apache.ignite.table.criteria.Expression
Accept the visitor with the given context.
accept(CriteriaVisitor<C>, C) - Method in class org.apache.ignite.table.criteria.Parameter
Accept the visitor with the given context.
acceptsURL(String) - Method in class org.apache.ignite.jdbc.IgniteJdbcDriver
Account - Class in org.apache.ignite.example.streaming
 
Account() - Constructor for class org.apache.ignite.example.streaming.Account
 
Account(int) - Constructor for class org.apache.ignite.example.streaming.Account
 
Account(int, String, long, boolean) - Constructor for class org.apache.ignite.example.streaming.Account
 
ACQUIRE_LOCK_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Failed to acquire a lock on a key due to a conflict.
ACQUIRE_LOCK_TIMEOUT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Failed to acquire a lock on a key within a timeout.
add(Object...) - Method in class org.apache.ignite.sql.BatchedArguments
Appends arguments to a batch.
addCancelAction(CancellationToken, Runnable, CompletableFuture<?>) - Static method in class org.apache.ignite.lang.CancelHandleHelper
Attaches a cancellable operation to the given token.
addCancelAction(CancellationToken, CompletableFuture<?>) - Static method in class org.apache.ignite.lang.CancelHandleHelper
Attaches a future to the given token.
addIssue(ValidationIssue) - Method in interface org.apache.ignite.configuration.validation.ValidationContext
Signifies that there's something wrong.
additionalColumnsInRecord() - Method in exception org.apache.ignite.migrationtools.persistence.mappers.RecordAndTableSchemaMismatchException
 
address() - Method in interface org.apache.ignite.network.ClusterNode
Returns the network address of the node.
ADDRESS_UNRESOLVED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Network
Could not resolve address.
addresses() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the addresses of Ignite server nodes within a cluster.
addresses() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.MigrateCacheParams
 
addresses(String...) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the addresses of Ignite server nodes within a cluster.
addressesFinder() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the address finder.
addressFinder(IgniteClientAddressFinder) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the address finder.
affectedRows() - Method in interface org.apache.ignite.sql.async.AsyncResultSet
Returns the number of rows affected by the DML statement execution (such as "INSERT", "UPDATE", etc.), or 0 if the statement returns nothing (such as "ALTER TABLE", etc), or -1 if inapplicable.
affectedRows() - Method in interface org.apache.ignite.sql.ResultSet
Returns the number of rows affected by the DML statement execution (such as "INSERT", "UPDATE", etc.), or 0 if the statement returns nothing (such as "ALTER TABLE", etc.), or -1 if not applicable.
AI3_CLUSTER - Static variable in class org.apache.ignite.migrationtools.tests.bases.MigrationTestBase
 
AllNodesBroadcastJobTarget - Class in org.apache.ignite.compute
All nodes broadcast execution target.
and(Expression...) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates the and of the expressions.
AND - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 
any() - Method in interface org.apache.ignite.configuration.NamedConfigurationTree
Returns a placeholder that allows you to add listeners for changing configuration value of any element of the named list and any of its nested configurations.
anyNode(Collection<ClusterNode>) - Static method in interface org.apache.ignite.compute.JobTarget
Creates a job target for any node from the provided collection.
anyNode(Set<ClusterNode>) - Static method in interface org.apache.ignite.compute.JobTarget
Creates a job target for any node from the provided collection.
anyNode(ClusterNode...) - Static method in interface org.apache.ignite.compute.JobTarget
Creates a job target for any node from the provided collection.
AnyNodeJobTarget - Class in org.apache.ignite.compute
Any node execution target.
api() - Method in interface org.apache.ignite.IgniteServer
Returns the Ignite API.
applicableException() - Method in class org.apache.ignite.migrationtools.cli.exceptions.DataStreamerExceptionHandler
 
applicableException() - Method in class org.apache.ignite.migrationtools.cli.exceptions.DefaultMigrateCacheExceptionHandler
 
applicableException() - Method in class org.apache.ignite.migrationtools.cli.exceptions.IgniteClientConnectionExceptionHandler
 
applicableException() - Method in class org.apache.ignite.migrationtools.cli.exceptions.RecordAndTableSchemaMismatchExceptionHandler
 
arg() - Method in class org.apache.ignite.compute.task.MapReduceJob
Arguments of the job.
args(T) - Method in class org.apache.ignite.compute.task.MapReduceJob.ComputeJobRunnerBuilder
Sets arguments of the job.
argumentMarshaller() - Method in class org.apache.ignite.compute.JobDescriptor
 
argumentMarshaller() - Method in interface org.apache.ignite.table.DataStreamerReceiver
Marshaller for the input argument.
argumentMarshaller() - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor
Argument marshaller.
argumentMarshaller() - Method in class org.apache.ignite.table.ReceiverDescriptor
Deprecated.
 
argumentMarshaller(Marshaller<A, byte[]>) - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor.Builder
Sets the argument marshaller.
argumentMarshaller(Marshaller<A, byte[]>) - Method in class org.apache.ignite.table.ReceiverDescriptor.Builder
Deprecated.
 
argumentMarshaller(Marshaller<T, byte[]>) - Method in class org.apache.ignite.compute.JobDescriptor.Builder
Sets the argument marshaller.
ARRAY - Enum constant in enum class org.apache.ignite.migrationtools.types.InspectedFieldType
 
asc() - Method in class org.apache.ignite.catalog.ColumnSorted
Assigns ascending sort order.
ASC - Enum constant in enum class org.apache.ignite.catalog.SortOrder
 
ASC_NULLS_FIRST - Enum constant in enum class org.apache.ignite.catalog.SortOrder
 
ASC_NULLS_LAST - Enum constant in enum class org.apache.ignite.catalog.SortOrder
 
assertResultSet(ResultSet, int[]) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.PrimitiveTest
 
assertResultSet(ResultSet, Integer) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MySimpleMapCacheTest
 
assertResultSet(ResultSet, List) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.ListTest
 
assertResultSet(ResultSet, Organization) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyOrganizationsCacheTest
 
assertResultSet(ResultSet, Person) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.PersonCacheTest
 
assertResultSet(ResultSet, V) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
 
assertValueFromIgnite2(V, V) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
 
assertValueFromIgnite3(Organization, Organization) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyOrganizationsCacheTest
 
assertValueFromIgnite3(V, V) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
 
asyncContinuationExecutor() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the async continuation executor.
asyncContinuationExecutor(Executor) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the async continuation executor.
asyncContinuationExecutor(Executor) - Method in class org.apache.ignite.IgniteServer.Builder
Specifies executor in which futures obtained via API will be completed..
AsyncCursor<T> - Interface in org.apache.ignite.lang
Provides methods to iterate over operation results and release underlying resources in an asynchronous way.
AsyncResultSet<T> - Interface in org.apache.ignite.sql.async
Provides methods for processing query results in an asynchronous way.
Authentication() - Constructor for class org.apache.ignite.lang.ErrorGroups.Authentication
 
AUTHENTICATION_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Authentication
Authentication error group.
AuthenticationProperties() - Constructor for class org.apache.ignite.IgniteClientProperties.AuthenticationProperties
 
AuthenticationType - Enum Class in org.apache.ignite.security
Authentication types.
authenticator() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the authenticator.
authenticator() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.IgniteClientAuthenticatorParams
Retrieves the authenticator instance for these parameters.
authenticator(IgniteClientAuthenticator) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the authenticator.
autoFlushInterval() - Method in class org.apache.ignite.table.DataStreamerOptions
Gets the auto flush interval, in milliseconds (the period of time after which the streamer will flush the per-node buffer even if it is not full).
autoFlushInterval(int) - Method in class org.apache.ignite.table.DataStreamerOptions.Builder
Sets the auto flush interval, in milliseconds (the period of time after which the streamer will flush the per-node buffer even if it is not full).
automap() - Method in class org.apache.ignite.table.mapper.MapperBuilder
Maps all matching fields to columns by name.
AutoSerializableArg - Class in org.apache.ignite.example.serialization
 
AutoSerializableArg() - Constructor for class org.apache.ignite.example.serialization.AutoSerializableArg
 
AutoSerializableResult - Class in org.apache.ignite.example.serialization
 
AutoSerializableResult() - Constructor for class org.apache.ignite.example.serialization.AutoSerializableResult
 

B

backgroundReconnectInterval() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the background reconnect interval, in milliseconds.
backgroundReconnectInterval(long) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the background reconnect interval, in milliseconds.
BASIC - Enum constant in enum class org.apache.ignite.security.AuthenticationType
 
BASIC_PROVIDER_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Authentication
Basic authentication provider is not found.
BasicAuthenticator - Class in org.apache.ignite.client
Basic authenticator with username and password.
BasicAuthenticator.Builder - Class in org.apache.ignite.client
Builder.
BasicAuthProperties() - Constructor for class org.apache.ignite.IgniteClientProperties.BasicAuthProperties
 
BasicProcessor<S,T> - Class in org.apache.ignite.migrationtools.persistence.utils.pubsub
Base class for building Flow.Processor which provides a transparent layer between a single publisher and a single subscriber.
BasicProcessor() - Constructor for class org.apache.ignite.migrationtools.persistence.utils.pubsub.BasicProcessor
 
batchAsync(long, JdbcBatchExecuteRequest) - Method in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
BatchedArguments - Class in org.apache.ignite.sql
Arguments for batch query execution.
batchPrepStatementAsync(long, JdbcBatchPreparedStmntRequest) - Method in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
BeanWrapperSpy - Class in org.apache.ignite.migrationtools.config.loader
A custom implementation that tracks which properties where explicitly set in the bean.
BeanWrapperSpy(MultiValuedMap<Object, Pair<PropertyDescriptor, BeanDefinition>>, BeanWrapper, RootBeanDefinition) - Constructor for class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
Constructor.
beforeAll(ExtensionContext) - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterWithSamples
 
begin() - Method in interface org.apache.ignite.tx.IgniteTransactions
Begins a transaction.
begin(TransactionOptions) - Method in interface org.apache.ignite.tx.IgniteTransactions
Begins a transaction.
beginAsync() - Method in interface org.apache.ignite.tx.IgniteTransactions
Begins a transaction.
beginAsync(TransactionOptions) - Method in interface org.apache.ignite.tx.IgniteTransactions
Begins an asynchronous transaction.
BIGINT - Static variable in class org.apache.ignite.catalog.ColumnType
BIGINT SQL column type.
BIND_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Network
Address or port bind error.
BOOLEAN - Enum constant in enum class org.apache.ignite.sql.ColumnType
Boolean.
BOOLEAN - Static variable in class org.apache.ignite.catalog.ColumnType
BOOLEAN SQL column type.
booleanValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
booleanValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets boolean column value.
booleanValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
booleanValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a boolean column value.
BroadcastExecution<R> - Interface in org.apache.ignite.compute
Broadcast job control object, provides information about the job executions and results.
BroadcastJobTarget - Interface in org.apache.ignite.compute
Broadcast job execution target.
build() - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Builds the table definition.
build() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Builds the zone definition.
build() - Method in class org.apache.ignite.client.BasicAuthenticator.Builder
Builds a new authenticator.
build() - Method in class org.apache.ignite.client.IgniteClient.Builder
Builds the client.
build() - Method in class org.apache.ignite.client.SslConfiguration.Builder
Build SslConfiguration instance.
build() - Method in class org.apache.ignite.compute.JobDescriptor.Builder
Builds the job descriptor.
build() - Method in class org.apache.ignite.compute.JobExecutionOptions.Builder
Builds the job execution options.
build() - Method in class org.apache.ignite.compute.task.MapReduceJob.ComputeJobRunnerBuilder
Constructs a compute job description object.
build() - Method in class org.apache.ignite.compute.TaskDescriptor.Builder
Builds the task descriptor.
build() - Method in class org.apache.ignite.IgniteServer.Builder
Builds an IgniteServer.
build() - Method in class org.apache.ignite.InitParametersBuilder
build() - Method in interface org.apache.ignite.sql.Statement.StatementBuilder
Creates an SQL statement abject.
build() - Method in class org.apache.ignite.table.criteria.CriteriaQueryOptions.Builder
Builds the options.
build() - Method in class org.apache.ignite.table.DataStreamerOptions.Builder
Builds the options.
build() - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor.Builder
Builds the receiver descriptor.
build() - Method in class org.apache.ignite.table.mapper.MapperBuilder
Builds a mapper.
build() - Method in class org.apache.ignite.table.ReceiverDescriptor.Builder
Deprecated.
Builds the receiver descriptor.
build() - Method in class org.apache.ignite.table.ReceiverExecutionOptions.Builder
Builds the receiver execution options.
buildAsync() - Method in class org.apache.ignite.client.IgniteClient.Builder
Builds the client.
buildClient() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
 
builder() - Static method in class org.apache.ignite.client.BasicAuthenticator
Creates a new builder.
builder() - Static method in interface org.apache.ignite.client.IgniteClient
Gets a new client builder.
builder() - Static method in interface org.apache.ignite.client.SslConfiguration
SSL configuration builder.
builder() - Static method in class org.apache.ignite.compute.JobExecutionOptions
Creates the builder for job execution options.
builder() - Static method in class org.apache.ignite.compute.task.MapReduceJob
Returns new builder.
builder() - Static method in class org.apache.ignite.InitParameters
 
builder() - Static method in class org.apache.ignite.table.criteria.CriteriaQueryOptions
Creates a new builder.
builder() - Static method in class org.apache.ignite.table.DataStreamerOptions
Creates a new builder.
builder() - Static method in class org.apache.ignite.table.ReceiverExecutionOptions
Creates the builder for job execution options.
builder(Class<? extends ComputeJob<T, R>>) - Static method in class org.apache.ignite.compute.JobDescriptor
Create a new builder.
builder(Class<? extends MapReduceTask<I, M, T, R>>) - Static method in class org.apache.ignite.compute.TaskDescriptor
Create a new builder.
builder(Class<? extends DataStreamerReceiver<?, A, ?>>) - Static method in class org.apache.ignite.table.ReceiverDescriptor
Deprecated.
Create a new builder.
builder(Class<? extends DataStreamerReceiver<T, A, R>>) - Static method in class org.apache.ignite.table.DataStreamerReceiverDescriptor
Create a new builder.
builder(Class<O>) - Static method in interface org.apache.ignite.table.mapper.Mapper
Creates a mapper builder for objects of a given class.
builder(String) - Static method in class org.apache.ignite.catalog.definitions.TableDefinition
Creates a builder for the table with the specified name.
builder(String) - Static method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Creates a builder for the zone with the specified name.
builder(String) - Static method in class org.apache.ignite.compute.JobDescriptor
Create a new builder.
builder(String) - Static method in class org.apache.ignite.compute.TaskDescriptor
Create a new builder.
builder(String) - Static method in class org.apache.ignite.table.DataStreamerReceiverDescriptor
Create a new builder.
builder(String) - Static method in class org.apache.ignite.table.ReceiverDescriptor
Deprecated.
Create a new builder.
builder(String, Path, Path) - Static method in interface org.apache.ignite.IgniteServer
Returns a builder for an embedded Ignite node.
builder(DataStreamerReceiver<T, A, R>) - Static method in class org.apache.ignite.table.DataStreamerReceiverDescriptor
Create a new builder from a receiver instance.
builder(QualifiedName) - Static method in class org.apache.ignite.catalog.definitions.TableDefinition
Creates a builder for the table with the specified qualified name.
Builder() - Constructor for class org.apache.ignite.client.BasicAuthenticator.Builder
 
Builder() - Constructor for class org.apache.ignite.client.IgniteClient.Builder
 
Builder() - Constructor for class org.apache.ignite.client.SslConfiguration.Builder
 
Builder() - Constructor for class org.apache.ignite.compute.JobExecutionOptions.Builder
 
Builder() - Constructor for class org.apache.ignite.table.criteria.CriteriaQueryOptions.Builder
 
Builder() - Constructor for class org.apache.ignite.table.DataStreamerOptions.Builder
 
Builder() - Constructor for class org.apache.ignite.table.ReceiverExecutionOptions.Builder
 
BYTE_ARRAY - Enum constant in enum class org.apache.ignite.sql.ColumnType
Binary data.
ByteArrayMarshaller<T> - Interface in org.apache.ignite.marshalling
The ByteArrayMarshaller interface is designed to marshal and unmarshal objects to and from byte arrays.
bytesReceived() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets received bytes.
bytesSent() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets sent bytes.
bytesValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
bytesValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a byte[] column value.
bytesValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
bytesValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a byte[] column value.
byteValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
byteValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets byte column value.
byteValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
byteValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a byte column value.

C

cacheConfiguration() - Method in interface org.apache.ignite.migrationtools.tests.e2e.framework.core.ExampleBasedCacheTest
 
cacheConfiguration() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.ListTest
 
cacheConfiguration() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.PrimitiveTest
 
cacheConfiguration() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest.MyBinaryTestCache
 
cacheConfiguration() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MySimpleMapCacheTest
 
cacheConfiguration() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
 
CacheDataRowProcessor - Class in org.apache.ignite.migrationtools.persistence.mappers
Processes CacheDataRow into Java Object entries.
CacheDataRowProcessor(CacheObjectContext) - Constructor for class org.apache.ignite.migrationtools.persistence.mappers.CacheDataRowProcessor
 
cacheDescriptor(String) - Method in class org.apache.ignite.migrationtools.persistence.MigrationCacheProcessor
 
cacheDescriptors() - Method in class org.apache.ignite.migrationtools.persistence.MigrationCacheProcessor
 
cacheId() - Method in class org.apache.ignite.migrationtools.cli.persistence.calls.ListCachesCall.Output
 
cacheName() - Method in class org.apache.ignite.migrationtools.cli.persistence.calls.ListCachesCall.Output
 
cacheName() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.MigrateCacheParams
 
cacheName() - Method in exception org.apache.ignite.migrationtools.persistence.exceptions.MigrateCacheException
Gets the source cache name for the underlying migration request.
CalendarToInstantConverter - Class in org.apache.ignite.migrationtools.types.converters
Converts Java Calendars to Instants.
CalendarToInstantConverter() - Constructor for class org.apache.ignite.migrationtools.types.converters.CalendarToInstantConverter
 
CalendarToLocalDateTimeConverter - Class in org.apache.ignite.migrationtools.types.converters
Converts Java Calendars to LocalDateTime.
CalendarToLocalDateTimeConverter() - Constructor for class org.apache.ignite.migrationtools.types.converters.CalendarToLocalDateTimeConverter
 
call() - Method in class org.apache.ignite.migrationtools.cli.configs.commands.ConfigurationConverterCmd
call() - Method in class org.apache.ignite.migrationtools.cli.persistence.commands.ListCachesCmd
 
call() - Method in class org.apache.ignite.migrationtools.cli.persistence.commands.MigrateCacheCmd
 
call() - Method in class org.apache.ignite.migrationtools.cli.sql.commands.SqlDdlGeneratorCmd
CamelCaseKeys - Annotation Interface in org.apache.ignite.configuration.validation
Signifies that a NamedConfigValue only has elements with keys in lower camel case, for example 'v', 'value', 'valueOne' and 'valueOneAndTwo'.
cancel() - Method in interface org.apache.ignite.lang.CancelHandle
Abruptly terminates an execution of an associated process.
cancel() - Method in class org.apache.ignite.migrationtools.persistence.utils.pubsub.StreamerPublisher
 
cancelAsync() - Method in interface org.apache.ignite.lang.CancelHandle
Abruptly terminates an execution of a associated process.
cancelAsync(long, long) - Method in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
cancelAsync(AsyncDataCursor.CancellationReason) - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcQueryCursor
CANCELED - Enum constant in enum class org.apache.ignite.compute.JobStatus
The job was successfully cancelled.
CANCELED - Enum constant in enum class org.apache.ignite.compute.TaskStatus
The task was successfully cancelled.
CancelHandle - Interface in org.apache.ignite.lang
A handle which may be used to request the cancellation of execution.
CancelHandleHelper - Class in org.apache.ignite.lang
Utility class to provide direct access to internals of CancelHandleImpl.
cancelHandlesCount() - Method in class org.apache.ignite.client.handler.ClientInboundMessageHandler
 
CANCELING - Enum constant in enum class org.apache.ignite.compute.JobStatus
The job has received the cancel command, but it is still running.
CANCELING - Enum constant in enum class org.apache.ignite.compute.TaskStatus
The task has received the cancel command, but it is still running.
CancellationToken - Interface in org.apache.ignite.lang
Cancellation token is an object that is issued by CancelHandle and can be used by an operation or a resource to observe a signal to terminate it.
CANCELLING_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Compute job cancel failed error.
canonicalName(String, String) - Static method in class org.apache.ignite.lang.util.IgniteNameUtils
Creates a fully qualified name in canonical form, that is, enclosing each part of the identifier chain in double quotes.
canValidate(Class<? extends Annotation>, Class<?>, boolean) - Method in interface org.apache.ignite.configuration.validation.Validator
Checks whether this validator can validate a schema field with given annotation and given class.
caseSensitive() - Element in annotation interface org.apache.ignite.configuration.validation.OneOf
Returns true if list is case-sensitive.
catalog() - Method in interface org.apache.ignite.Ignite
Returns IgniteCatalog which can be used to create and execute SQL DDL queries from annotated classes or from fluent-style builders.
Catalog() - Constructor for class org.apache.ignite.lang.ErrorGroups.Catalog
 
CATALOG_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Catalog
Catalog error group.
CatalogExtensions - Class in org.apache.ignite3.internal.catalog.sql
Utility methods based on the Ignite 3 Catalog package.
change(Consumer<CHANGET>) - Method in interface org.apache.ignite.configuration.ConfigurationTree
Changes this configuration node value.
CHANGE_JOB_PRIORITY_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Cannot change job priority.
changePriorityAsync(int) - Method in interface org.apache.ignite.compute.JobExecution
Changes job priority.
changePriorityAsync(int) - Method in interface org.apache.ignite.compute.task.TaskExecution
Changes task priority.
changeRoot(RootKey<?, ? super C, C>) - Method in interface org.apache.ignite.configuration.SuperRootChange
Returns a root change for the root key.
CHANNEL_CONNECT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
Connect channel.
channelInactive(ChannelHandlerContext) - Method in class org.apache.ignite.client.handler.ClientInboundMessageHandler
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.ignite.client.handler.ClientInboundMessageHandler
channelRegistered(ChannelHandlerContext) - Method in class org.apache.ignite.client.handler.ClientInboundMessageHandler
 
ciphers() - Method in interface org.apache.ignite.client.SslConfiguration
List of ciphers that will be used to setup the SSL connection.
ciphers() - Method in class org.apache.ignite.SslConfigurationProperties
 
ciphers(Iterable<String>) - Method in class org.apache.ignite.client.SslConfiguration.Builder
Ciphers setter.
CLASS_INITIALIZATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Job class initialization error.
CLASS_LOADER_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Class loader error.
CLASS_PATH_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Classpath error.
classloader(Path[]) - Method in class org.apache.ignite.migrationtools.cli.mixins.ClassloaderOption
Parses the command line argument and create the classloader field.
ClassloaderOption - Class in org.apache.ignite.migrationtools.cli.mixins
Option that allows the user to add 3rd party libraries to the command custom classloader.
ClassloaderOption() - Constructor for class org.apache.ignite.migrationtools.cli.mixins.ClassloaderOption
 
ClassnameUtils - Class in org.apache.ignite.migrationtools.utils
Small utilities for handling class names.
Client() - Constructor for class org.apache.ignite.lang.ErrorGroups.Client
 
CLIENT_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
Client error group.
CLIENT_SSL_CONFIGURATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
Client SSL configuration error.
clientBuilder() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
 
clientClassLoader() - Method in class org.apache.ignite.migrationtools.cli.configs.calls.ConfigurationConverterCall.Input
 
clientClassLoader() - Method in class org.apache.ignite.migrationtools.cli.mixins.ClassloaderOption
 
ClientClusterGetNodesRequest - Class in org.apache.ignite.client.handler.requests.cluster
Cluster nodes request.
ClientClusterGetNodesRequest() - Constructor for class org.apache.ignite.client.handler.requests.cluster.ClientClusterGetNodesRequest
 
clientCode() - Method in class org.apache.ignite.client.handler.ClientContext
Gets the client code.
ClientComputeCancelRequest - Class in org.apache.ignite.client.handler.requests.compute
Cancel compute job request.
ClientComputeCancelRequest() - Constructor for class org.apache.ignite.client.handler.requests.compute.ClientComputeCancelRequest
 
ClientComputeChangePriorityRequest - Class in org.apache.ignite.client.handler.requests.compute
Change compute job priority.
ClientComputeChangePriorityRequest() - Constructor for class org.apache.ignite.client.handler.requests.compute.ClientComputeChangePriorityRequest
 
ClientComputeExecuteColocatedRequest - Class in org.apache.ignite.client.handler.requests.compute
Compute execute colocated request.
ClientComputeExecuteColocatedRequest() - Constructor for class org.apache.ignite.client.handler.requests.compute.ClientComputeExecuteColocatedRequest
 
ClientComputeExecuteMapReduceRequest - Class in org.apache.ignite.client.handler.requests.compute
Compute MapReduce request.
ClientComputeExecuteMapReduceRequest() - Constructor for class org.apache.ignite.client.handler.requests.compute.ClientComputeExecuteMapReduceRequest
 
ClientComputeExecutePartitionedRequest - Class in org.apache.ignite.client.handler.requests.compute
Compute execute partitioned request.
ClientComputeExecutePartitionedRequest() - Constructor for class org.apache.ignite.client.handler.requests.compute.ClientComputeExecutePartitionedRequest
 
ClientComputeExecuteRequest - Class in org.apache.ignite.client.handler.requests.compute
Compute execute request.
ClientComputeExecuteRequest() - Constructor for class org.apache.ignite.client.handler.requests.compute.ClientComputeExecuteRequest
 
ClientComputeGetStateRequest - Class in org.apache.ignite.client.handler.requests.compute
Compute get state request.
ClientComputeGetStateRequest() - Constructor for class org.apache.ignite.client.handler.requests.compute.ClientComputeGetStateRequest
 
clientConnector - Variable in class org.apache.ignite.client.handler.configuration.ClientConnectorExtensionConfigurationSchema
 
ClientConnectorConfigurationSchema - Class in org.apache.ignite.client.handler.configuration
Configuration schema for thin client connector.
ClientConnectorConfigurationSchema() - Constructor for class org.apache.ignite.client.handler.configuration.ClientConnectorConfigurationSchema
 
ClientConnectorConverter - Class in org.apache.ignite.migrationtools.config.converters
ClientConnectorConverter.
ClientConnectorConverter() - Constructor for class org.apache.ignite.migrationtools.config.converters.ClientConnectorConverter
 
ClientConnectorExtensionConfigurationSchema - Class in org.apache.ignite.client.handler.configuration
Extension for thin client connector configuration schema.
ClientConnectorExtensionConfigurationSchema() - Constructor for class org.apache.ignite.client.handler.configuration.ClientConnectorExtensionConfigurationSchema
 
ClientContext - Class in org.apache.ignite.client.handler
Client connection context.
ClientHandlerConfigurationModule - Class in org.apache.ignite.client.handler.configuration
ConfigurationModule for node-local configuration provided by client-handler.
ClientHandlerConfigurationModule() - Constructor for class org.apache.ignite.client.handler.configuration.ClientHandlerConfigurationModule
 
ClientHandlerMetricSource - Class in org.apache.ignite.client.handler
Server-side client handler metrics.
ClientHandlerMetricSource() - Constructor for class org.apache.ignite.client.handler.ClientHandlerMetricSource
Constructor.
ClientHandlerMetricSource.Holder - Class in org.apache.ignite.client.handler
Holder.
ClientHandlerModule - Class in org.apache.ignite.client.handler
Client handler module maintains TCP endpoint for thin client connections.
ClientHandlerModule(QueryProcessor, IgniteTablesInternal, TxManager, IgniteComputeInternal, ClusterService, NettyBootstrapFactory, Supplier<ClusterInfo>, MetricManager, ClientHandlerMetricSource, AuthenticationManager, ClockService, SchemaSyncService, CatalogService, PlacementDriver, ClientConnectorConfiguration, LowWatermark, NodeProperties, Executor) - Constructor for class org.apache.ignite.client.handler.ClientHandlerModule
Constructor.
ClientInboundMessageHandler - Class in org.apache.ignite.client.handler
Handles messages from thin clients.
ClientInboundMessageHandler(IgniteTablesInternal, TxManager, QueryProcessor, ClientConnectorView, IgniteComputeInternal, ClusterService, Supplier<ClusterInfo>, ClientHandlerMetricSource, AuthenticationManager, ClockService, SchemaSyncService, CatalogService, long, ClientPrimaryReplicaTracker, Executor, BitSet, Map<HandshakeExtension, Object>, Function<String, CompletableFuture<PlatformComputeConnection>>, HandshakeEventLoopSwitcher) - Constructor for class org.apache.ignite.client.handler.ClientInboundMessageHandler
Constructor.
ClientJdbcCancelRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc cancel request handler.
ClientJdbcCancelRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcCancelRequest
 
ClientJdbcCloseRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc close request handler.
ClientJdbcCloseRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcCloseRequest
 
ClientJdbcColumnMetadataRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc column metadata request handler.
ClientJdbcColumnMetadataRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcColumnMetadataRequest
 
ClientJdbcConnectRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc request handler.
ClientJdbcConnectRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcConnectRequest
 
ClientJdbcExecuteBatchRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc request handler.
ClientJdbcExecuteBatchRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcExecuteBatchRequest
 
ClientJdbcExecuteRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc request handler.
ClientJdbcExecuteRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcExecuteRequest
 
ClientJdbcFetchRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc request handler.
ClientJdbcFetchRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcFetchRequest
 
ClientJdbcFinishTxRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc explicit transaction complete request handler.
ClientJdbcFinishTxRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcFinishTxRequest
 
ClientJdbcHasMoreRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc more results request.
ClientJdbcHasMoreRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcHasMoreRequest
 
ClientJdbcPreparedStmntBatchRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc prepared statement sql execute request handler.
ClientJdbcPreparedStmntBatchRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcPreparedStmntBatchRequest
 
ClientJdbcPrimaryKeyMetadataRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc primary key metadata request handler.
ClientJdbcPrimaryKeyMetadataRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcPrimaryKeyMetadataRequest
 
ClientJdbcSchemasMetadataRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc schema metadata request handler.
ClientJdbcSchemasMetadataRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcSchemasMetadataRequest
 
ClientJdbcTableMetadataRequest - Class in org.apache.ignite.client.handler.requests.jdbc
Client jdbc table metadata request handler.
ClientJdbcTableMetadataRequest() - Constructor for class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcTableMetadataRequest
 
ClientOperationCancelRequest - Class in org.apache.ignite.client.handler.requests
Request to cancel execution of any operation previously initiated on the same connection.
ClientOperationCancelRequest() - Constructor for class org.apache.ignite.client.handler.requests.ClientOperationCancelRequest
 
ClientOperationType - Enum Class in org.apache.ignite.client
Client operation type.
ClientPrimaryReplicaTracker - Class in org.apache.ignite.client.handler
Primary partition replica tracker.
ClientPrimaryReplicaTracker(PlacementDriver, CatalogService, ClockService, SchemaSyncService, LowWatermark, NodeProperties) - Constructor for class org.apache.ignite.client.handler.ClientPrimaryReplicaTracker
Constructor.
ClientPrimaryReplicaTracker.PrimaryReplicasResult - Class in org.apache.ignite.client.handler
Primary replicas per partition with timestamp.
ClientResource - Class in org.apache.ignite.client.handler
Client resource holder.
ClientResource(Object, Runnable) - Constructor for class org.apache.ignite.client.handler.ClientResource
 
ClientResourceRegistry - Class in org.apache.ignite.client.handler
Per-connection resource registry.
ClientResourceRegistry() - Constructor for class org.apache.ignite.client.handler.ClientResourceRegistry
 
ClientSchemasGetRequest - Class in org.apache.ignite.client.handler.requests.table
Client schemas retrieval request.
ClientSchemasGetRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientSchemasGetRequest
 
ClientSqlCursorCloseRequest - Class in org.apache.ignite.client.handler.requests.sql
Client SQL cursor close request.
ClientSqlCursorCloseRequest() - Constructor for class org.apache.ignite.client.handler.requests.sql.ClientSqlCursorCloseRequest
 
ClientSqlCursorNextPageRequest - Class in org.apache.ignite.client.handler.requests.sql
Client SQL cursor next page request.
ClientSqlCursorNextPageRequest() - Constructor for class org.apache.ignite.client.handler.requests.sql.ClientSqlCursorNextPageRequest
 
ClientSqlExecuteBatchRequest - Class in org.apache.ignite.client.handler.requests.sql
Client SQL execute batch request.
ClientSqlExecuteBatchRequest() - Constructor for class org.apache.ignite.client.handler.requests.sql.ClientSqlExecuteBatchRequest
 
ClientSqlExecuteRequest - Class in org.apache.ignite.client.handler.requests.sql
Client SQL execute request.
ClientSqlExecuteRequest() - Constructor for class org.apache.ignite.client.handler.requests.sql.ClientSqlExecuteRequest
 
ClientSqlExecuteScriptRequest - Class in org.apache.ignite.client.handler.requests.sql
Client SQL execute script request.
ClientSqlExecuteScriptRequest() - Constructor for class org.apache.ignite.client.handler.requests.sql.ClientSqlExecuteScriptRequest
 
ClientSqlQueryMetadataRequest - Class in org.apache.ignite.client.handler.requests.sql
Client SQL request for the parameter metadata.
ClientSqlQueryMetadataRequest() - Constructor for class org.apache.ignite.client.handler.requests.sql.ClientSqlQueryMetadataRequest
 
ClientStreamerBatchSendRequest - Class in org.apache.ignite.client.handler.requests.table
Client streamer batch request.
ClientStreamerBatchSendRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientStreamerBatchSendRequest
 
ClientStreamerWithReceiverBatchSendRequest - Class in org.apache.ignite.client.handler.requests.table
Client streamer batch request.
ClientStreamerWithReceiverBatchSendRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientStreamerWithReceiverBatchSendRequest
 
ClientTableCommon - Class in org.apache.ignite.client.handler.requests.table
Common table functionality.
ClientTableCommon() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTableCommon
 
ClientTableGetQualifiedRequest - Class in org.apache.ignite.client.handler.requests.table
Client table retrieval request.
ClientTableGetQualifiedRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTableGetQualifiedRequest
 
ClientTableGetRequest - Class in org.apache.ignite.client.handler.requests.table
Client table retrieval request.
ClientTableGetRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTableGetRequest
 
ClientTablePartitionPrimaryReplicasGetRequest - Class in org.apache.ignite.client.handler.requests.table
Client partition primary replicas retrieval request.
ClientTablePartitionPrimaryReplicasGetRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTablePartitionPrimaryReplicasGetRequest
 
ClientTablePartitionPrimaryReplicasNodesGetRequest - Class in org.apache.ignite.client.handler.requests.table.partition
Client primary replicas with node info retrieval request.
ClientTablePartitionPrimaryReplicasNodesGetRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.partition.ClientTablePartitionPrimaryReplicasNodesGetRequest
 
ClientTablesGetQualifiedRequest - Class in org.apache.ignite.client.handler.requests.table
Client tables retrieval request.
ClientTablesGetQualifiedRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTablesGetQualifiedRequest
 
ClientTablesGetRequest - Class in org.apache.ignite.client.handler.requests.table
Client tables retrieval request.
ClientTablesGetRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTablesGetRequest
 
ClientTransactionBeginRequest - Class in org.apache.ignite.client.handler.requests.tx
Client transaction begin request.
ClientTransactionBeginRequest() - Constructor for class org.apache.ignite.client.handler.requests.tx.ClientTransactionBeginRequest
 
ClientTransactionCommitRequest - Class in org.apache.ignite.client.handler.requests.tx
Client transaction commit request.
ClientTransactionCommitRequest() - Constructor for class org.apache.ignite.client.handler.requests.tx.ClientTransactionCommitRequest
 
ClientTransactionRollbackRequest - Class in org.apache.ignite.client.handler.requests.tx
Client transaction rollback request.
ClientTransactionRollbackRequest() - Constructor for class org.apache.ignite.client.handler.requests.tx.ClientTransactionRollbackRequest
 
ClientTupleContainsAllKeysRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple contains all keys request.
ClientTupleContainsAllKeysRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleContainsAllKeysRequest
 
ClientTupleContainsKeyRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple contains key request.
ClientTupleContainsKeyRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleContainsKeyRequest
 
ClientTupleDeleteAllExactRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple delete all exact request.
ClientTupleDeleteAllExactRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleDeleteAllExactRequest
 
ClientTupleDeleteAllRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple delete all request.
ClientTupleDeleteAllRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleDeleteAllRequest
 
ClientTupleDeleteExactRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple delete exact request.
ClientTupleDeleteExactRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleDeleteExactRequest
 
ClientTupleDeleteRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple delete request.
ClientTupleDeleteRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleDeleteRequest
 
ClientTupleGetAllRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple get all request.
ClientTupleGetAllRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleGetAllRequest
 
ClientTupleGetAndDeleteRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple get and delete request.
ClientTupleGetAndDeleteRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleGetAndDeleteRequest
 
ClientTupleGetAndReplaceRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple get and replace request.
ClientTupleGetAndReplaceRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleGetAndReplaceRequest
 
ClientTupleGetAndUpsertRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple get and upsert request.
ClientTupleGetAndUpsertRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleGetAndUpsertRequest
 
ClientTupleGetRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple get request.
ClientTupleGetRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleGetRequest
 
ClientTupleInsertAllRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple insert all request.
ClientTupleInsertAllRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleInsertAllRequest
 
ClientTupleInsertRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple insert request.
ClientTupleInsertRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleInsertRequest
 
ClientTupleReplaceExactRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple replace request.
ClientTupleReplaceExactRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleReplaceExactRequest
 
ClientTupleReplaceRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple replace request.
ClientTupleReplaceRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleReplaceRequest
 
ClientTupleUpsertAllRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple upsert all request.
ClientTupleUpsertAllRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleUpsertAllRequest
 
ClientTupleUpsertRequest - Class in org.apache.ignite.client.handler.requests.table
Client tuple upsert request.
ClientTupleUpsertRequest() - Constructor for class org.apache.ignite.client.handler.requests.table.ClientTupleUpsertRequest
 
close() - Method in class org.apache.ignite.client.handler.ClientResourceRegistry
Closes the registry and releases all resources.
close() - Method in interface org.apache.ignite.client.IgniteClient
 
close() - Method in interface org.apache.ignite.lang.Cursor
Closes this cursor and releases any underlying resources.
close() - Method in class org.apache.ignite.migrationtools.persistence.utils.pubsub.StreamerPublisher
 
close() - Method in interface org.apache.ignite.sql.ResultSet
Invalidates result set and cleans up remote resources.
closeAsync() - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcQueryCursor
closeAsync() - Method in interface org.apache.ignite.lang.AsyncCursor
Closes this cursor and releases any underlying resources.
closeAsync() - Method in interface org.apache.ignite.sql.async.AsyncResultSet
Invalidates a query result, stops the query, and cleans up query resources.
closeAsync(JdbcQueryCloseRequest) - Method in class org.apache.ignite.client.handler.JdbcQueryCursorHandlerImpl
CLOSED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.GarbageCollector
Garbage collector closed error.
closeExceptionally(Throwable) - Method in class org.apache.ignite.migrationtools.persistence.utils.pubsub.StreamerPublisher
Close with error.
cluster() - Method in interface org.apache.ignite.Ignite
Returns the cluster object, which provides access to the cluster nodes and the local node.
CLUSTER_CFG_PATH - Static variable in class org.apache.ignite.migrationtools.tests.clusters.FullSampleCluster
 
CLUSTER_ID_MISMATCH_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
Cluster ID mismatch error.
CLUSTER_INIT_FAILED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Embedded
Cluster initialization failed.
CLUSTER_NOT_IDLE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
Error while returning partition states.
CLUSTER_NOT_INIT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Rest
Cluster has not yet been initialized or the node is in the process of stopping.
CLUSTER_NOT_INITIALIZED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Embedded
Cluster is not yet initialized.
clusterConfiguration() - Method in class org.apache.ignite.InitParameters
 
clusterConfiguration(String) - Method in class org.apache.ignite.InitParametersBuilder
Sets cluster configuration, that will be applied after initialization.
ClusterInfo - Class in org.apache.ignite.client.handler
Information about the cluster.
ClusterInfo(ClusterTag, List<UUID>) - Constructor for class org.apache.ignite.client.handler.ClusterInfo
Constructor.
ClusterInitFailureException - Exception in org.apache.ignite.lang
Thrown when cluster initialization failed.
ClusterInitFailureException(String) - Constructor for exception org.apache.ignite.lang.ClusterInitFailureException
 
ClusterInitFailureException(String, Throwable) - Constructor for exception org.apache.ignite.lang.ClusterInitFailureException
 
ClusterInitFailureException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.ClusterInitFailureException
 
clusterName() - Method in class org.apache.ignite.InitParameters
 
clusterName(String) - Method in class org.apache.ignite.InitParametersBuilder
Sets Human-readable name of the cluster.
ClusterNode - Interface in org.apache.ignite.network
Representation of a node in a cluster.
clusterNodeIds - Static variable in class org.apache.ignite.migrationtools.tests.clusters.FullSampleCluster
 
clusterNodes() - Method in interface org.apache.ignite.Ignite
Deprecated.
clusterNodesAsync() - Method in interface org.apache.ignite.Ignite
Deprecated.
ClusterNotInitializedException - Exception in org.apache.ignite.lang
Thrown when cluster is not yet initialized.
ClusterNotInitializedException() - Constructor for exception org.apache.ignite.lang.ClusterNotInitializedException
 
ClusterNotInitializedException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.ClusterNotInitializedException
 
cmgNodeNames() - Method in class org.apache.ignite.InitParameters
 
cmgNodeNames(String...) - Method in class org.apache.ignite.InitParametersBuilder
Sets names of nodes that will host the CMG.
cmgNodeNames(Collection<String>) - Method in class org.apache.ignite.InitParametersBuilder
Sets names of nodes that will host the CMG.
cmgNodes(Collection<IgniteServer>) - Method in class org.apache.ignite.InitParametersBuilder
Sets nodes that will host the CMG.
cmgNodes(IgniteServer...) - Method in class org.apache.ignite.InitParametersBuilder
Sets nodes that will host the CMG.
code() - Method in exception org.apache.ignite.lang.IgniteCheckedException
Returns a full error code that includes the error's group and code, which uniquely identifies the problem within the group.
code() - Method in exception org.apache.ignite.lang.IgniteException
Returns a full error code that includes the error's group and code, which uniquely identifies the problem within the group.
code() - Method in interface org.apache.ignite.lang.TraceableException
Returns a full error code that includes the error's group and code, which uniquely identifies the problem within the group.
CODE_DEPLOYMENT_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.CodeDeployment
Code deployment error group.
codeAsString() - Method in exception org.apache.ignite.lang.IgniteCheckedException
Returns a human-readable string that represents a full error code.
codeAsString() - Method in exception org.apache.ignite.lang.IgniteException
Returns a human-readable string that represents a full error code.
CodeDeployment() - Constructor for class org.apache.ignite.lang.ErrorGroups.CodeDeployment
 
CodeDeploymentExample - Class in org.apache.ignite.example.code.deployment
 
CodeDeploymentExample() - Constructor for class org.apache.ignite.example.code.deployment.CodeDeploymentExample
 
colocateBy() - Element in annotation interface org.apache.ignite.catalog.annotations.Table
References to colocation columns.
colocateBy(String...) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets colocation columns.
colocateBy(List<String>) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets colocation columns.
colocated(String, K, Mapper<K>) - Static method in interface org.apache.ignite.compute.JobTarget
Creates a colocated job target for a specific table and key with mapper.
colocated(String, Tuple) - Static method in interface org.apache.ignite.compute.JobTarget
Creates a colocated job target for a specific table and key.
colocated(QualifiedName, K, Mapper<K>) - Static method in interface org.apache.ignite.compute.JobTarget
Creates a colocated job target for a specific QualifiedName and key with mapper.
colocated(QualifiedName, Tuple) - Static method in interface org.apache.ignite.compute.JobTarget
Creates a colocated job target for a specific QualifiedName and key.
ColocatedJobTarget - Class in org.apache.ignite.compute
Colocated job execution target.
colocationColumns() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns a list of colocation column names.
column(String) - Static method in class org.apache.ignite.catalog.ColumnSorted
Creates a reference to the column with the given name and default sort order.
column(String, String) - Static method in class org.apache.ignite.catalog.definitions.ColumnDefinition
Creates a column definition with the provided type definition.
column(String, ColumnType<?>) - Static method in class org.apache.ignite.catalog.definitions.ColumnDefinition
Creates a column definition with the provided type.
column(String, SortOrder) - Static method in class org.apache.ignite.catalog.ColumnSorted
Creates a reference to the column with the given name and sort order.
Column - Class in org.apache.ignite.table.criteria
Represents a column reference for criteria query.
Column - Annotation Interface in org.apache.ignite.catalog.annotations
Describes a column of the table.
COLUMN_ALREADY_EXISTS_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Table
Deprecated.
COLUMN_NOT_FOUND_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Table
Column not found.
ColumnAlreadyExistsException - Exception in org.apache.ignite.lang
Deprecated.
No longer used. Use SqlException with ErrorGroups.Sql.STMT_VALIDATION_ERR error code.
ColumnAlreadyExistsException(String) - Constructor for exception org.apache.ignite.lang.ColumnAlreadyExistsException
Deprecated.
Creates a new exception with a given column name.
ColumnAlreadyExistsException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.ColumnAlreadyExistsException
Deprecated.
Creates a new exception with the given trace ID, error code, detailed message, and cause.
columnCount() - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
columnCount() - Method in interface org.apache.ignite.table.Tuple
Gets a number of columns in the tuple.
columnDefinition() - Element in annotation interface org.apache.ignite.catalog.annotations.Column
Full SQL definition of the column type without the name, mutually exclusive with other options.
ColumnDefinition - Class in org.apache.ignite.catalog.definitions
Definition of the column.
columnIndex(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
columnIndex(String) - Method in interface org.apache.ignite.table.Tuple
Gets an index of the column with the specified name.
ColumnMetadata - Interface in org.apache.ignite.sql
Interface that provides methods for accessing column metadata.
ColumnMetadata.ColumnOrigin - Interface in org.apache.ignite.sql
Represents a column origin.
columnName() - Method in class org.apache.ignite.catalog.ColumnSorted
Returns column name.
columnName() - Method in interface org.apache.ignite.sql.ColumnMetadata.ColumnOrigin
Return a column name.
columnName(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
columnName(int) - Method in interface org.apache.ignite.table.Tuple
Gets a name of the column with the specified index.
ColumnNotFoundException - Exception in org.apache.ignite.lang
Exception is thrown when the indicated column is not found.
ColumnNotFoundException(String) - Constructor for exception org.apache.ignite.lang.ColumnNotFoundException
Creates an exception with a given column name.
ColumnNotFoundException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.ColumnNotFoundException
Creates an exception with the given trace ID, error code, detailed message, and cause.
ColumnNotFoundException(QualifiedName, String) - Constructor for exception org.apache.ignite.lang.ColumnNotFoundException
Creates an exception with a given column name.
ColumnRef - Annotation Interface in org.apache.ignite.catalog.annotations
Specifies columns in other annotations.
columns() - Element in annotation interface org.apache.ignite.catalog.annotations.Index
Columns to include in the index.
columns() - Method in class org.apache.ignite.catalog.definitions.IndexDefinition
Returns list of column references to include in the index.
columns() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns definitions of the columns.
columns() - Method in interface org.apache.ignite.sql.ResultSetMetadata
Returns metadata with a description for every column in the result set.
columns(List<ColumnDefinition>) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets definitions of the columns.
columns(ColumnDefinition...) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets definitions of the columns.
columnsMetaAsync(JdbcMetaColumnsRequest) - Method in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
ColumnSorted - Class in org.apache.ignite.catalog
Column reference with sort order, used in indexes or primary keys.
ColumnType<T> - Class in org.apache.ignite.catalog
Column types.
ColumnType - Enum Class in org.apache.ignite.sql
Predefined column types.
columnValue(String, Condition) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a predicate that tests whether the column value is equal to the given condition.
CombinedConfigRegistry - Class in org.apache.ignite.migrationtools.config.registry
Registry has two separated internal registries for cluster and node configurations.
CombinedConfigRegistry(ConfigurationRegistry, ConfigurationRegistry) - Constructor for class org.apache.ignite.migrationtools.config.registry.CombinedConfigRegistry
 
commit() - Method in interface org.apache.ignite.tx.Transaction
Synchronously commits a transaction.
commitAsync() - Method in interface org.apache.ignite.tx.Transaction
Asynchronously commits a transaction.
Common() - Constructor for class org.apache.ignite.lang.ErrorGroups.Common
 
COMMON_CONF_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.CommonConfiguration
 
COMMON_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Marshalling
Marshalling error.
COMMON_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
Common error group.
CommonConfiguration() - Constructor for class org.apache.ignite.lang.ErrorGroups.CommonConfiguration
 
CommunicationSpiConverter - Class in org.apache.ignite.migrationtools.config.converters
CommunicationSpiConverter.
CommunicationSpiConverter() - Constructor for class org.apache.ignite.migrationtools.config.converters.CommunicationSpiConverter
 
COMPACTED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.MetaStorage
Failed to perform a read operation on the underlying key value storage because the revision has already been compacted.
COMPACTION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.MetaStorage
Failed to compact the underlying key value storage.
COMPLETED - Enum constant in enum class org.apache.ignite.compute.JobStatus
The job was executed successfully and the execution result was returned.
COMPLETED - Enum constant in enum class org.apache.ignite.compute.TaskStatus
The task was executed successfully and the execution result was returned.
ComplexKeyIntStr - Class in org.apache.ignite.migrationtools.tests.models
ComplexKeyIntStr.
ComplexKeyIntStr(int, String) - Constructor for class org.apache.ignite.migrationtools.tests.models.ComplexKeyIntStr
 
COMPONENT_NOT_STARTED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
Component not started error.
compute() - Method in interface org.apache.ignite.Ignite
Returns IgniteCompute, which can be used to execute compute jobs.
Compute() - Constructor for class org.apache.ignite.lang.ErrorGroups.Compute
 
COMPUTE_CANCEL - Enum constant in enum class org.apache.ignite.client.ClientOperationType
Cancel compute job.
COMPUTE_CHANGE_PRIORITY - Enum constant in enum class org.apache.ignite.client.ClientOperationType
Change compute job priority (JobExecution.changePriorityAsync(int)).
COMPUTE_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Compute error group.
COMPUTE_EXECUTE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
COMPUTE_EXECUTE_MAPREDUCE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
COMPUTE_GET_STATE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
Get compute job state (JobExecution.stateAsync()).
COMPUTE_JOB_CANCELLED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Compute job cancelled.
COMPUTE_JOB_FAILED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Compute job failed.
COMPUTE_JOB_STATUS_TRANSITION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Compute job status transition error.
COMPUTE_PLATFORM_EXECUTOR_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Platform compute executor error.
ComputeAsyncExample - Class in org.apache.ignite.example.compute
This example demonstrates the usage of the IgniteCompute.executeAsync(JobTarget, JobDescriptor, Object) API.
ComputeAsyncExample() - Constructor for class org.apache.ignite.example.compute.ComputeAsyncExample
 
ComputeBroadcastExample - Class in org.apache.ignite.example.compute
This example demonstrates the usage of the IgniteCompute.execute(BroadcastJobTarget, JobDescriptor, Object) API.
ComputeBroadcastExample() - Constructor for class org.apache.ignite.example.compute.ComputeBroadcastExample
 
ComputeCancellationExample - Class in org.apache.ignite.example.compute
ComputeCancellationExample() - Constructor for class org.apache.ignite.example.compute.ComputeCancellationExample
 
ComputeColocatedExample - Class in org.apache.ignite.example.compute
This example demonstrates the usage of the IgniteCompute.execute(JobTarget, JobDescriptor, Object) API with colocated JobTarget.
ComputeColocatedExample() - Constructor for class org.apache.ignite.example.compute.ComputeColocatedExample
 
ComputeExample - Class in org.apache.ignite.example.compute
This example demonstrates the usage of the IgniteCompute.execute(JobTarget, JobDescriptor, Object) API.
ComputeExample() - Constructor for class org.apache.ignite.example.compute.ComputeExample
 
ComputeException - Exception in org.apache.ignite.compute
Compute exception base class.
ComputeException(int) - Constructor for exception org.apache.ignite.compute.ComputeException
Creates an exception with the given error code.
ComputeException(int, String) - Constructor for exception org.apache.ignite.compute.ComputeException
Creates an exception with the given error code and detailed message.
ComputeException(int, String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeException
Creates an exception with the given error code, detailed message and cause.
ComputeException(int, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeException
Creates an exception with the given error code and cause.
ComputeException(UUID, int, String) - Constructor for exception org.apache.ignite.compute.ComputeException
Creates an exception with the given trace ID, error code, and detailed message.
ComputeException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeException
Creates an exception with the given trace ID, error code, detailed message, and cause.
ComputeException(UUID, int, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeException
Creates an exception with the given trace ID, error code, and cause.
ComputeJob<T,R> - Interface in org.apache.ignite.compute
Core Ignite Compute Job interface.
ComputeJobPriorityExample - Class in org.apache.ignite.example.compute
This example demonstrates the usage of the IgniteCompute.execute(JobTarget, JobDescriptor, Object) API with different job priorities.
ComputeJobPriorityExample() - Constructor for class org.apache.ignite.example.compute.ComputeJobPriorityExample
 
ComputeJobRunnerBuilder() - Constructor for class org.apache.ignite.compute.task.MapReduceJob.ComputeJobRunnerBuilder
 
ComputeJobStateExample - Class in org.apache.ignite.example.compute
This code demonstrates the usage of the JobExecution interface that allows to get job statuses and, for example, handle failures.
ComputeJobStateExample() - Constructor for class org.apache.ignite.example.compute.ComputeJobStateExample
 
ComputeMapReduceExample - Class in org.apache.ignite.example.compute
This example demonstrates the usage of the IgniteCompute.executeMapReduce(TaskDescriptor, Object) API.
ComputeMapReduceExample() - Constructor for class org.apache.ignite.example.compute.ComputeMapReduceExample
 
ComputeMapReduceExample.PhraseWordLengthCountMapReduceTask - Class in org.apache.ignite.example.compute
MapReduce task that splits the input phrase into words and sends them to different nodes for the processing.
ComputeWithCustomResultMarshallerExample - Class in org.apache.ignite.example.compute
This example demonstrates the usage of the IgniteCompute.execute(JobTarget, JobDescriptor, Object) API with a custom result marshaller.
ComputeWithCustomResultMarshallerExample() - Constructor for class org.apache.ignite.example.compute.ComputeWithCustomResultMarshallerExample
 
ComputeWithCustomResultMarshallerExample.WordInfoJob - Class in org.apache.ignite.example.compute
Job that calculates length of the provided word.
ComputeWithCustomResultMarshallerExample.WordInfoResult - Class in org.apache.ignite.example.compute
The result object for the WordInfoJob.
ComputeWithCustomResultMarshallerExample.WordInfoResultMarshaller - Class in org.apache.ignite.example.compute
Marshals WordInfoResult into a byte array.
ComputeWithResultExample - Class in org.apache.ignite.example.compute
This example demonstrates the usage of the IgniteCompute.execute(JobTarget, JobDescriptor, Object) API with a result return.
ComputeWithResultExample() - Constructor for class org.apache.ignite.example.compute.ComputeWithResultExample
 
Condition - Class in org.apache.ignite.table.criteria
Represents an condition with operator and elements for criteria query.
Config - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation, if applied to a class, marks it as a configuration schema part.
CONFIG_FILE_CREATE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.NodeConfiguration
Config file creation error.
CONFIG_PARSE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.NodeConfiguration
Config parse error.
CONFIG_READ_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.NodeConfiguration
Config read error.
CONFIG_WRITE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.NodeConfiguration
Config write error.
configFile() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.PersistenceParams
 
configuration() - Method in interface org.apache.ignite.client.IgniteClient
Gets the configuration.
configuration() - Method in interface org.apache.ignite.client.RetryPolicyContext
Gets the client configuration.
CONFIGURATION_APPLY_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.CommonConfiguration
Configuration apply failed.
CONFIGURATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
Configuration error.
CONFIGURATION_PARSE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.CommonConfiguration
Configuration parse error.
CONFIGURATION_VALIDATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.CommonConfiguration
Configuration validation error.
ConfigurationChangeException - Exception in org.apache.ignite.configuration
Configuration change exception.
ConfigurationChangeException(String) - Constructor for exception org.apache.ignite.configuration.ConfigurationChangeException
Constructor.
ConfigurationChangeException(String, Throwable) - Constructor for exception org.apache.ignite.configuration.ConfigurationChangeException
Constructor.
ConfigurationConverter - Class in org.apache.ignite.migrationtools.config
ConfigurationConverter.
ConfigurationConverter - Interface in org.apache.ignite.migrationtools.config.converters
ConfigurationConverter.
ConfigurationConverter() - Constructor for class org.apache.ignite.migrationtools.config.ConfigurationConverter
 
ConfigurationConverterCall - Class in org.apache.ignite.migrationtools.cli.configs.calls
Call to the Configuration Converter.
ConfigurationConverterCall() - Constructor for class org.apache.ignite.migrationtools.cli.configs.calls.ConfigurationConverterCall
 
ConfigurationConverterCall.Input - Class in org.apache.ignite.migrationtools.cli.configs.calls
Inputs.
ConfigurationConverterCmd - Class in org.apache.ignite.migrationtools.cli.configs.commands
ConfigurationConverterCmd.
ConfigurationConverterCmd() - Constructor for class org.apache.ignite.migrationtools.cli.configs.commands.ConfigurationConverterCmd
 
ConfigurationDynamicDefaultsPatcher - Interface in org.apache.ignite.configuration
Patcher for the configuration.
ConfigurationExtension - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation can only be applied to a class that is either marked with ConfigurationRoot or the superclass is marked with ConfigurationRoot, Config.
ConfigurationListener<VIEWT> - Interface in org.apache.ignite.configuration.notifications
Configuration property change listener.
ConfigurationListenOnlyException - Exception in org.apache.ignite.configuration
This exception is used if an attempt was made to get/update a configuration value in listen-only mode.
ConfigurationListenOnlyException(String) - Constructor for exception org.apache.ignite.configuration.ConfigurationListenOnlyException
Constructor.
ConfigurationModule - Interface in org.apache.ignite.configuration
A module of configuration provided by a JAR file (or, in its source form, by a Maven/Gradle/...
ConfigurationNamedListListener<VIEWT> - Interface in org.apache.ignite.configuration.notifications
Configuration property change listener for named list configurations.
ConfigurationNodeAlreadyExistException - Exception in org.apache.ignite.configuration
This exception is thrown when an operation attempts to create a node with a key that already exists.
ConfigurationNodeAlreadyExistException(String) - Constructor for exception org.apache.ignite.configuration.ConfigurationNodeAlreadyExistException
The constructor.
ConfigurationNodeDoesNotExistException - Exception in org.apache.ignite.configuration
This exception is thrown when an operation attempts to access a node with a key that no longer exists.
ConfigurationNodeDoesNotExistException(String) - Constructor for exception org.apache.ignite.configuration.ConfigurationNodeDoesNotExistException
The constructor.
ConfigurationNodeModificationException - Exception in org.apache.ignite.configuration
The base class for exceptions that can be thrown during modification of NamedListChange.
ConfigurationNodeRemovedException - Exception in org.apache.ignite.configuration
This exception is thrown when an operation attempts to modify a node with a key that was removed.
ConfigurationNodeRemovedException(String) - Constructor for exception org.apache.ignite.configuration.ConfigurationNodeRemovedException
The constructor.
ConfigurationNotificationEvent<VIEWT> - Interface in org.apache.ignite.configuration.notifications
Event object propagated on configuration change.
ConfigurationProperty<VIEWT> - Interface in org.apache.ignite.configuration
Base interface for configuration.
ConfigurationReadOnlyException - Exception in org.apache.ignite.configuration
This exception is used if an attempt was made to update a configuration value in read-only mode.
ConfigurationReadOnlyException(String) - Constructor for exception org.apache.ignite.configuration.ConfigurationReadOnlyException
Constructor.
ConfigurationRegistryInterface - Interface in org.apache.ignite.migrationtools.config.registry
Custom Configuration Registry Interface.
ConfigurationRoot - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation, if applied to a class, marks it as a configuration schema root.
ConfigurationTree<VIEWT,CHANGET> - Interface in org.apache.ignite.configuration
Configuration tree with configuration values and other configuration trees as child nodes.
ConfigurationType - Enum Class in org.apache.ignite.configuration.annotation
Type of configuration storage.
ConfigurationValidationException - Exception in org.apache.ignite.configuration.validation
Configuration validation exception.
ConfigurationValidationException(String) - Constructor for exception org.apache.ignite.configuration.validation.ConfigurationValidationException
Constructor.
ConfigurationValidationException(Collection<ValidationIssue>) - Constructor for exception org.apache.ignite.configuration.validation.ConfigurationValidationException
Constructor.
ConfigurationValue<VIEWT> - Interface in org.apache.ignite.configuration
Configuration value.
ConfigurationWrongPolymorphicTypeIdException - Exception in org.apache.ignite.configuration
Thrown when the wrong (unknown) type of polymorphic configuration is used.
ConfigurationWrongPolymorphicTypeIdException(String) - Constructor for exception org.apache.ignite.configuration.ConfigurationWrongPolymorphicTypeIdException
Constructor.
ConfigValue - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation marks configuration schema field as a configuration tree node.
connect(String, Properties) - Method in class org.apache.ignite.jdbc.IgniteJdbcDriver
connect(ZoneId, String) - Method in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
CONNECTION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
Connection failed.
connections() - Method in interface org.apache.ignite.client.IgniteClient
Gets active client connections.
connectionsInitiated() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets total initiated connections.
connectTimeout() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the socket connect timeout, in milliseconds.
connectTimeout(long) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the socket connection timeout, in milliseconds.
connectTimeoutMillis - Variable in class org.apache.ignite.client.handler.configuration.ClientConnectorConfigurationSchema
Connect timeout.
consistencyMode() - Element in annotation interface org.apache.ignite.catalog.annotations.Zone
Consistency mode.
consistencyMode() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns consistency mode.
consistencyMode(String) - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Sets consistency mode.
consistentId() - Method in class org.apache.ignite.migrationtools.persistence.Ignite2PersistenceTools.NodeFolderDescriptor
consistentId.
CONSTRAINT_VIOLATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
Constraint violation error such as primary key violation.
container - Variable in class org.apache.ignite.migrationtools.tests.containers.MigrationToolsContainer
 
contains(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Determines whether a table contains an entry for the specified key.
contains(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Determines whether a table contains an entry for the specified key.
containsAll(Transaction, Collection<K>) - Method in interface org.apache.ignite.table.KeyValueView
Determines whether a table contains entries for all given keys.
containsAll(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Determines whether a table contains entries for all given keys.
containsAllAsync(Transaction, Collection<K>) - Method in interface org.apache.ignite.table.KeyValueView
Determines whether a table contains entries for all given keys.
containsAllAsync(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Determines whether a table contains entries for all given keys.
containsAsync(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Determines whether a table contains an entry for the specified key.
containsAsync(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Determines whether a table contains an entry for the specified key.
convert(String, TypeConverter<ObjectT, ColumnT>) - Method in class org.apache.ignite.table.mapper.MapperBuilder
Sets a converter for a column whose value must be converted before "write to" and after "read from".
convert(IgniteConfiguration, ConfigurationRegistryInterface) - Method in class org.apache.ignite.migrationtools.config.converters.ClientConnectorConverter
 
convert(IgniteConfiguration, ConfigurationRegistryInterface) - Method in class org.apache.ignite.migrationtools.config.converters.CommunicationSpiConverter
 
convert(IgniteConfiguration, ConfigurationRegistryInterface) - Method in interface org.apache.ignite.migrationtools.config.converters.ConfigurationConverter
 
convert(IgniteConfiguration, ConfigurationRegistryInterface) - Method in class org.apache.ignite.migrationtools.config.converters.DataRegionConfigurationConverter
 
convert(IgniteConfiguration, ConfigurationRegistryInterface) - Method in class org.apache.ignite.migrationtools.config.converters.DiscoverySpiConverter
 
convert(IgniteConfiguration, ConfigurationRegistryInterface) - Method in class org.apache.ignite.migrationtools.config.converters.SslContextFactoryConverter
 
convertConfigurationFile(File, File, File, boolean, ClassLoader) - Static method in class org.apache.ignite.migrationtools.config.ConfigurationConverter
Converts an Apache Ignite 2 configuration file into its Apache Ignite 3 node and cluster configurations counterparts.
converter() - Method in interface org.apache.ignite.table.mapper.OneColumnMapper
Returns a type converter for the mapped column.
converterFor(Class<ObjectT>, Class<ColumnT>) - Method in class org.apache.ignite.migrationtools.types.converters.StaticTypeConverterFactory
 
converterFor(Class<ObjectT>, Class<ColumnT>) - Method in interface org.apache.ignite.migrationtools.types.converters.TypeConverterFactory
 
converterForColumn(String) - Method in interface org.apache.ignite.table.mapper.PojoMapper
Returns a type converter for a given column.
convertIfNecessary(Object, Class<T>) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
convertIfNecessary(Object, Class<T>, Field) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
convertIfNecessary(Object, Class<T>, TypeDescriptor) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
convertIfNecessary(Object, Class<T>, MethodParameter) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
copy(Tuple) - Static method in interface org.apache.ignite.table.Tuple
Creates a tuple copy.
copyFileFromContainer(String, String) - Method in class org.apache.ignite.migrationtools.tests.containers.MigrationToolsContainer
 
create() - Static method in interface org.apache.ignite.lang.CancelHandle
A factory method to create a handle.
create() - Static method in interface org.apache.ignite.marshalling.ByteArrayMarshaller
 
create() - Static method in class org.apache.ignite.migrationtools.cli.exceptions.ErrorLoadingInputConfigurationHandlers
Create method.
create() - Static method in class org.apache.ignite.sql.BatchedArguments
Creates batched arguments.
create() - Static method in interface org.apache.ignite.table.Tuple
Creates a tuple.
create(int) - Static method in interface org.apache.ignite.table.Tuple
Creates a tuple with a specified initial capacity.
create(int, String, Consumer<CHANGET>) - Method in interface org.apache.ignite.configuration.NamedListChange
Creates a new value at the given position in the named list configuration.
create(String, Consumer<CHANGET>) - Method in interface org.apache.ignite.configuration.NamedListChange
Creates a new value in the named list configuration.
create(Map<String, Object>) - Static method in interface org.apache.ignite.table.Tuple
Creates a tuple from a given mapping.
create(GridKernalContext, IgniteConfiguration) - Static method in class org.apache.ignite.migrationtools.persistence.MigrationKernal
Factory method.
createAfter(String, String, Consumer<CHANGET>) - Method in interface org.apache.ignite.configuration.NamedListChange
Create a new value after a given precedingKey key in the named list configuration.
createAndStartMigrationContext(PersistenceParams, IgniteConfiguration) - Static method in class org.apache.ignite.migrationtools.cli.persistence.commands.PersistenceBaseCmd
Creates and starts the MigrationKernalContexts for the provided params and configurations.
createBean(String, RootBeanDefinition, Object[]) - Method in class org.apache.ignite.migrationtools.config.loader.CustomBeanFactory
 
createBeanFactory(boolean) - Static method in class org.apache.ignite.migrationtools.config.Ignite2ConfigurationUtils
Create spring bean factory based on the skipUnloadableBeans property.
createCacheConfiguration(String, Class<K>, Class<V>) - Static method in class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
Creates the cache configuration for this test.
createClusterContainers() - Method in class org.apache.ignite.migrationtools.tests.clusters.FullSampleCluster
 
createClusterContainers() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterWithSamples
 
createDdlQuery(List<TableDefinition>) - Static method in class org.apache.ignite.migrationtools.sql.SqlDdlGenerator
Create SQL DDL Statements from the provided list of table definitions.
createDdlQuery(TableDefinition) - Static method in class org.apache.ignite.migrationtools.sql.SqlDdlGenerator
 
createHolder() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
 
createIgniteClient(IgniteClientProperties, IgniteClientPropertiesCustomizer) - Method in class org.apache.ignite.IgniteClientAutoConfiguration
Creates Ignite client.
createMapper() - Static method in class org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor
Creates a JSON Mapper.
createOrUpdate(String, Consumer<CHANGET>) - Method in interface org.apache.ignite.configuration.NamedListChange
Updates a value in the named list configuration.
createSeedDataCountainer(Network) - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterWithSamples
 
createStatement(String) - Method in interface org.apache.ignite.sql.IgniteSql
Creates an SQL statement from a given query string.
createSubscribed(Flow.Publisher<Map.Entry<Object, Object>>, int, ClientSchema, Map<String, String>, TypeConverterFactory) - Method in interface org.apache.ignite.migrationtools.persistence.Ignite2PersistentCacheTools.ColumnsProcessorFactory
 
createTable(Class<?>) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a query object from the annotated record class.
createTable(Class<?>, Class<?>) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a query object from the annotated key and value classes.
createTable(TableDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a query object from the table definition.
createTableAsync(Class<?>) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a query object from the annotated record class.
createTableAsync(Class<?>, Class<?>) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a query object from the annotated key and value classes.
createTableAsync(TableDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a query object from the table definition.
createTime() - Method in interface org.apache.ignite.compute.JobState
Returns job create time.
createTime() - Method in interface org.apache.ignite.compute.TaskState
Returns task create time.
createUnexpectedRecordTypeError(Class<?>, Class<?>) - Static method in exception org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor.RecordMappingException
 
createValidIgniteCfg(PersistenceParams) - Static method in class org.apache.ignite.migrationtools.cli.persistence.commands.PersistenceBaseCmd
Creates a valid Ignite configuration.
createZone(ZoneDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a CREATE ZONE query object from the zone definition.
createZoneAsync(ZoneDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a query object from the zone definition.
Criteria - Interface in org.apache.ignite.table.criteria
Represents a criteria query predicate.
CriteriaException - Exception in org.apache.ignite.table.criteria
Criteria exception base class.
CriteriaException(int) - Constructor for exception org.apache.ignite.table.criteria.CriteriaException
Creates an exception with the given error code.
CriteriaException(int, String) - Constructor for exception org.apache.ignite.table.criteria.CriteriaException
Creates an exception with the given error code and detailed message.
CriteriaException(int, String, Throwable) - Constructor for exception org.apache.ignite.table.criteria.CriteriaException
Creates an exception with the given error code, detailed message, and cause.
CriteriaException(int, Throwable) - Constructor for exception org.apache.ignite.table.criteria.CriteriaException
Creates an exception with the given error code and cause.
CriteriaException(UUID, int) - Constructor for exception org.apache.ignite.table.criteria.CriteriaException
Creates an exception with the given trace ID and error code.
CriteriaException(UUID, int, String) - Constructor for exception org.apache.ignite.table.criteria.CriteriaException
Creates an exception with the given trace ID, error code, and detailed message.
CriteriaException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.table.criteria.CriteriaException
Creates an exception with the given trace ID, error code, detailed message, and cause.
CriteriaException(UUID, int, Throwable) - Constructor for exception org.apache.ignite.table.criteria.CriteriaException
Creates an exception with the given trace ID, error code, and cause.
CriteriaQueryOptions - Class in org.apache.ignite.table.criteria
Options useful for tuning the criteria query.
CriteriaQueryOptions.Builder - Class in org.apache.ignite.table.criteria
Builder.
CriteriaQuerySource<T> - Interface in org.apache.ignite.table.criteria
Represents an entity that can be used to execute predicate-based criteria queries.
CriteriaVisitor<C> - Interface in org.apache.ignite.table.criteria
A visitor to traverse an criteria tree.
CRITICAL_WORKERS_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.CriticalWorkers
Critical workers error group.
CriticalWorkers() - Constructor for class org.apache.ignite.lang.ErrorGroups.CriticalWorkers
 
currentKey() - Method in interface org.apache.ignite.configuration.validation.ValidationContext
Returns the key of validated node.
currentPage() - Method in interface org.apache.ignite.lang.AsyncCursor
Returns the current page content if the operation returns results.
currentPage() - Method in interface org.apache.ignite.sql.async.AsyncResultSet
Returns the current page content if the query returns rows.
currentPageSize() - Method in interface org.apache.ignite.lang.AsyncCursor
Returns the current page size if the operation return results.
currentPageSize() - Method in interface org.apache.ignite.sql.async.AsyncResultSet
Returns the current page size if the query return rows.
Cursor<T> - Interface in org.apache.ignite.lang
Provides methods to iterate over operation results and release underlying resources.
CURSOR_ALREADY_CLOSED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
Cursor is already closed error.
CURSOR_CLOSE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Replicator
Failed to close cursor.
CursorClosedException - Exception in org.apache.ignite.lang
Exception is thrown when a data fetch attempt is performed on a closed cursor.
CursorClosedException() - Constructor for exception org.apache.ignite.lang.CursorClosedException
Creates an exception instance.
cursorsActive() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets active cursors.
cursorsActiveDecrement() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Decrements active cursors.
cursorsActiveIncrement() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Increments active cursors.
CustomBeanFactory - Class in org.apache.ignite.migrationtools.config.loader
This factory overrides the BeanWrapper creation.
CustomBeanFactory(MultiValuedMap<Object, Pair<PropertyDescriptor, BeanDefinition>>) - Constructor for class org.apache.ignite.migrationtools.config.loader.CustomBeanFactory
 
customizeClient() - Method in class org.apache.ignite.customizer.example.ExampleApplicationWithCustomAuthenticator
This method can be used to set or override properties.
customizer() - Method in class org.apache.ignite.IgniteClientAutoConfiguration
 
CustomPojoSerializationExample - Class in org.apache.ignite.example.serialization
 
CustomPojoSerializationExample() - Constructor for class org.apache.ignite.example.serialization.CustomPojoSerializationExample
 
CustomPojoSerializationJob - Class in org.apache.ignite.example.serialization
 
CustomPojoSerializationJob() - Constructor for class org.apache.ignite.example.serialization.CustomPojoSerializationJob
 
CustomTupleImpl - Class in org.apache.ignite.migrationtools.persistence.mappers
Slightly more efficient Tuple implementation that uses precomputed column name to column id mappings.
CustomTupleImpl(Map<String, Integer>) - Constructor for class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 

D

dataNodesAutoAdjust() - Element in annotation interface org.apache.ignite.catalog.annotations.Zone
Deprecated.
dataNodesAutoAdjust() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Deprecated.
dataNodesAutoAdjust(Integer) - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Deprecated.
dataNodesAutoAdjustScaleDown() - Element in annotation interface org.apache.ignite.catalog.annotations.Zone
Timeout in seconds between node left topology event itself and data nodes switch.
dataNodesAutoAdjustScaleDown() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns timeout in seconds between node left topology event itself and data nodes switch.
dataNodesAutoAdjustScaleDown(Integer) - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Sets timeout in seconds between node left topology event itself and data nodes switch.
dataNodesAutoAdjustScaleUp() - Element in annotation interface org.apache.ignite.catalog.annotations.Zone
Timeout in seconds between node added topology event itself and data nodes switch.
dataNodesAutoAdjustScaleUp() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns timeout in seconds between node added topology event itself and data nodes switch.
dataNodesAutoAdjustScaleUp(Integer) - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Sets timeout in seconds between node added topology event itself and data nodes switch.
DataRegionConfigurationConverter - Class in org.apache.ignite.migrationtools.config.converters
DataRegionConfigurationConverter.
DataRegionConfigurationConverter() - Constructor for class org.apache.ignite.migrationtools.config.converters.DataRegionConfigurationConverter
 
DataStreamerException - Exception in org.apache.ignite.table
Represents an exception that is thrown during data streaming.
DataStreamerException(Set<?>, Throwable) - Constructor for exception org.apache.ignite.table.DataStreamerException
Constructor.
DataStreamerException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.table.DataStreamerException
Creates an exception with the given trace ID, error code, detailed message, and cause.
DataStreamerExceptionHandler - Class in org.apache.ignite.migrationtools.cli.exceptions
DataStreamerExceptionHandler.
DataStreamerExceptionHandler() - Constructor for class org.apache.ignite.migrationtools.cli.exceptions.DataStreamerExceptionHandler
 
DataStreamerItem<T> - Interface in org.apache.ignite.table
Data streamer item: data and operation type.
DataStreamerOperationType - Enum Class in org.apache.ignite.table
Data streamer operation type.
DataStreamerOptions - Class in org.apache.ignite.table
Data streamer options.
DataStreamerOptions.Builder - Class in org.apache.ignite.table
Builder.
DataStreamerReceiver<T,A,R> - Interface in org.apache.ignite.table
Data streamer receiver.
DataStreamerReceiverContext - Interface in org.apache.ignite.table
Context of the DataStreamerReceiver execution.
DataStreamerReceiverDescriptor<T,A,R> - Class in org.apache.ignite.table
Data streamer receiver descriptor.
DataStreamerReceiverDescriptor.Builder<T,A,R> - Class in org.apache.ignite.table
Builder.
DataStreamerTarget<T> - Interface in org.apache.ignite.table
Represents an entity that can be used as a target for streaming data.
DATE - Enum constant in enum class org.apache.ignite.sql.ColumnType
Timezone-free date.
DATE - Static variable in class org.apache.ignite.catalog.ColumnType
DATE SQL column type.
DATETIME - Enum constant in enum class org.apache.ignite.sql.ColumnType
Timezone-free datetime.
datetimeValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
datetimeValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a LocalDateTime column value.
datetimeValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
datetimeValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a LocalDateTime column value.
DateToInstantConverter - Class in org.apache.ignite.migrationtools.types.converters
Converts Java Date Calendars to Instants.
DateToInstantConverter() - Constructor for class org.apache.ignite.migrationtools.types.converters.DateToInstantConverter
 
DateToLocalDateTimeConverter - Class in org.apache.ignite.migrationtools.types.converters
Converts Java Date to LocalDateTime.
DateToLocalDateTimeConverter() - Constructor for class org.apache.ignite.migrationtools.types.converters.DateToLocalDateTimeConverter
 
dateValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
dateValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a LocalDate column value.
dateValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
dateValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a LocalDate column value.
decimal(int, int) - Static method in class org.apache.ignite.catalog.ColumnType
DECIMAL with specified precision and scale.
DECIMAL - Enum constant in enum class org.apache.ignite.sql.ColumnType
Arbitrary-precision signed decimal number.
DECIMAL - Static variable in class org.apache.ignite.catalog.ColumnType
DECIMAL SQL column type.
decimalValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
decimalValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a BigDecimal column value.
decimalValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
decimalValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a BigDecimal column value.
DEFAULT - Enum constant in enum class org.apache.ignite.catalog.IndexType
 
DEFAULT - Enum constant in enum class org.apache.ignite.catalog.SortOrder
 
DEFAULT - Static variable in class org.apache.ignite.compute.JobExecutionOptions
Default job execution options with priority default value = 0 and max retries default value = 0.
DEFAULT - Static variable in class org.apache.ignite.table.criteria.CriteriaQueryOptions
Default options.
DEFAULT - Static variable in class org.apache.ignite.table.DataStreamerOptions
Default options.
DEFAULT - Static variable in class org.apache.ignite.table.ReceiverExecutionOptions
Default receiver execution options.
DEFAULT_INSTANCE - Static variable in class org.apache.ignite.migrationtools.types.converters.StaticTypeConverterFactory
 
DEFAULT_RW_TX_TIMEOUT_SECONDS - Static variable in class org.apache.ignite.tx.IgniteTransactionDefaults
Default transaction timeout.
DEFAULT_SCHEMA - Static variable in annotation interface org.apache.ignite.catalog.annotations.Table
Default schema name.
DEFAULT_SCHEMA_NAME - Static variable in class org.apache.ignite.table.QualifiedName
Default schema name.
DEFAULT_ZONE - Static variable in annotation interface org.apache.ignite.catalog.annotations.Table
Default zone name.
defaultExpression() - Method in class org.apache.ignite.catalog.ColumnType
Returns default value expression of the column type.
defaultExpression(String) - Method in class org.apache.ignite.catalog.ColumnType
Set default value for this column type as an expression.
DefaultMigrateCacheExceptionHandler - Class in org.apache.ignite.migrationtools.cli.exceptions
DefaultMigrateCacheExceptionHandler.
DefaultMigrateCacheExceptionHandler() - Constructor for class org.apache.ignite.migrationtools.cli.exceptions.DefaultMigrateCacheExceptionHandler
 
defaultSchema() - Method in interface org.apache.ignite.sql.Statement
Returns a statement's default schema.
defaultSchema(String) - Method in interface org.apache.ignite.sql.Statement.StatementBuilder
Sets a default schema for the statement.
defaultValue() - Method in class org.apache.ignite.catalog.ColumnType
Returns default value of the column type.
defaultValue(T) - Method in class org.apache.ignite.catalog.ColumnType
Set default value for this column type.
definition() - Method in class org.apache.ignite.catalog.definitions.ColumnDefinition
Returns string definition of the column type.
delete(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Deletes a record with the same key column values as the given one from a table.
delete(String) - Method in interface org.apache.ignite.configuration.NamedListChange
Removes the value from the named list configuration.
deleteAll(Transaction) - Method in interface org.apache.ignite.table.RecordView
Removes all entries from a table records.
deleteAll(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Removes from a table records with the same key column values as the given one.
deleteAllAsync(Transaction) - Method in interface org.apache.ignite.table.RecordView
Asynchronously removes all entries from a table records.
deleteAllAsync(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Asynchronously removes from a table records with the same key column values as the given one.
deleteAllExact(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Remove the given records from a table.
deleteAllExactAsync(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Asynchronously removes the given records from a table.
deleteAsync(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Asynchronously deletes a record with the same key column values as the given one from a table.
deletedPrefixes() - Method in interface org.apache.ignite.configuration.ConfigurationModule
Returns a collection of prefixes, removed from configuration.
deleteExact(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Deletes the given record from a table.
deleteExactAsync(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Asynchronously deletes the given record from a table.
DEPLOYMENT_UNIT_NAME - Static variable in class org.apache.ignite.example.serialization.CustomPojoSerializationExample
 
DEPLOYMENT_UNIT_NAME - Static variable in class org.apache.ignite.example.serialization.PojoAutoSerializationExample
 
DEPLOYMENT_UNIT_NAME - Static variable in class org.apache.ignite.example.serialization.TupleSerializationExample
 
DEPLOYMENT_UNIT_VERSION - Static variable in class org.apache.ignite.example.serialization.CustomPojoSerializationExample
 
DEPLOYMENT_UNIT_VERSION - Static variable in class org.apache.ignite.example.serialization.PojoAutoSerializationExample
 
DEPLOYMENT_UNIT_VERSION - Static variable in class org.apache.ignite.example.serialization.TupleSerializationExample
 
DeploymentUnit - Class in org.apache.ignite.deployment
Deployment unit.
DeploymentUnit(String, String) - Constructor for class org.apache.ignite.deployment.DeploymentUnit
Constructor.
DeploymentUnit(String, Version) - Constructor for class org.apache.ignite.deployment.DeploymentUnit
Constructor.
DeploymentUnitInfo - Class in org.apache.ignite.deployment
Information about a deployment unit used by a job.
DeploymentUnitInfo(String, Version, Path) - Constructor for class org.apache.ignite.deployment.DeploymentUnitInfo
Creates deployment unit info.
deploymentUnits() - Method in interface org.apache.ignite.compute.JobExecutionContext
Collection of deployment units associated with this job execution.
desc() - Method in class org.apache.ignite.catalog.ColumnSorted
Assigns descending sort order.
DESC - Enum constant in enum class org.apache.ignite.catalog.SortOrder
 
DESC_NULLS_FIRST - Enum constant in enum class org.apache.ignite.catalog.SortOrder
 
DESC_NULLS_LAST - Enum constant in enum class org.apache.ignite.catalog.SortOrder
 
details(RecordAndTableSchemaMismatchException) - Static method in class org.apache.ignite.migrationtools.cli.exceptions.RecordAndTableSchemaMismatchExceptionHandler
Builds the details output.
DetectFailedEntriesExample - Class in org.apache.ignite.example.streaming
This example demonstrates how to use the streaming API to catch both asynchronous errors during background streaming and immediate submission errors.
DetectFailedEntriesExample() - Constructor for class org.apache.ignite.example.streaming.DetectFailedEntriesExample
 
determineTargetType(String, RootBeanDefinition, Class<?>...) - Method in class org.apache.ignite.migrationtools.config.loader.CustomBeanFactory
 
DFLT_BACKGROUND_RECONNECT_INTERVAL - Static variable in interface org.apache.ignite.client.IgniteClientConfiguration
Default background reconnect interval, in milliseconds.
DFLT_CONNECT_TIMEOUT - Static variable in interface org.apache.ignite.client.IgniteClientConfiguration
Default socket connect timeout, in milliseconds.
DFLT_HEARTBEAT_INTERVAL - Static variable in interface org.apache.ignite.client.IgniteClientConfiguration
Default heartbeat interval, in milliseconds.
DFLT_HEARTBEAT_TIMEOUT - Static variable in interface org.apache.ignite.client.IgniteClientConfiguration
Default heartbeat timeout, in milliseconds.
DFLT_OPERATION_TIMEOUT - Static variable in interface org.apache.ignite.client.IgniteClientConfiguration
Default operation timeout, in milliseconds.
DFLT_PORT - Static variable in interface org.apache.ignite.client.IgniteClientConfiguration
Default port.
DFLT_RETRY_LIMIT - Static variable in class org.apache.ignite.client.RetryLimitPolicy
Default retry limit.
DFLT_SQL_PARTITION_AWARENESS_METADATA_CACHE_SIZE - Static variable in interface org.apache.ignite.client.IgniteClientConfiguration
Default size for partition awareness metadata cache.
directProxy() - Method in interface org.apache.ignite.configuration.ConfigurationProperty
Returns a configuration tree for the purpose of reading configuration directly from the underlying storage.
directProxy() - Method in interface org.apache.ignite.configuration.NamedConfigurationTree
 
DisasterRecovery() - Constructor for class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
 
discoverClasses() - Static method in class org.apache.ignite.migrationtools.tests.e2e.framework.core.DiscoveryUtils
Discovers all the test class implementations.
DiscoverySpiConverter - Class in org.apache.ignite.migrationtools.config.converters
DiscoverySpiConverter.
DiscoverySpiConverter() - Constructor for class org.apache.ignite.migrationtools.config.converters.DiscoverySpiConverter
 
DiscoveryUtils - Class in org.apache.ignite.migrationtools.tests.e2e.framework.core
DiscoveryUtils.
DISTRIBUTED - Enum constant in enum class org.apache.ignite.configuration.annotation.ConfigurationType
Distributed configuration.
DistributedComputeWithReceiverExample - Class in org.apache.ignite.example.streaming
This example demonstrates how to use the streaming API to simulate a fraud detection process, which typically involves intensive processing of each transaction using ML models.
DistributedComputeWithReceiverExample() - Constructor for class org.apache.ignite.example.streaming.DistributedComputeWithReceiverExample
 
DISTRIBUTION_ZONES_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.DistributionZones
Distribution zones group.
distributionAlgorithm() - Element in annotation interface org.apache.ignite.catalog.annotations.Zone
Distribution algorithm.
distributionAlgorithm() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns distribution algorithm.
distributionAlgorithm(String) - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Sets the distribution algorithm.
DistributionZones() - Constructor for class org.apache.ignite.lang.ErrorGroups.DistributionZones
 
DIVERGED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.MetaStorage
Failed to start a node because Metastorage has diverged.
DOCKER_IMAGE_NAME - Static variable in class org.apache.ignite.migrationtools.tests.containers.MigrationToolsContainer
 
dockerHost() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterContainer
Returns docker host address.
dockerImageName() - Static method in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
Retrieves the ignite 3 docker image name which should be used in the tests.
doStop(boolean) - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterContainer
Stop the cluster.
DOTNET_SIDECAR - Enum constant in enum class org.apache.ignite.compute.JobExecutorType
Side-car .NET job executor.
DOUBLE - Enum constant in enum class org.apache.ignite.sql.ColumnType
64-bit double-precision floating-point number.
DOUBLE - Static variable in class org.apache.ignite.catalog.ColumnType
DOUBLE SQL column type.
doubleValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
doubleValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a double column value.
doubleValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
doubleValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a double column value.
dropTable(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a DROP TABLE query object from the table name.
dropTable(TableDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a DROP TABLE query object from the table definition.
dropTable(QualifiedName) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a DROP TABLE query object from the QualifiedName.
dropTableAsync(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a DROP TABLE query object from the table name.
dropTableAsync(TableDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a DROP TABLE query object from the table definition.
dropTableAsync(QualifiedName) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a DROP TABLE query object from the QualifiedName.
dropZone(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a DROP ZONE query object from the zone name.
dropZone(ZoneDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a DROP ZONE query object from the zone definition.
dropZoneAsync(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a DROP ZONE query object from the zone name.
dropZoneAsync(ZoneDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Creates a DROP ZONE query object from the zone definition.
DURATION - Enum constant in enum class org.apache.ignite.sql.ColumnType
Time interval.

E

Embedded() - Constructor for class org.apache.ignite.lang.ErrorGroups.Embedded
 
EMBEDDED_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Embedded
Embedded API group.
EMPTY_ASSIGNMENTS_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.PlacementDriver
Error that occurs if there are no assignments for a group.
EMPTY_DATA_NODES_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.DistributionZones
Empty data nodes.
enable() - Method in class org.apache.ignite.client.handler.ClientHandlerModule
Enables request handling.
enabled() - Method in interface org.apache.ignite.client.SslConfiguration
If set to true then the SSL connection will be used to interact with Ignite 3 node.
enabled() - Method in class org.apache.ignite.SslConfigurationProperties
 
enabled(boolean) - Method in class org.apache.ignite.client.SslConfiguration.Builder
Enabled/disabled setter.
endpoint() - Method in exception org.apache.ignite.client.IgniteClientConnectionException
Returns the endpoint that caused the exception.
Endpoint - Annotation Interface in org.apache.ignite.configuration.validation
Annotation to validate endpoint.
ensureNativelySupported(Class<O>) - Static method in interface org.apache.ignite.table.mapper.Mapper
Ensures a class is of natively supported kind and can be used in one-column mapping.
ensureWrapper(String) - Static method in class org.apache.ignite.migrationtools.utils.ClassnameUtils
 
EnumToStringTypeConverter<T extends Enum<T>> - Class in org.apache.ignite.migrationtools.types.converters
Converts an Enum to String.
EnumToStringTypeConverter(Class<T>) - Constructor for class org.apache.ignite.migrationtools.types.converters.EnumToStringTypeConverter
 
EQ - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 
equals(Object) - Method in class org.apache.ignite.catalog.ColumnSorted
 
equals(Object) - Method in class org.apache.ignite.catalog.definitions.ColumnDefinition
 
equals(Object) - Method in class org.apache.ignite.catalog.definitions.IndexDefinition
 
equals(Object) - Method in class org.apache.ignite.catalog.definitions.TableDefinition
 
equals(Object) - Method in class org.apache.ignite.configuration.validation.ValidationIssue
 
equals(Object) - Method in class org.apache.ignite.deployment.DeploymentUnit
 
equals(Object) - Method in class org.apache.ignite.example.compute.ComputeWithCustomResultMarshallerExample.WordInfoResult
equals(Object) - Method in class org.apache.ignite.lang.NullableValue
equals(Object) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
equals(Object) - Method in class org.apache.ignite.migrationtools.tests.models.ComplexKeyIntStr
 
equals(Object) - Method in class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel.Value
 
equals(Object) - Method in class org.apache.ignite.migrationtools.tests.models.SimplePojo
 
equals(Object) - Method in class org.apache.ignite.migrationtools.types.InspectedField
 
equals(Object) - Method in class org.apache.ignite.network.NetworkAddress
equals(Object) - Method in class org.apache.ignite.network.NodeMetadata
 
equals(Object) - Method in class org.apache.ignite.table.QualifiedName
equals(Object) - Method in class org.apache.ignite.table.ReceiverExecutionOptions
 
equals(Object) - Method in interface org.apache.ignite.table.Tuple
Indicates whether another object is "equal to" the specified one.
equals(Tuple, Tuple) - Static method in interface org.apache.ignite.table.Tuple
Compares tuples for equality.
equalTo(byte[]) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is equal to the specified value.
equalTo(Comparable<T>) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is equal to the specified value.
errorCode() - Method in exception org.apache.ignite.lang.IgniteCheckedException
Returns an error code that uniquely identifies a problem within a group.
errorCode() - Method in exception org.apache.ignite.lang.IgniteException
Returns an error code that uniquely identifies the problem within a group.
errorCode() - Method in interface org.apache.ignite.lang.TraceableException
Returns an error code that uniquely identifies the problem within a group.
ErrorCodeGroup - Annotation Interface in org.apache.ignite.error.code.annotations
Annotation that should be placed on the ErrorGroup in the java/org/apache/ignite/lang/ErrorGroups.java
ErrorGroup - Class in org.apache.ignite.lang
This class represents a concept of error group.
errorGroupByCode(int) - Static method in class org.apache.ignite.lang.ErrorGroups
Returns error group identified by the given error code.
errorGroupByGroupCode(short) - Static method in class org.apache.ignite.lang.ErrorGroups
Returns error group identified by the given groupCode.
ErrorGroups - Class in org.apache.ignite.lang
Defines error groups and its errors.
ErrorGroups() - Constructor for class org.apache.ignite.lang.ErrorGroups
 
ErrorGroups.Authentication - Class in org.apache.ignite.lang
Authentication error group.
ErrorGroups.Catalog - Class in org.apache.ignite.lang
Catalog error group.
ErrorGroups.Client - Class in org.apache.ignite.lang
Client error group.
ErrorGroups.CodeDeployment - Class in org.apache.ignite.lang
Code deployment error group.
ErrorGroups.Common - Class in org.apache.ignite.lang
Common error group.
ErrorGroups.CommonConfiguration - Class in org.apache.ignite.lang
Configuration error group.
ErrorGroups.Compute - Class in org.apache.ignite.lang
Compute error group.
ErrorGroups.CriticalWorkers - Class in org.apache.ignite.lang
Critical workers error group.
ErrorGroups.DisasterRecovery - Class in org.apache.ignite.lang
Disaster recovery error group.
ErrorGroups.DistributionZones - Class in org.apache.ignite.lang
Distribution zones error group.
ErrorGroups.Embedded - Class in org.apache.ignite.lang
Embedded API error group.
ErrorGroups.GarbageCollector - Class in org.apache.ignite.lang
Garbage collector error group.
ErrorGroups.Index - Class in org.apache.ignite.lang
Deprecated.
The whole group is unused.
ErrorGroups.Marshalling - Class in org.apache.ignite.lang
Marshalling error group.
ErrorGroups.MetaStorage - Class in org.apache.ignite.lang
Meta storage error group.
ErrorGroups.Network - Class in org.apache.ignite.lang
Network error group.
ErrorGroups.NodeConfiguration - Class in org.apache.ignite.lang
Node configuration error group.
ErrorGroups.PlacementDriver - Class in org.apache.ignite.lang
Placement driver error group.
ErrorGroups.Replicator - Class in org.apache.ignite.lang
Replicator error group.
ErrorGroups.Rest - Class in org.apache.ignite.lang
REST service error group.
ErrorGroups.Sql - Class in org.apache.ignite.lang
SQL error group.
ErrorGroups.Storage - Class in org.apache.ignite.lang
Storage error group.
ErrorGroups.Table - Class in org.apache.ignite.lang
Tables error group.
ErrorGroups.Transactions - Class in org.apache.ignite.lang
Transactions error group.
ErrorLoadingInputConfigurationHandlers - Class in org.apache.ignite.migrationtools.cli.exceptions
ExceptionHandlers for Error loading input configurations.
ErrorLoadingInputConfigurationHandlers() - Constructor for class org.apache.ignite.migrationtools.cli.exceptions.ErrorLoadingInputConfigurationHandlers
 
errorMessage(UUID, int, String) - Static method in class org.apache.ignite.lang.ErrorGroup
Creates a new error message with predefined prefix.
errorPrefix() - Method in class org.apache.ignite.lang.ErrorGroup
Returns a error prefix of this group.
ExampleApplication - Class in org.apache.ignite.example
Example application.
ExampleApplication() - Constructor for class org.apache.ignite.example.ExampleApplication
 
ExampleApplicationWithCustomAuthenticator - Class in org.apache.ignite.customizer.example
Example application that uses IgniteClientPropertiesCustomizer to set custom authenticator.
ExampleApplicationWithCustomAuthenticator() - Constructor for class org.apache.ignite.customizer.example.ExampleApplicationWithCustomAuthenticator
 
ExampleBasedCacheTest<K,V> - Interface in org.apache.ignite.migrationtools.tests.e2e.framework.core
Interface for example based tests.
ExampleBasedCacheTestProvider - Interface in org.apache.ignite.migrationtools.tests.e2e.framework.core
ExampleBasedCacheTestProvider.
exception() - Method in interface org.apache.ignite.client.RetryPolicyContext
Gets the connection exception that caused current retry iteration.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.ignite.client.handler.ClientInboundMessageHandler
ExceptKeys - Annotation Interface in org.apache.ignite.configuration.validation
Signifies that a NamedConfigValue can't have elements with provided names.
execInContainer(String...) - Method in class org.apache.ignite.migrationtools.tests.containers.MigrationToolsContainer
 
execInContainer(Charset, String...) - Method in class org.apache.ignite.migrationtools.tests.containers.MigrationToolsContainer
 
execInContainer(Charset, ExecConfig) - Method in class org.apache.ignite.migrationtools.tests.containers.MigrationToolsContainer
 
execInContainer(ExecConfig) - Method in class org.apache.ignite.migrationtools.tests.containers.MigrationToolsContainer
 
execute(Transaction, CancellationToken, String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a single SQL query.
execute(Transaction, CancellationToken, Statement, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a single SQL statement.
execute(Transaction, Mapper<T>, CancellationToken, String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes single SQL statement and maps results to objects with the provided mapper.
execute(Transaction, Mapper<T>, CancellationToken, Statement, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes single SQL statement and maps results to objects with the provided mapper.
execute(Transaction, Mapper<T>, String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes single SQL statement and maps results to objects with the provided mapper.
execute(Transaction, Mapper<T>, Statement, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes single SQL statement and maps results to objects with the provided mapper.
execute(Transaction, String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a single SQL query.
execute(Transaction, Statement, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a single SQL statement.
execute(BroadcastJobTarget, JobDescriptor<T, R>, T) - Method in interface org.apache.ignite.compute.IgniteCompute
Executes a ComputeJob of the given class on all nodes in the given node set.
execute(BroadcastJobTarget, JobDescriptor<T, R>, T, CancellationToken) - Method in interface org.apache.ignite.compute.IgniteCompute
Executes a ComputeJob of the given class on all nodes in the given node set.
execute(JobTarget, JobDescriptor<T, R>, T) - Method in interface org.apache.ignite.compute.IgniteCompute
Executes a ComputeJob of the given class on a single node from a set of candidate nodes.
execute(JobTarget, JobDescriptor<T, R>, T, CancellationToken) - Method in interface org.apache.ignite.compute.IgniteCompute
Executes a ComputeJob of the given class on a single node from a set of candidate nodes.
execute(ClientMessageUnpacker, JdbcQueryEventHandlerImpl, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcExecuteRequest
Processes remote JdbcQueryExecuteRequest.
execute(ClientMessageUnpacker, JdbcQueryEventHandler) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcCancelRequest
Processes a remote JDBC request to cancel the current execution.
execute(ClientMessageUnpacker, JdbcQueryEventHandler, String) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcConnectRequest
Processes remote JdbcQueryExecuteRequest.
execute(ConfigurationConverterCall.Input) - Method in class org.apache.ignite.migrationtools.cli.configs.calls.ConfigurationConverterCall
 
execute(ListCachesCall.Input) - Method in class org.apache.ignite.migrationtools.cli.persistence.calls.ListCachesCall
 
execute(MigrateCacheCall.Input) - Method in class org.apache.ignite.migrationtools.cli.persistence.calls.MigrateCacheCall
 
execute(RetriableMigrateCacheCall.Input) - Method in class org.apache.ignite.migrationtools.cli.persistence.calls.RetriableMigrateCacheCall
 
execute(SqlDdlGeneratorCall.Input) - Method in class org.apache.ignite.migrationtools.cli.sql.calls.SqlDdlGeneratorCall
 
executeAsync(Transaction, CancellationToken, String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes SQL query in an asynchronous way.
executeAsync(Transaction, CancellationToken, Statement, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes an SQL statement asynchronously.
executeAsync(Transaction, Mapper<T>, CancellationToken, String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes SQL statement in an asynchronous way and maps results to objects with the provided mapper.
executeAsync(Transaction, Mapper<T>, CancellationToken, Statement, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes SQL statement in an asynchronous way and maps results to objects with the provided mapper.
executeAsync(Transaction, Mapper<T>, String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes SQL statement in an asynchronous way and maps results to objects with the provided mapper.
executeAsync(Transaction, Mapper<T>, Statement, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes SQL statement in an asynchronous way and maps results to objects with the provided mapper.
executeAsync(Transaction, String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes SQL query in an asynchronous way.
executeAsync(Transaction, Statement, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes an SQL statement asynchronously.
executeAsync(BroadcastJobTarget, JobDescriptor<T, R>, T) - Method in interface org.apache.ignite.compute.IgniteCompute
Executes a ComputeJob of the given class on all nodes in the given node set.
executeAsync(BroadcastJobTarget, JobDescriptor<T, R>, T, CancellationToken) - Method in interface org.apache.ignite.compute.IgniteCompute
Executes a ComputeJob of the given class on all nodes in the given node set.
executeAsync(JobExecutionContext, Integer) - Method in class org.apache.ignite.example.serialization.IntegerDecrementJob
 
executeAsync(JobExecutionContext, String) - Method in class org.apache.ignite.example.code.deployment.MyJob
 
executeAsync(JobExecutionContext, String) - Method in class org.apache.ignite.example.compute.ComputeWithCustomResultMarshallerExample.WordInfoJob
Executes the job on an Ignite node.
executeAsync(JobExecutionContext, AutoSerializableArg) - Method in class org.apache.ignite.example.serialization.PojoAutoSerializationJob
 
executeAsync(JobExecutionContext, JsonArg) - Method in class org.apache.ignite.example.serialization.CustomPojoSerializationJob
 
executeAsync(JobExecutionContext, T) - Method in interface org.apache.ignite.compute.ComputeJob
Executes the job on an Ignite node.
executeAsync(JobTarget, JobDescriptor<T, R>, T) - Method in interface org.apache.ignite.compute.IgniteCompute
Submits a ComputeJob of the given class for an execution on a single node from a set of candidate nodes.
executeAsync(JobTarget, JobDescriptor<T, R>, T, CancellationToken) - Method in interface org.apache.ignite.compute.IgniteCompute
Submits a ComputeJob of the given class for an execution on a single node from a set of candidate nodes.
executeBatch(Transaction, CancellationToken, String, BatchedArguments) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a batched SQL query.
executeBatch(Transaction, CancellationToken, Statement, BatchedArguments) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a batched SQL statement.
executeBatch(Transaction, String, BatchedArguments) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a batched SQL query.
executeBatch(Transaction, Statement, BatchedArguments) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a batched SQL statement.
executeBatchAsync(Transaction, CancellationToken, String, BatchedArguments) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a batched SQL query asynchronously.
executeBatchAsync(Transaction, CancellationToken, Statement, BatchedArguments) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a batched SQL statement asynchronously.
executeBatchAsync(Transaction, String, BatchedArguments) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a batched SQL query asynchronously.
executeBatchAsync(Transaction, Statement, BatchedArguments) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a batched SQL statement asynchronously.
executeCommand(String[]) - Static method in class org.apache.ignite.migrationtools.cli.Main
Executes the builds and executes the picocli command.
executeMapReduce(TaskDescriptor<T, R>, T) - Method in interface org.apache.ignite.compute.IgniteCompute
Executes a MapReduceTask of the given class.
executeMapReduce(TaskDescriptor<T, R>, T, CancellationToken) - Method in interface org.apache.ignite.compute.IgniteCompute
Executes a MapReduceTask of the given class.
executeMapReduceAsync(TaskDescriptor<T, R>, T) - Method in interface org.apache.ignite.compute.IgniteCompute
Submits a MapReduceTask of the given class for an execution.
executeMapReduceAsync(TaskDescriptor<T, R>, T, CancellationToken) - Method in interface org.apache.ignite.compute.IgniteCompute
Submits a MapReduceTask of the given class for an execution.
executeScript(CancellationToken, String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a multi-statement SQL query.
executeScript(String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a multi-statement SQL query.
executeScriptAsync(CancellationToken, String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a multi-statement SQL query.
executeScriptAsync(String, Object...) - Method in interface org.apache.ignite.sql.IgniteSql
Executes a multi-statement SQL query.
EXECUTING - Enum constant in enum class org.apache.ignite.compute.JobStatus
The job is being executed.
EXECUTING - Enum constant in enum class org.apache.ignite.compute.TaskStatus
The task is being executed.
EXECUTION_CANCELLED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
Statement canceled error.
executions() - Method in interface org.apache.ignite.compute.BroadcastExecution
Returns a collection of individual job executions.
executorType() - Method in class org.apache.ignite.compute.JobExecutionOptions
Gets the job executor type.
executorType() - Method in class org.apache.ignite.table.ReceiverExecutionOptions
Gets the receiver executor type.
executorType(JobExecutorType) - Method in class org.apache.ignite.compute.JobExecutionOptions.Builder
Sets the job executor type.
executorType(JobExecutorType) - Method in class org.apache.ignite.table.ReceiverExecutionOptions.Builder
Sets the receiver executor type.
Expression - Class in org.apache.ignite.table.criteria
Defines a expression for a criteria query with operator and it's arguments.
EXTRA_FIELDS_COLUMN_NAME - Static variable in class org.apache.ignite.migrationtools.sql.SqlDdlGenerator
Name of the column that will be used to store fields that cannot be serialized natively, like nested objects in POJOs.
extractCauseMessage(String) - Static method in class org.apache.ignite.lang.ErrorGroups
Returns a message extracted from the given errorMessage if this errorMessage matches ErrorGroups.EXCEPTION_MESSAGE_PATTERN.
extractErrorCode(int) - Static method in class org.apache.ignite.lang.ErrorGroup
Returns error code extracted from the given full error code.
extractGroupCode(int) - Static method in class org.apache.ignite.lang.ErrorGroups
Returns group code extracted from the given full error code.

F

FAIL_TO_GET_JOB_STATE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Compute job state can't be retrieved.
FAILED - Enum constant in enum class org.apache.ignite.compute.JobStatus
The job was unexpectedly terminated during execution.
FAILED - Enum constant in enum class org.apache.ignite.compute.TaskStatus
The task was unexpectedly terminated during execution.
failedItems() - Method in exception org.apache.ignite.table.DataStreamerException
Gets the set of items that were not streamed to the cluster.
fetchAsync(JdbcFetchQueryResultsRequest) - Method in class org.apache.ignite.client.handler.JdbcQueryCursorHandlerImpl
fetchNextPage() - Method in interface org.apache.ignite.lang.AsyncCursor
Fetches the next page of results asynchronously.
fetchNextPage() - Method in interface org.apache.ignite.sql.async.AsyncResultSet
Fetches the next page of results asynchronously.
fieldForColumn(String) - Method in interface org.apache.ignite.table.mapper.PojoMapper
Returns a field name for a given column name when POJO individual fields are mapped to columns, otherwise fails.
fieldName() - Method in class org.apache.ignite.migrationtools.types.InspectedField
 
FieldNameConflictException - Exception in org.apache.ignite.migrationtools.sql
Defines a situation when it was not possible to assign a field name due to a conflict with other fields.
FieldNameConflictException(InspectedField, Set<String>) - Constructor for exception org.apache.ignite.migrationtools.sql.FieldNameConflictException
 
fields() - Method in interface org.apache.ignite.table.mapper.PojoMapper
Returns all fields that should be mapped to columns.
fieldToColumnMappings() - Method in class org.apache.ignite.migrationtools.sql.SqlDdlGenerator.GenerateTableResult
Combines FieldNamesForColumn mappings for keys and values into the same map.
fieldType() - Method in class org.apache.ignite.migrationtools.types.InspectedField
 
FILE_TRANSFER_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Network
File transfer error.
FILE_VALIDATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Network
File validation error.
filter() - Element in annotation interface org.apache.ignite.catalog.annotations.Zone
Nodes filter.
filter() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns nodes filter.
filter(String) - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Sets nodes filter.
findCustomEditor(Class<?>, String) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
finishTime() - Method in interface org.apache.ignite.compute.JobState
Returns job finish time.
finishTime() - Method in interface org.apache.ignite.compute.TaskState
Returns task finish time.
finishTxAsync(long, boolean) - Method in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
FLOAT - Enum constant in enum class org.apache.ignite.sql.ColumnType
32-bit single-precision floating-point number.
FLOAT - Static variable in class org.apache.ignite.catalog.ColumnType
32-bit single-precision floating-point number.
floatValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
floatValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a float column value.
floatValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
floatValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a float column value.
forName(String) - Method in interface org.apache.ignite.lang.LoggerFactory
Creates a logger instance with a given name.
forNamed(String, String, InspectedFieldType, boolean, boolean) - Static method in class org.apache.ignite.migrationtools.types.InspectedField
Factory method for named fields (non-primitive and non-array).
forSpecificField(String, String) - Static method in exception org.apache.ignite.migrationtools.sql.FieldNameConflictException
 
forSpecificField(String, String, String) - Static method in exception org.apache.ignite.migrationtools.sql.FieldNameConflictException
 
forUnknownType(String, String) - Static method in exception org.apache.ignite.migrationtools.sql.FieldNameConflictException
Creates an exception for an Unknown conflict type.
forUnnamed(String, InspectedFieldType) - Static method in class org.apache.ignite.migrationtools.types.InspectedField
Factory method for primitive and array fields.
from(String) - Static method in class org.apache.ignite.network.NetworkAddress
Parses a NetworkAddress from a string in the "host:port" format.
from(InetSocketAddress) - Static method in class org.apache.ignite.network.NetworkAddress
Creates a NetworkAddress from a InetSocketAddress.
from(List<List<Object>>) - Static method in class org.apache.ignite.sql.BatchedArguments
Creates batched arguments.
fromConsumer(Consumer<ConfigurationNotificationEvent<T>>) - Static method in interface org.apache.ignite.configuration.notifications.ConfigurationListener
Creates an adapter for a given callback.
fromDeletedPrefixes(Collection<String>) - Static method in interface org.apache.ignite.configuration.KeyIgnorer
Creates a key ignorer that uses specified deletedPrefixes.
fromNewValueConsumer(Consumer<T>) - Static method in interface org.apache.ignite.configuration.notifications.ConfigurationListener
Creates an adapter for a given callback.
fromNormalized(String, String) - Static method in class org.apache.ignite.table.QualifiedNameHelper
Return QualifiedName from a given schema and table names.
fromOrdinal(int) - Static method in enum class org.apache.ignite.compute.JobExecutorType
Returns the enumerated value from its ordinal.
fromSimple(String) - Static method in class org.apache.ignite.table.QualifiedName
Factory method that creates qualified name from given simple name by resolving it against the default schema.
FullSampleCluster - Class in org.apache.ignite.migrationtools.tests.clusters
Cluster with all the samples from all the caches.
FullSampleCluster() - Constructor for class org.apache.ignite.migrationtools.tests.clusters.FullSampleCluster
 

G

GarbageCollector() - Constructor for class org.apache.ignite.lang.ErrorGroups.GarbageCollector
 
GC_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.GarbageCollector
Garbage collector error group.
generate(CacheConfiguration<?, ?>) - Method in class org.apache.ignite.migrationtools.sql.SqlDdlGenerator
Generate table based on the provided CacheConfiguration.
generateTableDefinition(CacheConfiguration<?, ?>) - Method in class org.apache.ignite.migrationtools.sql.SqlDdlGenerator
 
GenerateTableResult(TableDefinition, TableTypeDescriptor) - Constructor for class org.apache.ignite.migrationtools.sql.SqlDdlGenerator.GenerateTableResult
Constructor.
get() - Method in class org.apache.ignite.lang.NullableValue
Returns a wrapped value.
get() - Method in interface org.apache.ignite.table.DataStreamerItem
Gets the data.
get(int) - Method in interface org.apache.ignite.configuration.NamedListView
Returns value located at the specified index.
get(int) - Method in class org.apache.ignite.sql.BatchedArguments
Returns the arguments list at the specified position.
get(long) - Method in class org.apache.ignite.client.handler.ClientResourceRegistry
Gets the resource by id.
get(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Gets a value associated with a given key.
get(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Gets a record with the same key column values as the given one from a table.
get(Class<T>) - Method in class org.apache.ignite.client.handler.ClientResource
Gets the underlying object.
get(String) - Method in interface org.apache.ignite.configuration.NamedConfigurationTree
Get named configuration by name.
get(String) - Method in interface org.apache.ignite.configuration.NamedListView
Returns value associated with the passed key.
get(UUID) - Method in interface org.apache.ignite.configuration.NamedConfigurationTree
Retrieves a named list element by its internal id.
get(UUID) - Method in interface org.apache.ignite.configuration.NamedListView
Returns value associated with the passed internal id.
getAddress() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
 
getAddresses() - Method in interface org.apache.ignite.client.IgniteClientAddressFinder
Get addresses of Ignite server nodes within a cluster.
getAddresses() - Method in class org.apache.ignite.IgniteClientProperties
Gets connection addresses.
getAddressFinder() - Method in class org.apache.ignite.IgniteClientProperties
Gets ignite client address finder.
getAffinityStr() - Method in class org.apache.ignite.migrationtools.tests.models.ComplexKeyIntStr
 
getAge() - Method in class org.apache.ignite.example.table.Person
 
getAll(Transaction, Collection<K>) - Method in interface org.apache.ignite.table.KeyValueView
Get values associated with given keys.
getAll(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Gets records from a table.
getAllAsync(Transaction, Collection<K>) - Method in interface org.apache.ignite.table.KeyValueView
Get values associated with given keys.
getAllAsync(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Asynchronously gets records from a table.
getAmount() - Method in class org.apache.ignite.migrationtools.tests.models.SimplePojo
 
getAndDelete(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Gets and deletes from a table a record with the same key column values as the given one.
getAndDeleteAsync(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Asynchronously gets and deletes from a table a record with the same key columns values as the given one.
getAndPut(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Puts into a table a new, or replaces an existing, value associated with the given key.
getAndPutAsync(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously puts into a table a new, or replaces an existing, value associated with given key.
getAndRemove(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Gets and removes from a table a value associated with the given key.
getAndRemoveAsync(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously gets and removes from a table a value associated with the given key.
getAndReplace(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Replaces a value for a given key if it exists.
getAndReplace(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Gets an existing record associated with the same key columns values as the given one, then replaces it with the given one.
getAndReplaceAsync(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously replaces a value for a given key if it exists.
getAndReplaceAsync(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Asynchronously gets an existing record associated with the same key column values as the given one, then replaces it with the given one.
getAndUpsert(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Inserts a record into a table, or replaces an existing record and returns the replaced record.
getAndUpsertAsync(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Asynchronously inserts a record into a table, or replaces an existing record and returns the replaced record.
getArraySupport() - Method in class org.apache.ignite.data.IgniteDialect
 
getAsync(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously gets a value associated with a given key.
getAsync(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Asynchronously gets a record with the same key column values as the given one from a table.
getAsyncContinuationExecutor() - Method in class org.apache.ignite.IgniteClientProperties
Gets async continuation executor.
getAuth() - Method in class org.apache.ignite.IgniteClientProperties
Gets authentication properties.
getAuthenticator() - Method in class org.apache.ignite.IgniteClientProperties
Gets ignite client authenticator.
getAutoGrowCollectionLimit() - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
getBackgroundReconnectInterval() - Method in class org.apache.ignite.IgniteClientProperties
Gets reconnect interval.
getBalance() - Method in class org.apache.ignite.example.streaming.Account
 
getBasic() - Method in class org.apache.ignite.IgniteClientProperties.AuthenticationProperties
 
getById(int) - Static method in enum class org.apache.ignite.sql.ColumnType
Returns the ColumnType instance by its id, or null if the id is invalid.
getCityId() - Method in class org.apache.ignite.example.table.Person
 
getColumnsMeta(String, String, String) - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcMetadataCatalog
getCompany() - Method in class org.apache.ignite.example.table.Person
 
getConfiguration(RootKey<T, V, C>) - Method in class org.apache.ignite.migrationtools.config.registry.CombinedConfigRegistry
 
getConfiguration(RootKey<T, V, C>) - Method in interface org.apache.ignite.migrationtools.config.registry.ConfigurationRegistryInterface
 
getConnectTimeout() - Method in class org.apache.ignite.IgniteClientProperties
Sets connection timeout.
getConversionService() - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
getDecimalAmount() - Method in class org.apache.ignite.migrationtools.tests.models.SimplePojo
 
getDecimalScale(NativeType) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTableCommon
Gets type scale.
getDialect(JdbcOperations) - Method in class org.apache.ignite.data.IgniteDialectProvider
 
getDroppedColumns() - Method in class org.apache.ignite.migrationtools.persistence.mappers.IgnoreMismatchesSchemaColumnProcessor.IgnoredColumnsStats
 
getElements() - Method in class org.apache.ignite.table.criteria.Condition
Get a condition elements.
getElements() - Method in class org.apache.ignite.table.criteria.Expression
Get a condition elements.
getHeartbeatInterval() - Method in class org.apache.ignite.IgniteClientProperties
Gets heartbeat interval.
getHeartbeatTimeout() - Method in class org.apache.ignite.IgniteClientProperties
Gets heartbeat timeout.
getId() - Method in class org.apache.ignite.example.streaming.Account
 
getId() - Method in class org.apache.ignite.example.table.Person
 
getId() - Method in class org.apache.ignite.migrationtools.tests.models.ComplexKeyIntStr
 
getIdentifierProcessing() - Method in class org.apache.ignite.data.IgniteDialect
 
getInternalAddress() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
 
getIssues() - Method in exception org.apache.ignite.configuration.validation.ConfigurationValidationException
Returns list of issues occurred during validation.
getLatestSchemaForTable(ClientTable) - Static method in class org.apache.ignite.migrationtools.tablemanagement.SchemaUtils
Exposes ClientTable.getLatestSchema().
getLoggerFactory() - Method in class org.apache.ignite.IgniteClientProperties
Gets logger factory.
getMajorVersion() - Method in class org.apache.ignite.jdbc.IgniteJdbcDriver
getMessage() - Method in exception org.apache.ignite.migrationtools.persistence.mappers.RecordAndTableSchemaMismatchException
 
getMinorVersion() - Method in class org.apache.ignite.jdbc.IgniteJdbcDriver
getMoreResultsAsync(JdbcFetchQueryResultsRequest) - Method in class org.apache.ignite.client.handler.JdbcQueryCursorHandlerImpl
getMsg() - Method in class org.apache.ignite.migrationtools.cli.persistence.calls.MigrateCacheCall.Ouput
 
getName() - Method in class org.apache.ignite.example.streaming.Account
 
getName() - Method in class org.apache.ignite.example.table.Person
 
getName() - Method in class org.apache.ignite.migrationtools.tests.models.SimplePojo
 
getName() - Method in class org.apache.ignite.table.criteria.Column
Gets column name.
getNetwork() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterContainer
 
getNewOwner() - Method in interface org.apache.ignite.configuration.validation.ValidationContext
Returns the updated view of the owner of the current value.
getNewRoot(RootKey<?, ROOT, ?>) - Method in interface org.apache.ignite.configuration.validation.ValidationContext
Returns updated value of the configuration root.
getNewValue() - Method in interface org.apache.ignite.configuration.validation.ValidationContext
Returns updated value of the configuration.
getNullable(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Gets a nullable value associated with a given key.
getNullableAndPut(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Puts into a table a new, or replaces an existing, value associated with given key.
getNullableAndPutAsync(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously puts into a table a new, or replaces an existing, value associated with given key.
getNullableAndRemove(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Gets and removes from a table a value associated with the given key.
getNullableAndRemoveAsync(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously gets and removes from a table a value associated with the given key.
getNullableAndReplace(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Replaces a value for a given key if it exists.
getNullableAndReplaceAsync(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously replaces a value for a given key if it exists.
getNullableAsync(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Gets a nullable value associated with a given key.
getNumSkippedRecords() - Method in class org.apache.ignite.migrationtools.persistence.mappers.SkipRecordsSchemaColumnsProcessor.SkippedRecordsStats
 
getOldOwner() - Method in interface org.apache.ignite.configuration.validation.ValidationContext
Returns a previous view of the owner of the current value.
getOldRoot(RootKey<?, ROOT, ?>) - Method in interface org.apache.ignite.configuration.validation.ValidationContext
Returns previous value of the configuration root.
getOldValue() - Method in interface org.apache.ignite.configuration.validation.ValidationContext
Returns previous value of the configuration.
getOperationTimeout() - Method in class org.apache.ignite.IgniteClientProperties
Gets operation timeout.
getOperator() - Method in class org.apache.ignite.table.criteria.Condition
Get a condition operator.
getOperator() - Method in class org.apache.ignite.table.criteria.Expression
Get a operator.
getOrCreateTraceId(Throwable) - Static method in class org.apache.ignite.lang.util.TraceIdUtils
Returns trace identifier from the provided throwable if it is an instance of TraceableException or it has a cause that is an instance of TraceableException.
getOrDefault(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Gets a value associated with a given key, if it exists and is not null, otherwise returns defaultValue.
getOrDefaultAsync(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Gets a value associated with a given key, if it exists and is not null, otherwise returns defaultValue.
getParentLogger() - Method in class org.apache.ignite.jdbc.IgniteJdbcDriver
getPassword() - Method in class org.apache.ignite.IgniteClientProperties.BasicAuthProperties
 
getPrecision(NativeType) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTableCommon
Gets type precision.
getPrimaryKeys(String, String) - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcMetadataCatalog
getProcessedElements() - Method in class org.apache.ignite.migrationtools.persistence.mappers.SchemaColumnProcessorStats
 
getProgressFilePath() - Method in class org.apache.ignite.migrationtools.cli.persistence.calls.MigrateCacheCall.Ouput
 
getPropertyDescriptor(String) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
getPropertyDescriptors() - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
getPropertyInfo(String, Properties) - Method in class org.apache.ignite.jdbc.IgniteJdbcDriver
getPropertyType(String) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
getPropertyTypeDescriptor(String) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
getPropertyValue(String) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
getRawVersion() - Method in exception org.apache.ignite.deployment.version.VersionParseException
 
getRetryPolicy() - Method in class org.apache.ignite.IgniteClientProperties
Gets retry policy.
getSchemaName() - Method in interface org.apache.ignite.migrationtools.tests.e2e.framework.core.ExampleBasedCacheTest
Case-sensitve, unquoted version of the schema, or null if not defined.
getSchemaName() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MySimpleMapCacheTest
 
getSchemaName() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
 
getSchemasMeta(String) - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcMetadataCatalog
getSslConfiguration() - Method in class org.apache.ignite.IgniteClientProperties
Gets SSL configuration.
getStats() - Method in class org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor
 
getStats() - Method in class org.apache.ignite.migrationtools.persistence.mappers.IgnoreMismatchesSchemaColumnProcessor
 
getStats() - Method in interface org.apache.ignite.migrationtools.persistence.mappers.SchemaColumnsProcessor
 
getStats() - Method in class org.apache.ignite.migrationtools.persistence.mappers.SkipRecordsSchemaColumnsProcessor
 
getTableName() - Method in interface org.apache.ignite.migrationtools.tests.e2e.framework.core.ExampleBasedCacheTest
Case-sensitve, unquoted version of the table name.
getTableName() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.ListTest
 
getTableName() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.PrimitiveTest
 
getTableName() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest.MyBinaryOrganizationCache
 
getTableName() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest.MyBinaryPersonPojoCache
 
getTableName() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest.MyBinaryTestCache
 
getTableName() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyOrganizationsCacheTest
 
getTableName() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MySimpleMapCacheTest
 
getTableName() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.PersonCacheTest
 
getTablesMeta(String, String, String[]) - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcMetadataCatalog
getUsername() - Method in class org.apache.ignite.IgniteClientProperties.BasicAuthProperties
 
getValue() - Method in class org.apache.ignite.table.criteria.Parameter
Gets parameter value.
getWrappedClass() - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
getWrappedInstance() - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
GOE - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 
greaterThan(Comparable<T>) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is greater than the specified value.
greaterThanOrEqualTo(Comparable<T>) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is greater than or equal than the specified value.
GROUP_OVERLOADED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Replicator
Replication group overloaded exception code.
groupCode() - Method in class org.apache.ignite.lang.ErrorGroup
Returns a code of this group.
groupCode() - Method in exception org.apache.ignite.lang.IgniteCheckedException
Returns an error group.
groupCode() - Method in exception org.apache.ignite.lang.IgniteException
Returns an error group.
groupCode() - Method in interface org.apache.ignite.lang.TraceableException
Returns an error group.
groupName() - Method in exception org.apache.ignite.lang.IgniteCheckedException
Returns a group name of the error.
groupName() - Method in exception org.apache.ignite.lang.IgniteException
Returns a group name of the error.
GT - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 

H

handle(ExceptionWriter, Throwable) - Method in class org.apache.ignite.migrationtools.cli.exceptions.DefaultMigrateCacheExceptionHandler
 
handle(ExceptionWriter, RecordAndTableSchemaMismatchException) - Method in class org.apache.ignite.migrationtools.cli.exceptions.RecordAndTableSchemaMismatchExceptionHandler
 
handle(ExceptionWriter, IgniteClientConnectionException) - Method in class org.apache.ignite.migrationtools.cli.exceptions.IgniteClientConnectionExceptionHandler
 
handle(ExceptionWriter, DataStreamerException) - Method in class org.apache.ignite.migrationtools.cli.exceptions.DataStreamerExceptionHandler
 
handler() - Method in class org.apache.ignite.client.handler.ClientHandlerModule
 
handlerAdded(ChannelHandlerContext) - Method in class org.apache.ignite.client.handler.ClientInboundMessageHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class org.apache.ignite.client.handler.ClientInboundMessageHandler
 
handleTestExecutionException(ExtensionContext, Throwable) - Method in class org.apache.ignite.migrationtools.handlers.SkipUnsupportedOperationsHandlers
 
HANDSHAKE_HEADER_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
Client handshake header error.
hasAllFeatures(ProtocolBitmaskFeature...) - Method in class org.apache.ignite.client.handler.ClientContext
Сhecks if all features are enabled.
hasAnnotation() - Method in class org.apache.ignite.migrationtools.types.InspectedField
 
hasDefault() - Element in annotation interface org.apache.ignite.configuration.annotation.InjectedValue
Indicates that the current configuration value has a default value.
hasDefault() - Element in annotation interface org.apache.ignite.configuration.annotation.PolymorphicId
Indicates that the field contains a default value that should be equal to one of the PolymorphicConfigInstance.value().
hasDefault() - Element in annotation interface org.apache.ignite.configuration.annotation.Value
Indicates that the current configuration value has a default value.
hasFeature(ProtocolBitmaskFeature) - Method in class org.apache.ignite.client.handler.ClientContext
Checks if a feature is enabled.
HASH - Enum constant in enum class org.apache.ignite.catalog.IndexType
 
hashCode() - Method in class org.apache.ignite.catalog.ColumnSorted
 
hashCode() - Method in class org.apache.ignite.catalog.definitions.ColumnDefinition
 
hashCode() - Method in class org.apache.ignite.catalog.definitions.IndexDefinition
 
hashCode() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
 
hashCode() - Method in class org.apache.ignite.configuration.validation.ValidationIssue
 
hashCode() - Method in class org.apache.ignite.deployment.DeploymentUnit
 
hashCode() - Method in class org.apache.ignite.example.compute.ComputeWithCustomResultMarshallerExample.WordInfoResult
hashCode() - Method in class org.apache.ignite.lang.NullableValue
hashCode() - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
hashCode() - Method in class org.apache.ignite.migrationtools.tests.models.ComplexKeyIntStr
 
hashCode() - Method in class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel.Value
 
hashCode() - Method in class org.apache.ignite.migrationtools.tests.models.SimplePojo
 
hashCode() - Method in class org.apache.ignite.migrationtools.types.InspectedField
 
hashCode() - Method in class org.apache.ignite.network.NetworkAddress
hashCode() - Method in class org.apache.ignite.network.NodeMetadata
 
hashCode() - Method in class org.apache.ignite.table.QualifiedName
hashCode() - Method in class org.apache.ignite.table.ReceiverExecutionOptions
 
hashCode() - Method in interface org.apache.ignite.table.Tuple
Returns a hash code value for the tuple.
hashCode(Tuple) - Static method in interface org.apache.ignite.table.Tuple
Returns a hash code value for the tuple.
hasMorePages() - Method in interface org.apache.ignite.lang.AsyncCursor
Indicates whether there are more pages of results.
hasNextResult() - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcQueryCursor
hasReceivedError() - Method in class org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor
 
hasRowSet() - Method in interface org.apache.ignite.sql.async.AsyncResultSet
Defines whether the result of a query is a collection of rows or not.
hasRowSet() - Method in interface org.apache.ignite.sql.ResultSet
Indicates whether the query result is a collection of rows.
HEADER - Static variable in class org.apache.ignite.migrationtools.cli.exceptions.DefaultMigrateCacheExceptionHandler
 
heartbeatInterval() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the heartbeat message interval, in milliseconds.
heartbeatInterval(long) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the heartbeat message interval, in milliseconds.
heartbeatTimeout() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the heartbeat message timeout, in milliseconds.
heartbeatTimeout(long) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the heartbeat message timeout, in milliseconds.
Holder() - Constructor for class org.apache.ignite.client.handler.ClientHandlerMetricSource.Holder
 
host() - Method in class org.apache.ignite.network.NetworkAddress
Returns the host name.
httpPort() - Method in class org.apache.ignite.network.NodeMetadata
 
httpsPort() - Method in class org.apache.ignite.network.NodeMetadata
 

I

id() - Method in interface org.apache.ignite.compute.JobState
Returns job ID.
id() - Method in interface org.apache.ignite.compute.TaskState
Returns task ID.
id() - Method in interface org.apache.ignite.network.ClusterNode
Returns the node's local ID.
id() - Method in interface org.apache.ignite.network.IgniteCluster
Returns the current cluster ID.
id() - Method in enum class org.apache.ignite.sql.ColumnType
Returns id of type.
Id - Annotation Interface in org.apache.ignite.catalog.annotations
Columns annotated with this annotation will be included in the primary key.
idAsync() - Method in interface org.apache.ignite.compute.JobExecution
Returns the id of the job.
idAsync() - Method in interface org.apache.ignite.compute.task.TaskExecution
Returns the id of the task.
identity() - Method in class org.apache.ignite.client.BasicAuthenticator
 
identity() - Method in interface org.apache.ignite.client.IgniteClientAuthenticator
Identity.
IdentityConverter<T> - Class in org.apache.ignite.migrationtools.types.converters
Identity Converter.
IdentityConverter() - Constructor for class org.apache.ignite.migrationtools.types.converters.IdentityConverter
 
idHistory() - Method in class org.apache.ignite.client.handler.ClusterInfo
Returns history of cluster IDs (oldest to newest).
idleTimeoutMillis - Variable in class org.apache.ignite.client.handler.configuration.ClientConnectorConfigurationSchema
Idle timeout.
idsAsync() - Method in interface org.apache.ignite.compute.task.TaskExecution
Returns a collection of ids of the jobs which are executing under this task.
ifNotExists() - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets not exists flag.
ifNotExists() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns not exists flag.
ifNotExists() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Sets the not exists flag.
ifNotExists() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns not exists flag.
ignite() - Method in interface org.apache.ignite.compute.JobExecutionContext
Ignite API entry point.
ignite() - Method in interface org.apache.ignite.compute.task.TaskExecutionContext
Ignite API entry point.
ignite() - Method in interface org.apache.ignite.table.DataStreamerReceiverContext
Gets the Ignite instance.
Ignite - Interface in org.apache.ignite
Ignite API entry point.
IGNITE_ERR_PREFIX - Static variable in class org.apache.ignite.lang.ErrorGroups
Additional prefix that is used in a human-readable format of ignite errors.
Ignite2ClusterContainer - Class in org.apache.ignite.migrationtools.tests.containers
Container of an Ignite 2 cluster.
Ignite2ClusterContainer(Path, Path, List<String>) - Constructor for class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterContainer
 
Ignite2ClusterContainer(Network, Path, Path, List<String>) - Constructor for class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterContainer
Constructor.
Ignite2ClusterWithSamples - Class in org.apache.ignite.migrationtools.tests.containers
Ignite2ClusterWithSamples.
Ignite2ClusterWithSamples(Path) - Constructor for class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterWithSamples
 
Ignite2ConfigurationUtils - Class in org.apache.ignite.migrationtools.config
Utility methods for managing Ignite 2 Configurations.
Ignite2PersistenceTools - Class in org.apache.ignite.migrationtools.persistence
Utility class to handle Ignite 2 persistence work dirs.
Ignite2PersistenceTools() - Constructor for class org.apache.ignite.migrationtools.persistence.Ignite2PersistenceTools
 
Ignite2PersistenceTools.NodeFolderDescriptor - Class in org.apache.ignite.migrationtools.persistence
Simple descriptor of discovered node folders.
Ignite2PersistentCacheTools - Class in org.apache.ignite.migrationtools.persistence
Utility methods to interact with Ignite 2 persistent caches.
Ignite2PersistentCacheTools() - Constructor for class org.apache.ignite.migrationtools.persistence.Ignite2PersistentCacheTools
 
Ignite2PersistentCacheTools.ColumnsProcessorFactory - Interface in org.apache.ignite.migrationtools.persistence
ColumnsProcessorFactory.
Ignite2SeedDataTest - Class in org.apache.ignite.migrationtools.tests.e2e.framework.runners
This is not really a test.
Ignite2SeedDataTest() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.framework.runners.Ignite2SeedDataTest
 
Ignite2TestBootStrap - Class in org.apache.ignite.migrationtools.tests.e2e.framework.runners
Ignite2TestBootStrap.
Ignite2TestBootStrap() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.framework.runners.Ignite2TestBootStrap
 
Ignite2TestBootStrap(Supplier<Ignite>) - Constructor for class org.apache.ignite.migrationtools.tests.e2e.framework.runners.Ignite2TestBootStrap
 
Ignite3ClusterContainer - Class in org.apache.ignite.migrationtools.tests.containers
Ignite 3 cluster container.
Ignite3ClusterContainer() - Constructor for class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
 
Ignite3ClusterContainer(Network) - Constructor for class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
Constructor.
Ignite3ConfigurationUtils - Class in org.apache.ignite.migrationtools.config
Utility methods for loading Ignite 3 Configuration Modules.
Ignite3ConfigurationUtils() - Constructor for class org.apache.ignite.migrationtools.config.Ignite3ConfigurationUtils
 
ignite3TableName(ExampleBasedCacheTest<?, ?>) - Static method in class org.apache.ignite.migrationtools.tests.e2e.framework.core.NameUtils
Fully qualified name of the test table for ignite 3.
Ignite3TestAnnotation - Annotation Interface in org.apache.ignite.migrationtools.tests.e2e.framework.core
Ignite3TestAnnotation.
IgniteCatalog - Interface in org.apache.ignite.catalog
Provides the ability to create and execute SQL DDL queries from annotated classes or fluent builders.
IgniteCheckedException - Exception in org.apache.ignite.lang
General Ignite exception.
IgniteCheckedException(int) - Constructor for exception org.apache.ignite.lang.IgniteCheckedException
Creates an exception with the given error code.
IgniteCheckedException(int, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteCheckedException
Creates an exception with the given error code and cause.
IgniteCheckedException(int, String) - Constructor for exception org.apache.ignite.lang.IgniteCheckedException
Creates an exception with the given error code and detailed message.
IgniteCheckedException(int, String, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteCheckedException
Creates an exception with the given error code, detailed message, and cause.
IgniteCheckedException(UUID, int) - Constructor for exception org.apache.ignite.lang.IgniteCheckedException
Creates an exception with the given trace ID and error code.
IgniteCheckedException(UUID, int, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteCheckedException
Creates an exception with the given trace ID, error code, and cause.
IgniteCheckedException(UUID, int, String) - Constructor for exception org.apache.ignite.lang.IgniteCheckedException
Creates an exception with the given trace ID, error code, and detailed message.
IgniteCheckedException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteCheckedException
Creates an exception with the given trace ID, error code, detailed message, and cause.
IgniteClient - Interface in org.apache.ignite.client
Ignite client entry point.
IgniteClient.Builder - Class in org.apache.ignite.client
Client builder.
IgniteClientAddressFinder - Interface in org.apache.ignite.client
Provides a list of Ignite node addresses.
IgniteClientAuthenticator - Interface in org.apache.ignite.client
Ignite client authenticator.
IgniteClientAuthenticatorParams - Class in org.apache.ignite.migrationtools.cli.persistence.params
IgniteClient Authenticator parameters.
IgniteClientAuthenticatorParams() - Constructor for class org.apache.ignite.migrationtools.cli.persistence.params.IgniteClientAuthenticatorParams
 
IgniteClientAutoConfiguration - Class in org.apache.ignite
Auto-configuration for Apache Ignite 3 client.
IgniteClientAutoConfiguration() - Constructor for class org.apache.ignite.IgniteClientAutoConfiguration
 
IgniteClientConfiguration - Interface in org.apache.ignite.client
Ignite client configuration.
IgniteClientConnectionException - Exception in org.apache.ignite.client
Indicates all the Ignite servers specified in the client configuration are no longer available.
IgniteClientConnectionException(int, String, String) - Constructor for exception org.apache.ignite.client.IgniteClientConnectionException
Constructs a new exception with the specified detail message.
IgniteClientConnectionException(int, String, String, Throwable) - Constructor for exception org.apache.ignite.client.IgniteClientConnectionException
Constructs a new exception with the specified cause and detail message.
IgniteClientConnectionException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.client.IgniteClientConnectionException
Constructs a new exception with the specified cause and detail message.
IgniteClientConnectionExceptionHandler - Class in org.apache.ignite.migrationtools.cli.exceptions
Simple exception handler for IgniteClientConnectionException.
IgniteClientConnectionExceptionHandler() - Constructor for class org.apache.ignite.migrationtools.cli.exceptions.IgniteClientConnectionExceptionHandler
 
IgniteClientExample - Class in org.apache.ignite.example.client
This example demonstrates the usage of the basic client API without any fine-tuning.
IgniteClientExample() - Constructor for class org.apache.ignite.example.client.IgniteClientExample
 
IgniteClientFeatureNotSupportedByServerException - Exception in org.apache.ignite.client
Indicates that thin client feature is not supported by the server.
IgniteClientFeatureNotSupportedByServerException(String) - Constructor for exception org.apache.ignite.client.IgniteClientFeatureNotSupportedByServerException
Constructs a new exception with the specified missing feature.
IgniteClientFeatureNotSupportedByServerException(String, Throwable) - Constructor for exception org.apache.ignite.client.IgniteClientFeatureNotSupportedByServerException
Constructs a new exception with the specified cause and detail message.
IgniteClientProperties - Class in org.apache.ignite
Describes properties for Ignite client.
IgniteClientProperties() - Constructor for class org.apache.ignite.IgniteClientProperties
 
IgniteClientProperties.AuthenticationProperties - Class in org.apache.ignite
Authentication configuration properties.
IgniteClientProperties.BasicAuthProperties - Class in org.apache.ignite
Basic authentication properties.
IgniteClientPropertiesCustomizer - Interface in org.apache.ignite
Interface that can be implemented by beans wishing to customize the auto-configured IgniteClientProperties.
IgniteClientWithConfigExample - Class in org.apache.ignite.example.client
This example demonstrates the usage of the basic client API with additional configuration parameters.
IgniteClientWithConfigExample() - Constructor for class org.apache.ignite.example.client.IgniteClientWithConfigExample
 
IgniteCluster - Interface in org.apache.ignite.network
Represents an Ignite cluster, providing access to the cluster nodes and the local node.
IgniteCompute - Interface in org.apache.ignite.compute
Provides the ability to execute Compute jobs.
IgniteDialect - Class in org.apache.ignite.data
Implementation of Ignite-specific dialect.
IgniteDialectProvider - Class in org.apache.ignite.data
Provider for Ignite-specific dialect.
IgniteDialectProvider() - Constructor for class org.apache.ignite.data.IgniteDialectProvider
 
IgniteException - Exception in org.apache.ignite.lang
General Ignite exception.
IgniteException(int) - Constructor for exception org.apache.ignite.lang.IgniteException
Creates an exception with the given error code.
IgniteException(int, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteException
Creates an exception with the given error code and cause.
IgniteException(int, String) - Constructor for exception org.apache.ignite.lang.IgniteException
Creates an exception with the given error code and detailed message.
IgniteException(int, String, boolean) - Constructor for exception org.apache.ignite.lang.IgniteException
Creates an exception with the given error code and detailed message with the ability to skip filling in the stacktrace.
IgniteException(int, String, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteException
Creates an exception with the given error code, detailed message, and cause.
IgniteException(UUID, int) - Constructor for exception org.apache.ignite.lang.IgniteException
Creates an exception with the given trace ID and error code.
IgniteException(UUID, int, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteException
Creates an exception with the given trace ID, error code, and cause.
IgniteException(UUID, int, String) - Constructor for exception org.apache.ignite.lang.IgniteException
Creates an exception with the given trace ID, error code, and detailed message.
IgniteException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteException
Creates an exception with the given trace ID, error code, detailed message, and cause.
IgniteException(UUID, int, String, Throwable, boolean, boolean) - Constructor for exception org.apache.ignite.lang.IgniteException
Creates an exception with the given trace ID, error code, and detailed message.
IgniteJdbcDriver - Class in org.apache.ignite.jdbc
JDBC driver implementation for Apache Ignite 3.x.
IgniteJdbcDriver() - Constructor for class org.apache.ignite.jdbc.IgniteJdbcDriver
 
IgniteNameUtils - Class in org.apache.ignite.lang.util
Utility methods used for cluster's named objects: schemas, tables, columns, indexes, etc.
IgniteServer - Interface in org.apache.ignite
Embedded Ignite node.
IgniteServer.Builder - Class in org.apache.ignite
Builder for IgniteServer.
IgniteSql - Interface in org.apache.ignite.sql
Ignite SQL query facade.
IgniteTables - Interface in org.apache.ignite.table
Interface that provides methods for managing tables.
IgniteTransactionDefaults - Class in org.apache.ignite.tx
Utility class containing transaction default constants.
IgniteTransactionDefaults() - Constructor for class org.apache.ignite.tx.IgniteTransactionDefaults
 
IgniteTransactions - Interface in org.apache.ignite.tx
The Ignite Transactions facade that supports distributed transactions when working with tables.
IGNORE_COLUMN - Enum constant in enum class org.apache.ignite.migrationtools.cli.persistence.params.MigrationMode
Any additional columns/fields in the cache record will be ignored (not migrated to the table; lost).
IgnoredColumnsStats(long, Map<String, Long>) - Constructor for class org.apache.ignite.migrationtools.persistence.mappers.IgnoreMismatchesSchemaColumnProcessor.IgnoredColumnsStats
 
IgnoreMismatchesSchemaColumnProcessor - Class in org.apache.ignite.migrationtools.persistence.mappers
Provides a mapping layer between Ignite 2 Tuples (created from Binary Objects) and a Ignite 3 table schema.
IgnoreMismatchesSchemaColumnProcessor(ClientSchema, Map<String, String>, TypeConverterFactory) - Constructor for class org.apache.ignite.migrationtools.persistence.mappers.IgnoreMismatchesSchemaColumnProcessor
 
IgnoreMismatchesSchemaColumnProcessor.IgnoredColumnsStats - Class in org.apache.ignite.migrationtools.persistence.mappers
IgnoredColumnsStats.
ILLEGAL_ARGUMENT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
Illegal argument or argument in a wrong format has been passed.
ILLEGAL_NODES_SET_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
Error when node names are not in valid set.
ILLEGAL_PARTITION_ID_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
Partition ID is not in valid range.
Immutable - Annotation Interface in org.apache.ignite.configuration.validation
Signifies that this value can only be initialized and can't be changed afterwards.
in(byte[]...) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is is found within the specified collection.
in(Comparable<T>...) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is is found within the specified collection.
IN - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 
includeDefaults() - Method in class org.apache.ignite.migrationtools.cli.configs.calls.ConfigurationConverterCall.Input
 
IncompatibleSchemaException - Exception in org.apache.ignite.tx
Thrown when, during an attempt to execute a transactional operation, it turns out that the operation cannot be executed because an incompatible schema change has happened.
IncompatibleSchemaException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.tx.IncompatibleSchemaException
Constructs a new instance of IncompatibleSchemaException.
index(String, IndexType, List<ColumnSorted>) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Adds an index on this table using specified columns with sort order and index type.
index(String, IndexType, ColumnSorted...) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Adds an index on this table using specified columns with sort order and index type.
index(String...) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Adds an index on this table using specified columns and default index type and sort order.
Index - Annotation Interface in org.apache.ignite.catalog.annotations
Describes an index.
Index() - Constructor for class org.apache.ignite.lang.ErrorGroups.Index
Deprecated.
 
INDEX_ALREADY_EXISTS_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Index
Deprecated.
INDEX_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Index
Deprecated.
INDEX_NOT_BUILT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Storage
Error reading from an index that has not yet been built.
INDEX_NOT_FOUND_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Index
Deprecated.
IndexAlreadyExistsException - Exception in org.apache.ignite.lang
Deprecated.
No longer used. Use SqlException with ErrorGroups.Sql.STMT_VALIDATION_ERR error code.
IndexAlreadyExistsException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.IndexAlreadyExistsException
Deprecated.
Creates an exception with the given trace ID, error code, detailed message, and cause.
IndexAlreadyExistsException(QualifiedName) - Constructor for exception org.apache.ignite.lang.IndexAlreadyExistsException
Deprecated.
Creates an exception with the given index name.
IndexDefinition - Class in org.apache.ignite.catalog.definitions
Definition of the CREATE INDEX statement.
indexes() - Element in annotation interface org.apache.ignite.catalog.annotations.Table
Indexes to create on this table.
indexes() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns a list of indexes to create on this table.
IndexNotFoundException - Exception in org.apache.ignite.lang
Deprecated.
No longer used. Use SqlException with ErrorGroups.Sql.STMT_VALIDATION_ERR error code.
IndexNotFoundException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.IndexNotFoundException
Deprecated.
Creates a new exception with the given trace ID, error code, detailed message, and cause.
IndexNotFoundException(UUID, String, Throwable) - Constructor for exception org.apache.ignite.lang.IndexNotFoundException
Deprecated.
Creates an exception with the given trace ID, error code, detailed message, and cause.
IndexNotFoundException(QualifiedName) - Constructor for exception org.apache.ignite.lang.IndexNotFoundException
Deprecated.
Creates an exception with the given index name.
indexOf(String) - Method in interface org.apache.ignite.sql.ResultSetMetadata
Returns a column index for the column with a given name.
IndexType - Enum Class in org.apache.ignite.catalog
Type of the index to create.
initCluster(InitParameters) - Method in interface org.apache.ignite.IgniteServer
Initializes the cluster that the given node is present in synchronously.
initClusterAsync(InitParameters) - Method in interface org.apache.ignite.IgniteServer
Initializes the cluster that the given node is present in.
initialize() - Static method in class org.apache.ignite.lang.ErrorGroups
Initializes and register all error groups and error codes.
InitParameters - Class in org.apache.ignite
Initialization parameters.
InitParametersBuilder - Class in org.apache.ignite
Builder of InitParameters.
InitParametersBuilder() - Constructor for class org.apache.ignite.InitParametersBuilder
 
InjectedName - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation marks a configuration schema field as special (read-only) for getting the key associated with the configuration in the named list.
InjectedValue - Annotation Interface in org.apache.ignite.configuration.annotation
This annotations is intended to be placed on NamedConfigValue elements to emulate key-value pairs in configuration schemas.
Input(Path, Path, boolean, boolean, ClassLoader) - Constructor for class org.apache.ignite.migrationtools.cli.sql.calls.SqlDdlGeneratorCall.Input
Constructor.
Input(Path, Path, Path, boolean, ClassLoader) - Constructor for class org.apache.ignite.migrationtools.cli.configs.calls.ConfigurationConverterCall.Input
Contructor.
Input(PersistenceParams) - Constructor for class org.apache.ignite.migrationtools.cli.persistence.calls.ListCachesCall.Input
 
Input(PersistenceParams, MigrateCacheParams, IgniteClientAuthenticatorParams) - Constructor for class org.apache.ignite.migrationtools.cli.persistence.calls.MigrateCacheCall.Input
Constructor.
Input(PersistenceParams, MigrateCacheParams, RetrieableMigrateCacheParams, IgniteClientAuthenticatorParams) - Constructor for class org.apache.ignite.migrationtools.cli.persistence.calls.RetriableMigrateCacheCall.Input
Constructor.
inputConfigFilePath() - Method in class org.apache.ignite.migrationtools.cli.configs.calls.ConfigurationConverterCall.Input
 
inputMarshaller() - Method in interface org.apache.ignite.compute.ComputeJob
Marshaller for the input argument.
inputMarshaller() - Method in class org.apache.ignite.example.serialization.CustomPojoSerializationJob
 
insert(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Inserts a record into a table if it does not exists.
insertAll(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Inserts into a table records that do not exist, skips those that exist.
insertAllAsync(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Asynchronously inserts into a table records that do not exist, skips those that exist.
insertAsync(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Asynchronously inserts a record into a table if it does not exists.
InspectedField - Class in org.apache.ignite.migrationtools.types
Holds information about how a field should be persisted.
InspectedFieldType - Enum Class in org.apache.ignite.migrationtools.types
InspectedFieldTypeEnum.
inspectType(Class<?>) - Static method in class org.apache.ignite.migrationtools.types.TypeInspector
Inspects the given class, extracting information about how its fields should be persisted.
INSTANCE - Static variable in class org.apache.ignite.data.IgniteDialect
Singleton instance.
INSTANCE - Static variable in class org.apache.ignite.migrationtools.cli.exceptions.DefaultMigrateCacheExceptionHandler
 
INSTANCE - Static variable in class org.apache.ignite.migrationtools.cli.exceptions.RecordAndTableSchemaMismatchExceptionHandler
 
INSTANCE - Static variable in class org.apache.ignite.migrationtools.types.converters.IdentityConverter
 
instantiateBean(String, RootBeanDefinition) - Method in class org.apache.ignite.migrationtools.config.loader.CustomBeanFactory
 
INT16 - Enum constant in enum class org.apache.ignite.sql.ColumnType
16-bit signed integer.
INT16 - Static variable in class org.apache.ignite.catalog.ColumnType
16-bit signed integer.
INT32 - Enum constant in enum class org.apache.ignite.sql.ColumnType
32-bit signed integer.
INT32 - Static variable in class org.apache.ignite.catalog.ColumnType
32-bit signed integer.
INT64 - Enum constant in enum class org.apache.ignite.sql.ColumnType
64-bit signed integer.
INT64 - Static variable in class org.apache.ignite.catalog.ColumnType
64-bit signed integer.
INT8 - Enum constant in enum class org.apache.ignite.sql.ColumnType
8-bit signed integer.
INT8 - Static variable in class org.apache.ignite.catalog.ColumnType
8-bit signed integer.
IntArrayCachesTest - Class in org.apache.ignite.migrationtools.tests.e2e.impl
IntArrayCachesTest.
IntArrayCachesTest() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest
 
IntArrayCachesTest.ListTest - Class in org.apache.ignite.migrationtools.tests.e2e.impl
ListTest.
IntArrayCachesTest.PrimitiveTest - Class in org.apache.ignite.migrationtools.tests.e2e.impl
PrimitiveTest.
INTEGER - Static variable in class org.apache.ignite.catalog.ColumnType
INTEGER SQL column type.
IntegerDecrementJob - Class in org.apache.ignite.example.serialization
 
IntegerDecrementJob() - Constructor for class org.apache.ignite.example.serialization.IntegerDecrementJob
 
InterceptingFieldsModel - Class in org.apache.ignite.migrationtools.tests.models
Provides two models with intercepting field names.
InterceptingFieldsModel() - Constructor for class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel
 
InterceptingFieldsModel.Key - Class in org.apache.ignite.migrationtools.tests.models
Key model.
InterceptingFieldsModel.Value - Class in org.apache.ignite.migrationtools.tests.models
Value model.
internal() - Element in annotation interface org.apache.ignite.configuration.annotation.ConfigurationExtension
Controls whether this configuration is part of the public configuration or is hidden from the end user.
internal() - Method in class org.apache.ignite.configuration.RootKey
Check if the root configuration is marked with ConfigurationExtension and ConfigurationExtension.internal() is true.
INTERNAL_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
This error code represents an internal error caused by faulty logic or coding in the Ignite codebase.
InternalId - Annotation Interface in org.apache.ignite.configuration.annotation
Internal id.
internalIds() - Method in interface org.apache.ignite.configuration.NamedConfigurationTree
Returns all internal ids of the elements from the list.
intValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
intValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a int column value.
intValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
intValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a int column value.
INVALID_CREDENTIALS_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Authentication
Authentication error caused by invalid credentials.
InvalidCredentialsException - Exception in org.apache.ignite.security.exception
Exception thrown when authentication fails due to invalid credentials.
InvalidCredentialsException(String) - Constructor for exception org.apache.ignite.security.exception.InvalidCredentialsException
Creates a new authentication exception.
InvalidProgressFileException(String) - Constructor for exception org.apache.ignite.migrationtools.cli.persistence.calls.MigrateCacheCall.InvalidProgressFileException
 
IS_NOT_NULL - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 
IS_NULL - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 
isActive() - Method in class org.apache.ignite.example.streaming.Account
 
isAutoGrowNestedPaths() - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
isCancelled() - Method in interface org.apache.ignite.compute.JobExecutionContext
Flag indicating whether the job was cancelled.
isCancelled() - Method in interface org.apache.ignite.compute.task.TaskExecutionContext
Flag indicating whether the task was cancelled.
isCancelled() - Method in interface org.apache.ignite.lang.CancelHandle
Flag indicating whether cancellation was requested or not.
isCancelled(CancellationToken) - Static method in class org.apache.ignite.lang.CancelHandleHelper
Flag indicating whether cancellation was requested or not.
isEmpty() - Method in interface org.apache.ignite.configuration.NamedListView
Returns the true if this list is empty.
isEmpty() - Method in class org.apache.ignite.sql.BatchedArguments
Returns true if this batch contains is empty.
isExtractOldValueForEditor() - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
isExtraFieldsColumn(ClientColumn) - Static method in class org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor
 
isMetricsEnabled() - Method in class org.apache.ignite.IgniteClientProperties
Returns true if metrics enabled.
isReadableProperty(String) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
isReadOnly() - Method in interface org.apache.ignite.tx.Transaction
Returns {code true} if given transaction is a read-only, false otherwise.
isTableFromNamespace(String) - Static method in class org.apache.ignite.migrationtools.tablemanagement.Namespace
Check if the provided table name is inside our namespace.
isValidNormalizedIdentifier(String) - Static method in class org.apache.ignite.lang.util.IgniteNameUtils
Returns true if given string is valid normalized identifier, false otherwise.
isWritableProperty(String) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
iteration() - Method in interface org.apache.ignite.client.RetryPolicyContext
Gets the current iteration number (zero-based).
iterator() - Method in interface org.apache.ignite.configuration.NamedListView
 
iterator() - Method in class org.apache.ignite.sql.BatchedArguments
Returns an iterator over the elements in this batch.
iterator() - Method in interface org.apache.ignite.table.Tuple

J

JAVA_EMBEDDED - Enum constant in enum class org.apache.ignite.compute.JobExecutorType
Embedded Java job executor.
javaClass() - Method in enum class org.apache.ignite.sql.ColumnType
Appropriate java match type.
jdbcCompliant() - Method in class org.apache.ignite.jdbc.IgniteJdbcDriver
JdbcMetadataCatalog - Class in org.apache.ignite.client.handler.requests.jdbc
Facade over IgniteTables to get information about database entities in terms of JDBC.
JdbcMetadataCatalog(ClockService, SchemaSyncService, CatalogService) - Constructor for class org.apache.ignite.client.handler.requests.jdbc.JdbcMetadataCatalog
Initializes info.
JdbcQueryCursor<T> - Class in org.apache.ignite.client.handler.requests.jdbc
Jdbc query cursor with the ability to limit the maximum number of rows returned.
JdbcQueryCursor(int, AsyncSqlCursor<T>) - Constructor for class org.apache.ignite.client.handler.requests.jdbc.JdbcQueryCursor
Constructor.
JdbcQueryCursorHandlerImpl - Class in org.apache.ignite.client.handler
Jdbc query event handler implementation.
JdbcQueryEventHandlerImpl - Class in org.apache.ignite.client.handler
Jdbc query event handler implementation.
JdbcQueryEventHandlerImpl(QueryProcessor, JdbcMetadataCatalog, ClientResourceRegistry, TxManager) - Constructor for class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
Constructor.
JdbcTestBootstrap - Class in org.apache.ignite.migrationtools.tests.e2e.framework.runners
JDBCTestBootstrap.
JdbcTestBootstrap() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.framework.runners.JdbcTestBootstrap
Constructor.
JdbcTestBootstrap(String) - Constructor for class org.apache.ignite.migrationtools.tests.e2e.framework.runners.JdbcTestBootstrap
 
jdbcTests() - Method in interface org.apache.ignite.migrationtools.tests.e2e.framework.core.ExampleBasedCacheTest
This method exposes references to JDBC Tests.
jdbcTests() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest.MyBinaryTestCache
 
jdbcTests() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
 
jobClassName() - Method in class org.apache.ignite.compute.JobDescriptor
Job class name.
jobDescriptor() - Method in class org.apache.ignite.compute.task.MapReduceJob
Job descriptor.
jobDescriptor(JobDescriptor<T, R>) - Method in class org.apache.ignite.compute.task.MapReduceJob.ComputeJobRunnerBuilder
Sets job descriptor.
JobDescriptor<T,R> - Class in org.apache.ignite.compute
Compute job descriptor.
JobDescriptor.Builder<T,R> - Class in org.apache.ignite.compute
Builder.
JobExecution<R> - Interface in org.apache.ignite.compute
Job control object, provides information about the job execution process and result, allows cancelling the job.
JobExecutionContext - Interface in org.apache.ignite.compute
Context of the ComputeJob execution.
JobExecutionOptions - Class in org.apache.ignite.compute
Job execution options.
JobExecutionOptions.Builder - Class in org.apache.ignite.compute
JobExecutionOptions builder.
JobExecutorType - Enum Class in org.apache.ignite.compute
Job executor type.
JobState - Interface in org.apache.ignite.compute
Job state.
JobStatus - Enum Class in org.apache.ignite.compute
Compute job's status.
JobTarget - Interface in org.apache.ignite.compute
Job execution target.
JsonArg - Class in org.apache.ignite.example.serialization
 
JsonArg() - Constructor for class org.apache.ignite.example.serialization.JsonArg
 
JsonResult - Class in org.apache.ignite.example.serialization
 
JsonResult() - Constructor for class org.apache.ignite.example.serialization.JsonResult
 

K

key() - Method in class org.apache.ignite.compute.ColocatedJobTarget
 
key() - Method in interface org.apache.ignite.configuration.ConfigurationProperty
Get key of this node.
key() - Method in class org.apache.ignite.configuration.RootKey
Returns the name of the configuration root.
key() - Method in class org.apache.ignite.configuration.validation.ValidationIssue
Returns configuration key that did not pass the validation.
key(Class<?>) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets key class to generate columns.
Key() - Constructor for class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel.Key
 
Key(int, int) - Constructor for class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel.Key
Constructor.
key1() - Method in class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel.Key
 
key1() - Method in class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel.Value
 
key2() - Method in class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel.Key
 
key2() - Method in class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel.Value
 
keyClass() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns a class to use to generate columns.
keyClassName() - Method in class org.apache.ignite.migrationtools.tablemanagement.TableTypeDescriptor
 
keyFieldNameForColumn() - Method in class org.apache.ignite.migrationtools.tablemanagement.TableTypeDescriptor
 
KeyIgnorer - Interface in org.apache.ignite.configuration
Determines if key should be ignored while processing configuration.
keyMapper() - Method in class org.apache.ignite.compute.ColocatedJobTarget
 
keyMapper() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
 
keyStorePassword() - Method in interface org.apache.ignite.client.SslConfiguration
Keystore password that will be used to setup the SSL connection.
keyStorePassword() - Method in class org.apache.ignite.SslConfigurationProperties
 
keyStorePassword(String) - Method in class org.apache.ignite.client.SslConfiguration.Builder
Keystore password setter.
keyStorePath() - Method in interface org.apache.ignite.client.SslConfiguration
Keystore path that will be used to setup the SSL connection.
keyStorePath() - Method in class org.apache.ignite.SslConfigurationProperties
 
keyStorePath(String) - Method in class org.apache.ignite.client.SslConfiguration.Builder
Keystore path setter.
keyValueView() - Method in interface org.apache.ignite.table.Table
Gets a key-value view of the table.
keyValueView(Class<K>, Class<V>) - Method in interface org.apache.ignite.table.Table
Gets a key-value view of the table using the default mapper for the specified key and value classes.
keyValueView(Mapper<K>, Mapper<V>) - Method in interface org.apache.ignite.table.Table
Gets a key-value view of the table using the specified key-value class mappers.
KeyValueView<K,V> - Interface in org.apache.ignite.table
Key-Value view of a table provides methods to access table records.
KeyValueViewExample - Class in org.apache.ignite.example.table
This example demonstrates the usage of the KeyValueView API.
KeyValueViewExample() - Constructor for class org.apache.ignite.example.table.KeyValueViewExample
 
KeyValueViewPojoExample - Class in org.apache.ignite.example.table
This example demonstrates the usage of the KeyValueView API with user-defined POJOs.
KeyValueViewPojoExample() - Constructor for class org.apache.ignite.example.table.KeyValueViewPojoExample
 

L

LATEST - Static variable in interface org.apache.ignite.deployment.version.Version
Implementation of Version interface with special latest logic.
legacyNames() - Element in annotation interface org.apache.ignite.configuration.annotation.PublicName
An array of old deprecated names for the configuration.
length() - Element in annotation interface org.apache.ignite.catalog.annotations.Column
The length of the string type.
length() - Method in class org.apache.ignite.catalog.ColumnType
Returns length of the column type.
length(Integer) - Method in class org.apache.ignite.catalog.ColumnType
Sets length for this column type.
lengthAllowed() - Method in enum class org.apache.ignite.sql.ColumnType
If true length need to be specified, false otherwise.
lessThan(Comparable<T>) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is less than the specified value.
lessThanOrEqualTo(Comparable<T>) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is less than or equal than the specified value.
limit() - Method in class org.apache.ignite.data.IgniteDialect
 
ListCachesCall - Class in org.apache.ignite.migrationtools.cli.persistence.calls
Call to the List Caches Command.
ListCachesCall() - Constructor for class org.apache.ignite.migrationtools.cli.persistence.calls.ListCachesCall
 
ListCachesCall.Input - Class in org.apache.ignite.migrationtools.cli.persistence.calls
Input.
ListCachesCall.Output - Class in org.apache.ignite.migrationtools.cli.persistence.calls
Output.
ListCachesCmd - Class in org.apache.ignite.migrationtools.cli.persistence.commands
List Caches command.
ListCachesCmd() - Constructor for class org.apache.ignite.migrationtools.cli.persistence.commands.ListCachesCmd
 
listen(ConfigurationListener<VIEWT>) - Method in interface org.apache.ignite.configuration.ConfigurationProperty
Adds configuration values listener.
listenAddresses - Variable in class org.apache.ignite.client.handler.configuration.ClientConnectorConfigurationSchema
Addresses (IPs or hostnames) to listen on.
listenElements(ConfigurationNamedListListener<VIEWT>) - Method in interface org.apache.ignite.configuration.NamedConfigurationTree
Add named-list-specific configuration values listener.
ListTest() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.ListTest
 
loadAllDescriptors() - Method in class org.apache.ignite.migrationtools.persistence.MigrationCacheProcessor
Load all descriptors.
loadClusterConfiguration(Path, boolean) - Static method in class org.apache.ignite.migrationtools.config.Ignite3ConfigurationUtils
Loads a Configuration Registry with only Cluster modules.
loadCombinedRegistry(Path, Path, boolean) - Static method in class org.apache.ignite.migrationtools.config.Ignite3ConfigurationUtils
Loads a special combined registry with modules from both the Cluster and Node modules.
loadIgnite2Configuration(File, boolean) - Static method in class org.apache.ignite.migrationtools.config.Ignite2ConfigurationUtils
 
loadIgnite2Configuration(File, boolean, ClassLoader) - Static method in class org.apache.ignite.migrationtools.config.Ignite2ConfigurationUtils
 
loadIgnite2Configuration(Resource, DefaultListableBeanFactory, ClassLoader) - Static method in class org.apache.ignite.migrationtools.config.Ignite2ConfigurationUtils
Load and Apache Ignite 2 configuration into memory.
loadNodeConfiguration(Path, boolean) - Static method in class org.apache.ignite.migrationtools.config.Ignite3ConfigurationUtils
Loads a Configuration Registry with only Node modules.
LOCAL - Enum constant in enum class org.apache.ignite.configuration.annotation.ConfigurationType
Local configuration.
localAddress() - Method in class org.apache.ignite.client.handler.ClientHandlerModule
Returns the local address where this handler is bound to.
localNode() - Method in interface org.apache.ignite.network.IgniteCluster
Returns the local cluster node if available.
lock() - Method in class org.apache.ignite.data.IgniteDialect
 
LOE - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 
loggerFactory() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Returns the logger factory.
loggerFactory(LoggerFactory) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the logger factory.
LoggerFactory - Interface in org.apache.ignite.lang
An interface describing a factory to create a logger instance.
longValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
longValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a long column value.
longValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
longValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a long column value.
LT - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 

M

main(String[]) - Static method in class org.apache.ignite.customizer.example.ExampleApplicationWithCustomAuthenticator
 
main(String[]) - Static method in class org.apache.ignite.example.client.IgniteClientExample
 
main(String[]) - Static method in class org.apache.ignite.example.client.IgniteClientWithConfigExample
 
main(String[]) - Static method in class org.apache.ignite.example.code.deployment.CodeDeploymentExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.compute.ComputeAsyncExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.compute.ComputeBroadcastExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.compute.ComputeCancellationExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.compute.ComputeColocatedExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.compute.ComputeExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.compute.ComputeJobPriorityExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.compute.ComputeJobStateExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.compute.ComputeMapReduceExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.compute.ComputeWithCustomResultMarshallerExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.compute.ComputeWithResultExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.ExampleApplication
 
main(String[]) - Static method in class org.apache.ignite.example.serialization.SerializationExample
 
main(String[]) - Static method in class org.apache.ignite.example.sql.jdbc.SqlJdbcExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.sql.SqlApiExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.storage.PersistentPageMemoryStorageExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.storage.RocksDbStorageExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.storage.VolatilePageMemoryStorageExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.streaming.DetectFailedEntriesExample
 
main(String[]) - Static method in class org.apache.ignite.example.streaming.DistributedComputeWithReceiverExample
 
main(String[]) - Static method in class org.apache.ignite.example.streaming.MultiTableDataStreamerExample
 
main(String[]) - Static method in class org.apache.ignite.example.streaming.SingleTableDataStreamerExample
 
main(String[]) - Static method in class org.apache.ignite.example.table.KeyValueViewExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.table.KeyValueViewPojoExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.table.MapperExample
 
main(String[]) - Static method in class org.apache.ignite.example.table.QueryExample
 
main(String[]) - Static method in class org.apache.ignite.example.table.RecordViewExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.table.RecordViewPojoExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.table.TableExample
Main method of the example.
main(String[]) - Static method in class org.apache.ignite.example.tx.TransactionsExample
 
main(String[]) - Static method in class org.apache.ignite.migrationtools.cli.Main
Entry point.
Main - Class in org.apache.ignite.migrationtools.cli
Main.
Main() - Constructor for class org.apache.ignite.migrationtools.cli.Main
 
map(String, String, String...) - Method in class org.apache.ignite.table.mapper.MapperBuilder
Maps a field to a column.
map(String, String, TypeConverter<ObjectT, ColumnT>) - Method in class org.apache.ignite.table.mapper.MapperBuilder
Maps a field to a column using a type converter.
mappedColumn() - Method in interface org.apache.ignite.table.mapper.OneColumnMapper
Returns a name of the column the object is mapped to or null if not specified.
Mapper<T> - Interface in org.apache.ignite.table.mapper
Mapper interface defines marshaller methods for mapping class field names to table columns.
MapperBuilder<T> - Class in org.apache.ignite.table.mapper
Mapper builder provides methods for mapping object fields to columns.
MapperExample - Class in org.apache.ignite.example.table
 
MapperExample() - Constructor for class org.apache.ignite.example.table.MapperExample
 
MAPPING_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
SQL engine was unable to map query on current cluster topology.
MapReduceJob<T,R> - Class in org.apache.ignite.compute.task
A description of the job to be submitted as a result of the split step of the MapReduceTask.
MapReduceJob.ComputeJobRunnerBuilder<T,R> - Class in org.apache.ignite.compute.task
Job submit parameters builder.
MapReduceTask<I,M,T,R> - Interface in org.apache.ignite.compute.task
A map reduce task interface.
marshal(T) - Method in interface org.apache.ignite.marshalling.ByteArrayMarshaller
 
marshal(T) - Method in interface org.apache.ignite.marshalling.Marshaller
Marshal the object into raw type.
Marshaller<T,R> - Interface in org.apache.ignite.marshalling
Object marshaller interface that is used in every Ignite API that requires serialization/deserialization of user objects.
MarshallerException - Exception in org.apache.ignite.lang
This exception is caused by a failure to marshall or unmarshall a value.
MarshallerException(String) - Constructor for exception org.apache.ignite.lang.MarshallerException
Creates a new exception with the given error message.
MarshallerException(String, Throwable) - Constructor for exception org.apache.ignite.lang.MarshallerException
Creates a new exception with the given error message.
MarshallerException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.MarshallerException
Creates an exception with the given trace ID, error code, detailed message, and cause.
Marshalling() - Constructor for class org.apache.ignite.lang.ErrorGroups.Marshalling
 
MARSHALLING_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Marshalling
Marshalling error group.
MARSHALLING_TYPE_MISMATCH_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Incompatible types for argument/result in compute job.
MarshallingException - Exception in org.apache.ignite.marshalling
Exception thrown when an object type is not supported by the marshaller.
MarshallingException(String, Throwable) - Constructor for exception org.apache.ignite.marshalling.MarshallingException
Creates an exception with the given message and cause.
MarshallingException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.marshalling.MarshallingException
Creates an exception with the given trace ID, error code, detailed message, and cause.
max() - Element in annotation interface org.apache.ignite.configuration.validation.Range
Returns the upper bound for the value.
maxRetries() - Method in class org.apache.ignite.compute.JobExecutionOptions
Gets the number of times to retry job execution in case of failure.
maxRetries() - Method in class org.apache.ignite.table.ReceiverExecutionOptions
Gets the number of times to retry receiver execution in case of failure.
maxRetries(int) - Method in class org.apache.ignite.compute.JobExecutionOptions.Builder
Sets the number of times to retry job execution in case of failure.
maxRetries(int) - Method in class org.apache.ignite.table.ReceiverExecutionOptions.Builder
Sets the number of times to retry receiver execution in case of failure.
merge(InternalTable, int, String, long, InternalTransaction, boolean) - Static method in class org.apache.ignite.client.handler.requests.tx.ClientTransactionCommitRequest
Attempts to merge server and client enlistments.
message() - Method in class org.apache.ignite.configuration.validation.ValidationIssue
Returns error message.
META_STORAGE_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.MetaStorage
Meta storage error group.
metadata() - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcQueryCursor
metadata() - Method in interface org.apache.ignite.sql.async.AsyncResultSet
Returns metadata for query results.
metadata() - Method in interface org.apache.ignite.sql.ResultSet
Returns metadata for the results if the result contains rows (if ResultSet.hasRowSet() returns true).
metadata() - Method in interface org.apache.ignite.sql.SqlRow
Result set columns' metadata.
MetaStorage() - Constructor for class org.apache.ignite.lang.ErrorGroups.MetaStorage
 
metaStorageNodeNames() - Method in class org.apache.ignite.InitParameters
 
metaStorageNodeNames(String...) - Method in class org.apache.ignite.InitParametersBuilder
Sets names of nodes that will host the Meta Storage.
metaStorageNodeNames(Collection<String>) - Method in class org.apache.ignite.InitParametersBuilder
Sets names of nodes that will host the Meta Storage.
metaStorageNodes(Collection<IgniteServer>) - Method in class org.apache.ignite.InitParametersBuilder
Sets nodes that will host the Meta Storage.
metaStorageNodes(IgniteServer...) - Method in class org.apache.ignite.InitParametersBuilder
Sets nodes that will host the Meta Storage.
metrics() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource.Holder
 
metricsEnabled - Variable in class org.apache.ignite.client.handler.configuration.ClientConnectorConfigurationSchema
Metrics.
metricsEnabled() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets a value indicating whether JMX metrics are enabled.
metricsEnabled(boolean) - Method in class org.apache.ignite.client.IgniteClient.Builder
Enables or disables JMX metrics.
migrateCache(MigrationToolsContainer, int, String, String, String, Map.Entry<String, String>, Path) - Static method in class org.apache.ignite.migrationtools.tests.bases.MigrationTestBase
Executes the migration cache command in a container running the migration tools.
migrateCache(IgniteClient, SqlDdlGenerator, List<MigrationKernalContext>, String, Ignite2PersistentCacheTools.ColumnsProcessorFactory) - Static method in class org.apache.ignite.migrationtools.persistence.Ignite2PersistentCacheTools
Wrapper method that migrates a given cache.
MigrateCacheCall - Class in org.apache.ignite.migrationtools.cli.persistence.calls
Call to the Migrate Cache command.
MigrateCacheCall() - Constructor for class org.apache.ignite.migrationtools.cli.persistence.calls.MigrateCacheCall
 
MigrateCacheCall.Input - Class in org.apache.ignite.migrationtools.cli.persistence.calls
Input.
MigrateCacheCall.InvalidProgressFileException - Exception in org.apache.ignite.migrationtools.cli.persistence.calls
InvalidProgressFileException.
MigrateCacheCall.Ouput - Class in org.apache.ignite.migrationtools.cli.persistence.calls
Output.
MigrateCacheCmd - Class in org.apache.ignite.migrationtools.cli.persistence.commands
Migrate cache command.
MigrateCacheCmd() - Constructor for class org.apache.ignite.migrationtools.cli.persistence.commands.MigrateCacheCmd
 
MigrateCacheException - Exception in org.apache.ignite.migrationtools.persistence.exceptions
MigrateCacheException.
MigrateCacheException(String, String, Throwable) - Constructor for exception org.apache.ignite.migrationtools.persistence.exceptions.MigrateCacheException
Default constructor.
MigrateCacheParams - Class in org.apache.ignite.migrationtools.cli.persistence.params
MigrateCacheParams.
MigrateCacheParams(String, String[], MigrationMode, int, boolean, Path) - Constructor for class org.apache.ignite.migrationtools.cli.persistence.params.MigrateCacheParams
Constructor.
migrateDeprecatedConfigurations(SuperRootChange) - Method in interface org.apache.ignite.configuration.ConfigurationModule
Logic to perform configuration migration when Ignite version is upgraded.
MIGRATION_TOOLS_CONTAINER - Static variable in class org.apache.ignite.migrationtools.tests.bases.MigrationTestBase
 
MigrationCacheProcessor - Class in org.apache.ignite.migrationtools.persistence
This is a lazy version of the GridCacheProcessor.
MigrationCacheProcessor(GridKernalContext) - Constructor for class org.apache.ignite.migrationtools.persistence.MigrationCacheProcessor
Constructor.
migrationIsSuccessfull(String, String) - Static method in class org.apache.ignite.migrationtools.tests.bases.MigrationTestBase
Assert that the migration is successfull.
MigrationKernal - Class in org.apache.ignite.migrationtools.persistence
Custom IgniteKernal for the migration.
MigrationKernalContext - Class in org.apache.ignite.migrationtools.persistence
Minimal kernal context used to read an Apache Ignite 2 cluster working dir.
MigrationKernalContext(IgniteConfiguration, File, Serializable) - Constructor for class org.apache.ignite.migrationtools.persistence.MigrationKernalContext
Constructor.
migrationMode() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.MigrateCacheParams
 
MigrationMode - Enum Class in org.apache.ignite.migrationtools.cli.persistence.params
Allows controlling the error handling policy in case of an irreconcilable mismatch between the GG8 record and the target GG9 Table.
MigrationTestBase - Class in org.apache.ignite.migrationtools.tests.bases
Base class for the migration tests.
MigrationTestBase() - Constructor for class org.apache.ignite.migrationtools.tests.bases.MigrationTestBase
 
MigrationToolsContainer - Class in org.apache.ignite.migrationtools.tests.containers
Container running the migrtion tools.
MigrationToolsContainer(Network) - Constructor for class org.apache.ignite.migrationtools.tests.containers.MigrationToolsContainer
Constructor.
min() - Element in annotation interface org.apache.ignite.configuration.validation.Range
Returns the lower bound for the value.
MismatchingTransactionOutcomeException - Exception in org.apache.ignite.tx
The exception is thrown when the transaction result differs from the intended one.
MismatchingTransactionOutcomeException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.tx.MismatchingTransactionOutcomeException
Constructs a new instance.
missingColumnsInRecord() - Method in exception org.apache.ignite.migrationtools.persistence.mappers.RecordAndTableSchemaMismatchException
 
MultiTableDataStreamerExample - Class in org.apache.ignite.example.streaming
This example demonstrates how to use the streaming API to how to implement a receiver that processes data containing customer and address information, and updates two separate tables on the server.
MultiTableDataStreamerExample() - Constructor for class org.apache.ignite.example.streaming.MultiTableDataStreamerExample
 
MyAnnotationProcessor - Class in org.apache.ignite.migrationtools.tests.e2e.framework.core
MyAnnotationProcessor.
MyAnnotationProcessor() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.framework.core.MyAnnotationProcessor
 
MyBinaryKeyValueCacheTest - Class in org.apache.ignite.migrationtools.tests.e2e.impl
MyBinaryKeyValueCacheTest.
MyBinaryKeyValueCacheTest() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest
 
MyBinaryKeyValueCacheTest.MyBinaryOrganizationCache - Class in org.apache.ignite.migrationtools.tests.e2e.impl
MyBinaryOrganizationCache.
MyBinaryKeyValueCacheTest.MyBinaryPersonPojoCache - Class in org.apache.ignite.migrationtools.tests.e2e.impl
MyBinaryPersonPojoCache.
MyBinaryKeyValueCacheTest.MyBinaryTestCache - Class in org.apache.ignite.migrationtools.tests.e2e.impl
MyBinaryTestCache.
MyBinaryOrganizationCache() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest.MyBinaryOrganizationCache
 
MyBinaryPersonPojoCache() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest.MyBinaryPersonPojoCache
 
MyBinaryTestCache() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest.MyBinaryTestCache
 
MyJob - Class in org.apache.ignite.example.code.deployment
 
MyJob() - Constructor for class org.apache.ignite.example.code.deployment.MyJob
 
MyOrganizationsCacheTest - Class in org.apache.ignite.migrationtools.tests.e2e.impl
MyOrganizationsCacheTest.
MyOrganizationsCacheTest() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.MyOrganizationsCacheTest
 
MySimpleMapCacheTest - Class in org.apache.ignite.migrationtools.tests.e2e.impl
MySimpleMapCacheTest.
MySimpleMapCacheTest() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.MySimpleMapCacheTest
 

N

name() - Method in class org.apache.ignite.catalog.definitions.ColumnDefinition
Returns column name.
name() - Method in class org.apache.ignite.catalog.definitions.IndexDefinition
Returns index name.
name() - Method in class org.apache.ignite.client.handler.ClusterInfo
Returns cluster name.
name() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the client name.
name() - Method in class org.apache.ignite.deployment.DeploymentUnit
Returns name of the deployment unit.
name() - Method in class org.apache.ignite.deployment.DeploymentUnitInfo
Returns the name of the deployment unit.
name() - Method in interface org.apache.ignite.Ignite
Returns the unique name (consistent ID) of the Ignite node in the cluster.
name() - Method in interface org.apache.ignite.IgniteServer
Returns node name.
name() - Method in class org.apache.ignite.lang.ErrorGroup
Returns a name of this group.
name() - Method in interface org.apache.ignite.network.ClusterNode
Returns the unique name (consistent ID) of the node in the cluster.
name() - Method in interface org.apache.ignite.sql.ColumnMetadata
Returns a column name in the result set.
name() - Method in interface org.apache.ignite.table.Table
Gets the canonical name of the table ([schema_name].[table_name]) with SQL-parser style quotation.
name(String) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the client name.
Name - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation is used in conjunction with ConfigValue in case the nested schema contains a field with InjectedName in order to be able to set different default values for the field with InjectedName.
NamedConfigurationTree<T extends ConfigurationProperty<VIEWT>,VIEWT,CHANGET extends VIEWT> - Interface in org.apache.ignite.configuration
Configuration tree representing arbitrary set of named underlying configuration tree of the same type.
NamedConfigValue - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation denotes configuration schema fields that are dynamically created and mapped by name.
NamedListChange<VIEWT,CHANGET extends VIEWT> - Interface in org.apache.ignite.configuration
Closure parameter for ConfigurationTree.change(Consumer) method.
namedListKeys() - Method in interface org.apache.ignite.configuration.NamedListView
Returns an immutable collection of keys contained within this list.
NamedListView<VIEWT> - Interface in org.apache.ignite.configuration
View type for a NamedConfigurationTree.
Namespace - Class in org.apache.ignite.migrationtools.tablemanagement
Old class to help navigate the limitation of custom schemas in Ignite 3.
NameUtils - Class in org.apache.ignite.migrationtools.tests.e2e.framework.core
Utilities for handling table names.
NameUtils() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.framework.core.NameUtils
 
nativelySupported(Class<?>) - Static method in interface org.apache.ignite.table.mapper.Mapper
Checks if a class is of natively supported type.
NESTED_POJO_ATTRIBUTE - Enum constant in enum class org.apache.ignite.migrationtools.types.InspectedFieldType
 
network - Static variable in class org.apache.ignite.migrationtools.tests.bases.MigrationTestBase
 
network - Variable in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterContainer
 
network - Variable in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
 
Network() - Constructor for class org.apache.ignite.lang.ErrorGroups.Network
 
NETWORK_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Network
Network error group.
NetworkAddress - Class in org.apache.ignite.network
Representation of a network address that includes a host name and a port.
NetworkAddress(String, int) - Constructor for class org.apache.ignite.network.NetworkAddress
Constructor.
newName(Class<?>) - Method in interface org.apache.ignite.configuration.notifications.ConfigurationNotificationEvent
Returns new value of the key of a named list item for the parent (any from the root) or current configuration.
newValue() - Method in interface org.apache.ignite.configuration.notifications.ConfigurationNotificationEvent
Returns updated value of the configuration.
newValue(Class<T>) - Method in interface org.apache.ignite.configuration.notifications.ConfigurationNotificationEvent
Returns new value of the parent (any from the root) or current configuration.
nextResult() - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcQueryCursor
node - Variable in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
 
node() - Method in interface org.apache.ignite.compute.JobExecution
A cluster node on which this job is executing.
node(ClusterNode) - Static method in interface org.apache.ignite.compute.JobTarget
Creates a job target for a specific node.
node(ClusterNode) - Method in class org.apache.ignite.compute.task.MapReduceJob.ComputeJobRunnerBuilder
Adds a node to the set of candidate nodes.
NODE_CONFIGURATION_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.NodeConfiguration
Node configuration error group.
NODE_LEFT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
Operation failed because a node has left the cluster.
NODE_NAMES - Static variable in class org.apache.ignite.migrationtools.tests.bases.MigrationTestBase
 
NODE_NOT_FOUND_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Specified node is not found in the cluster.
NODE_NOT_STARTED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Embedded
Node not started.
NODE_START_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Embedded
Node start failed..
NODE_STOPPING_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
Node stopping error.
NodeConfiguration() - Constructor for class org.apache.ignite.lang.ErrorGroups.NodeConfiguration
 
nodeConsistentId() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.PersistenceParams
 
NoDefaultsStorageConfiguration - Class in org.apache.ignite.migrationtools.config.storage
Patched version of the LocalFileConfiguration Storage that does not store defaults.
NoDefaultsStorageConfiguration(Path, ConfigurationTreeGenerator, ConfigurationModule) - Constructor for class org.apache.ignite.migrationtools.config.storage.NoDefaultsStorageConfiguration
 
nodeFolderCandidates(IgniteConfiguration) - Static method in class org.apache.ignite.migrationtools.persistence.Ignite2PersistenceTools
Compute a list of Ignite2PersistenceTools.NodeFolderDescriptors available for the provided Ignite 2 cluster configuration.
NodeFolderDescriptor(File, Serializable) - Constructor for class org.apache.ignite.migrationtools.persistence.Ignite2PersistenceTools.NodeFolderDescriptor
 
nodeMetadata() - Method in interface org.apache.ignite.network.ClusterNode
Returns the metadata of the node.
NodeMetadata - Class in org.apache.ignite.network
Contains metadata of the cluster node.
NodeMetadata(String, int, int) - Constructor for class org.apache.ignite.network.NodeMetadata
Constructor.
nodeNames() - Method in class org.apache.ignite.client.handler.ClientPrimaryReplicaTracker.PrimaryReplicasResult
 
NodeNotFoundException - Exception in org.apache.ignite.compute
Thrown when compute component can't find the node to run the job on in the cluster.
NodeNotFoundException(Set<String>) - Constructor for exception org.apache.ignite.compute.NodeNotFoundException
 
NodeNotFoundException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.compute.NodeNotFoundException
 
NodeNotStartedException - Exception in org.apache.ignite.lang
Thrown when embedded node is not yet started or it's already stopped.
NodeNotStartedException() - Constructor for exception org.apache.ignite.lang.NodeNotStartedException
 
NodeNotStartedException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.NodeNotStartedException
 
nodes() - Method in class org.apache.ignite.compute.AllNodesBroadcastJobTarget
Returns a set of nodes to execute the jobs on.
nodes() - Method in class org.apache.ignite.compute.AnyNodeJobTarget
 
nodes() - Method in class org.apache.ignite.compute.task.MapReduceJob
Candidate nodes; the job will be executed on one of them.
nodes() - Method in interface org.apache.ignite.network.IgniteCluster
Returns all cluster nodes that are part of the logical topology, including the local node if applicable.
nodes(Collection<ClusterNode>) - Static method in interface org.apache.ignite.compute.BroadcastJobTarget
Creates a job target for all nodes from the provided collection.
nodes(Collection<ClusterNode>) - Method in class org.apache.ignite.compute.task.MapReduceJob.ComputeJobRunnerBuilder
Adds nodes to the set of candidate nodes.
nodes(Set<ClusterNode>) - Static method in interface org.apache.ignite.compute.BroadcastJobTarget
Creates a job target for all nodes from the provided collection.
nodes(ClusterNode...) - Static method in interface org.apache.ignite.compute.BroadcastJobTarget
Creates a job target for all nodes from the provided collection.
NODES_NOT_FOUND_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
Nodes were not found.
nodesAsync() - Method in interface org.apache.ignite.network.IgniteCluster
Asynchronously retrieves all cluster nodes that are part of the logical topology, including the local node if applicable.
NodeStartException - Exception in org.apache.ignite.lang
Thrown when node failed to start.
NodeStartException(String) - Constructor for exception org.apache.ignite.lang.NodeStartException
 
NodeStartException(String, Throwable) - Constructor for exception org.apache.ignite.lang.NodeStartException
 
NodeStartException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.NodeStartException
 
NoRowSetExpectedException - Exception in org.apache.ignite.sql
Exception is thrown when a query doesn't intend to return any rows (e.g.
NoRowSetExpectedException() - Constructor for exception org.apache.ignite.sql.NoRowSetExpectedException
Creates an exception.
not(Expression) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates the negation of the predicate.
NOT - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 
NOT_ENOUGH_ALIVE_NODES_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
Error when not enough alive nodes to perform restart with clean up.
NOT_EQ - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 
NOT_IN - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 
NotBlank - Annotation Interface in org.apache.ignite.configuration.validation
Signifies that current String configuration values can not be blank.
notEqualTo(byte[]) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is not equal to the specified value.
notEqualTo(Comparable<T>) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is not equal to the specified value.
NotificationSender - Interface in org.apache.ignite.client.handler
Client notification sender.
notify(AuthenticationEventParameters) - Method in class org.apache.ignite.client.handler.ClientInboundMessageHandler
 
notIn(byte[]...) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is is not found within the specified collection.
notIn(Comparable<T>...) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is is not found within the specified collection.
notNull() - Method in class org.apache.ignite.catalog.ColumnType
Sets this type as not nullable.
notNullValue() - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is not null.
NULL - Enum constant in enum class org.apache.ignite.sql.ColumnType
Null.
nullable() - Element in annotation interface org.apache.ignite.catalog.annotations.Column
Whether this column is nullable or not.
nullable() - Method in class org.apache.ignite.catalog.ColumnType
Returns nullability of the column type.
nullable() - Method in class org.apache.ignite.migrationtools.types.InspectedField
 
nullable() - Method in interface org.apache.ignite.sql.ColumnMetadata
Returns a row column nullability flag.
nullable(Boolean) - Method in class org.apache.ignite.catalog.ColumnType
Sets nullability of this type.
NULLABLE_VALUE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
This error code indicates that a method can't return a null value due it's ambiguity (whether the value is absent or is null).
NullableValue<T> - Class in org.apache.ignite.lang
Container object that contains a nullable value.
NULLS_FIRST - Enum constant in enum class org.apache.ignite.catalog.SortOrder
 
NULLS_LAST - Enum constant in enum class org.apache.ignite.catalog.SortOrder
 
nullValue() - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates a condition that test the examined object is null.

O

objectName() - Method in class org.apache.ignite.table.QualifiedName
Returns normalized object name.
of(String, String) - Static method in class org.apache.ignite.table.QualifiedName
Factory method that creates qualified name from given schema and object name.
of(Class<?>) - Static method in class org.apache.ignite.catalog.ColumnType
Creates a column type with the type derived from the Java type and default length, precision, scale and nullability.
of(Class<?>, Integer, Integer, Integer, Boolean) - Static method in class org.apache.ignite.catalog.ColumnType
Creates a column type with the type derived from the Java type and specified length, precision, scale and nullability.
of(Class<O>) - Static method in interface org.apache.ignite.table.mapper.Mapper
Creates a mapper for the specified class.
of(Class<O>, String) - Static method in interface org.apache.ignite.table.mapper.Mapper
Creates a mapper for a case where an object represents a single column.
of(Class<O>, String, String, String...) - Static method in interface org.apache.ignite.table.mapper.Mapper
Creates a mapper for a case where object's individual fields map to columns by name.
of(Class<ObjectT>, String, TypeConverter<ObjectT, ColumnT>) - Static method in interface org.apache.ignite.table.mapper.Mapper
Creates a mapper for a case where an object represents a single column and an additional transformation is required.
of(Object...) - Static method in class org.apache.ignite.sql.BatchedArguments
Creates batched arguments.
of(T) - Static method in class org.apache.ignite.lang.NullableValue
Wraps a nullable object.
of(T) - Static method in interface org.apache.ignite.table.DataStreamerItem
Creates a new data streamer item with the given data and DataStreamerOperationType.PUT operation type.
of(T, DataStreamerOperationType) - Static method in interface org.apache.ignite.table.DataStreamerItem
Creates a new data streamer item with the given data and operation type.
offer(T) - Method in class org.apache.ignite.migrationtools.persistence.utils.pubsub.StreamerPublisher
Offer a new item to the subscriber.
oldName(Class<?>) - Method in interface org.apache.ignite.configuration.notifications.ConfigurationNotificationEvent
Returns old value of the key of a named list item for the parent (any from the root) or current configuration.
oldValue() - Method in interface org.apache.ignite.configuration.notifications.ConfigurationNotificationEvent
Returns the previous value of the updated configuration.
oldValue(Class<T>) - Method in interface org.apache.ignite.configuration.notifications.ConfigurationNotificationEvent
Returns old value of the parent (any from the root) or current configuration.
onClose() - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcQueryCursor
onComplete() - Method in class org.apache.ignite.migrationtools.persistence.utils.pubsub.BasicProcessor
 
onCreate(ConfigurationNotificationEvent<VIEWT>) - Method in interface org.apache.ignite.configuration.notifications.ConfigurationNamedListListener
Called when new named list element is created.
onDefaultsPersisted() - Method in class org.apache.ignite.migrationtools.config.registry.CombinedConfigRegistry
 
onDelete(ConfigurationNotificationEvent<VIEWT>) - Method in interface org.apache.ignite.configuration.notifications.ConfigurationNamedListListener
Called when named list element is deleted.
OneColumnMapper<ObjectT> - Interface in org.apache.ignite.table.mapper
Maps the entire object of a natively supported type to a single column.
OneOf - Annotation Interface in org.apache.ignite.configuration.validation
Signifies that current String configuration values can only be equal to one of the listed values.
onError(Throwable) - Method in class org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor
 
onError(Throwable) - Method in class org.apache.ignite.migrationtools.persistence.mappers.SkipRecordsSchemaColumnsProcessor
 
onError(Throwable) - Method in class org.apache.ignite.migrationtools.persistence.utils.pubsub.BasicProcessor
 
onFirstPageReady() - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcQueryCursor
onNext(Map.Entry<Object, Object>) - Method in class org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor
 
onNext(CacheDataRow) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CacheDataRowProcessor
 
onNext(S) - Method in class org.apache.ignite.migrationtools.persistence.utils.pubsub.RateLimiterProcessor
 
onRename(ConfigurationNotificationEvent<VIEWT>) - Method in interface org.apache.ignite.configuration.notifications.ConfigurationNamedListListener
Called when a named list element is renamed.
onSubscribe(Flow.Subscription) - Method in class org.apache.ignite.migrationtools.persistence.utils.pubsub.BasicProcessor
 
onUpdate(ConfigurationNotificationEvent<VIEWT>) - Method in interface org.apache.ignite.configuration.notifications.ConfigurationListener
Called on property value update.
onUpdate(ConfigurationNotificationEvent<VIEWT>) - Method in interface org.apache.ignite.configuration.notifications.ConfigurationNamedListListener
Called on property value update.
OP_EXECUTION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.MetaStorage
Failed to perform an operation on the underlying key value storage.
OP_EXECUTION_TIMEOUT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.MetaStorage
Failed to perform an operation within a specified time period.
operation() - Method in interface org.apache.ignite.client.RetryPolicyContext
Gets the operation type.
operationTimeout() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the operation timeout, in milliseconds.
operationTimeout(long) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the operation timeout, in milliseconds.
operationType() - Method in interface org.apache.ignite.table.DataStreamerItem
Gets the operation type.
Operator - Enum Class in org.apache.ignite.table.criteria
Provides the operators for the criteria query grammar.
options() - Method in class org.apache.ignite.compute.JobDescriptor
Job execution options.
options() - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor
Receiver execution options.
options() - Method in class org.apache.ignite.table.ReceiverDescriptor
Deprecated.
Receiver execution options.
options(JobExecutionOptions) - Method in class org.apache.ignite.compute.JobDescriptor.Builder
Sets the job execution options.
options(ReceiverExecutionOptions) - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor.Builder
Sets the receiver execution options.
options(ReceiverExecutionOptions) - Method in class org.apache.ignite.table.ReceiverDescriptor.Builder
Deprecated.
Sets the receiver execution options.
or(Expression...) - Static method in interface org.apache.ignite.table.criteria.Criteria
Creates the or of the expressions.
OR - Enum constant in enum class org.apache.ignite.table.criteria.Operator
 
org.apache.ignite - package org.apache.ignite
Contains the Ignite node API and classes for node lifecycle management.
org.apache.ignite.catalog - package org.apache.ignite.catalog
 
org.apache.ignite.catalog.annotations - package org.apache.ignite.catalog.annotations
 
org.apache.ignite.catalog.definitions - package org.apache.ignite.catalog.definitions
 
org.apache.ignite.client - package org.apache.ignite.client
Ignite thin client.
org.apache.ignite.client.handler - package org.apache.ignite.client.handler
Ignite thin client handler (server-side connector).
org.apache.ignite.client.handler.configuration - package org.apache.ignite.client.handler.configuration
Configuration schemas for thin client components.
org.apache.ignite.client.handler.requests - package org.apache.ignite.client.handler.requests
 
org.apache.ignite.client.handler.requests.cluster - package org.apache.ignite.client.handler.requests.cluster
 
org.apache.ignite.client.handler.requests.compute - package org.apache.ignite.client.handler.requests.compute
 
org.apache.ignite.client.handler.requests.jdbc - package org.apache.ignite.client.handler.requests.jdbc
Sql API handler.
org.apache.ignite.client.handler.requests.sql - package org.apache.ignite.client.handler.requests.sql
 
org.apache.ignite.client.handler.requests.table - package org.apache.ignite.client.handler.requests.table
Table API requests.
org.apache.ignite.client.handler.requests.table.partition - package org.apache.ignite.client.handler.requests.table.partition
 
org.apache.ignite.client.handler.requests.tx - package org.apache.ignite.client.handler.requests.tx
 
org.apache.ignite.compute - package org.apache.ignite.compute
 
org.apache.ignite.compute.task - package org.apache.ignite.compute.task
 
org.apache.ignite.configuration - package org.apache.ignite.configuration
Basic classes and interfaces for describing and handling configuration trees.
org.apache.ignite.configuration.annotation - package org.apache.ignite.configuration.annotation
Annotations for configuration schemas.
org.apache.ignite.configuration.notifications - package org.apache.ignite.configuration.notifications
Interfaces and classes for configuration notifications.
org.apache.ignite.configuration.validation - package org.apache.ignite.configuration.validation
Interfaces and classes for configuration validation.
org.apache.ignite.customizer.example - package org.apache.ignite.customizer.example
 
org.apache.ignite.data - package org.apache.ignite.data
 
org.apache.ignite.deployment - package org.apache.ignite.deployment
 
org.apache.ignite.deployment.version - package org.apache.ignite.deployment.version
 
org.apache.ignite.error.code.annotations - package org.apache.ignite.error.code.annotations
 
org.apache.ignite.example - package org.apache.ignite.example
 
org.apache.ignite.example.client - package org.apache.ignite.example.client
 
org.apache.ignite.example.code.deployment - package org.apache.ignite.example.code.deployment
 
org.apache.ignite.example.compute - package org.apache.ignite.example.compute
 
org.apache.ignite.example.serialization - package org.apache.ignite.example.serialization
 
org.apache.ignite.example.sql - package org.apache.ignite.example.sql
 
org.apache.ignite.example.sql.jdbc - package org.apache.ignite.example.sql.jdbc
 
org.apache.ignite.example.storage - package org.apache.ignite.example.storage
 
org.apache.ignite.example.streaming - package org.apache.ignite.example.streaming
 
org.apache.ignite.example.table - package org.apache.ignite.example.table
 
org.apache.ignite.example.tx - package org.apache.ignite.example.tx
 
org.apache.ignite.jdbc - package org.apache.ignite.jdbc
Contains JDBC driver implementation for Apache Ignite 3.x.
org.apache.ignite.lang - package org.apache.ignite.lang
Ignite general purpose classes and interfaces.
org.apache.ignite.lang.util - package org.apache.ignite.lang.util
 
org.apache.ignite.marshalling - package org.apache.ignite.marshalling
 
org.apache.ignite.migrationtools.cli - package org.apache.ignite.migrationtools.cli
 
org.apache.ignite.migrationtools.cli.configs.calls - package org.apache.ignite.migrationtools.cli.configs.calls
 
org.apache.ignite.migrationtools.cli.configs.commands - package org.apache.ignite.migrationtools.cli.configs.commands
 
org.apache.ignite.migrationtools.cli.exceptions - package org.apache.ignite.migrationtools.cli.exceptions
 
org.apache.ignite.migrationtools.cli.mixins - package org.apache.ignite.migrationtools.cli.mixins
 
org.apache.ignite.migrationtools.cli.persistence.calls - package org.apache.ignite.migrationtools.cli.persistence.calls
 
org.apache.ignite.migrationtools.cli.persistence.commands - package org.apache.ignite.migrationtools.cli.persistence.commands
 
org.apache.ignite.migrationtools.cli.persistence.params - package org.apache.ignite.migrationtools.cli.persistence.params
 
org.apache.ignite.migrationtools.cli.sql.calls - package org.apache.ignite.migrationtools.cli.sql.calls
 
org.apache.ignite.migrationtools.cli.sql.commands - package org.apache.ignite.migrationtools.cli.sql.commands
 
org.apache.ignite.migrationtools.config - package org.apache.ignite.migrationtools.config
 
org.apache.ignite.migrationtools.config.converters - package org.apache.ignite.migrationtools.config.converters
 
org.apache.ignite.migrationtools.config.loader - package org.apache.ignite.migrationtools.config.loader
 
org.apache.ignite.migrationtools.config.registry - package org.apache.ignite.migrationtools.config.registry
 
org.apache.ignite.migrationtools.config.storage - package org.apache.ignite.migrationtools.config.storage
 
org.apache.ignite.migrationtools.handlers - package org.apache.ignite.migrationtools.handlers
 
org.apache.ignite.migrationtools.persistence - package org.apache.ignite.migrationtools.persistence
 
org.apache.ignite.migrationtools.persistence.exceptions - package org.apache.ignite.migrationtools.persistence.exceptions
 
org.apache.ignite.migrationtools.persistence.mappers - package org.apache.ignite.migrationtools.persistence.mappers
 
org.apache.ignite.migrationtools.persistence.utils.pubsub - package org.apache.ignite.migrationtools.persistence.utils.pubsub
 
org.apache.ignite.migrationtools.sql - package org.apache.ignite.migrationtools.sql
 
org.apache.ignite.migrationtools.tablemanagement - package org.apache.ignite.migrationtools.tablemanagement
 
org.apache.ignite.migrationtools.tests.bases - package org.apache.ignite.migrationtools.tests.bases
 
org.apache.ignite.migrationtools.tests.clusters - package org.apache.ignite.migrationtools.tests.clusters
 
org.apache.ignite.migrationtools.tests.containers - package org.apache.ignite.migrationtools.tests.containers
 
org.apache.ignite.migrationtools.tests.e2e.framework.core - package org.apache.ignite.migrationtools.tests.e2e.framework.core
 
org.apache.ignite.migrationtools.tests.e2e.framework.runners - package org.apache.ignite.migrationtools.tests.e2e.framework.runners
 
org.apache.ignite.migrationtools.tests.e2e.impl - package org.apache.ignite.migrationtools.tests.e2e.impl
 
org.apache.ignite.migrationtools.tests.models - package org.apache.ignite.migrationtools.tests.models
 
org.apache.ignite.migrationtools.tests.utils - package org.apache.ignite.migrationtools.tests.utils
 
org.apache.ignite.migrationtools.types - package org.apache.ignite.migrationtools.types
 
org.apache.ignite.migrationtools.types.converters - package org.apache.ignite.migrationtools.types.converters
 
org.apache.ignite.migrationtools.utils - package org.apache.ignite.migrationtools.utils
 
org.apache.ignite.network - package org.apache.ignite.network
 
org.apache.ignite.security - package org.apache.ignite.security
 
org.apache.ignite.security.exception - package org.apache.ignite.security.exception
 
org.apache.ignite.sql - package org.apache.ignite.sql
Contains Ignite SQL API classes and interfaces.
org.apache.ignite.sql.async - package org.apache.ignite.sql.async
SQL API for asynchronous SQL query execution.
org.apache.ignite.table - package org.apache.ignite.table
Table access API.
org.apache.ignite.table.criteria - package org.apache.ignite.table.criteria
Contains API classes for criteria queries.
org.apache.ignite.table.mapper - package org.apache.ignite.table.mapper
Contains user classes, mapping API classes, and mapper builders.
org.apache.ignite.table.partition - package org.apache.ignite.table.partition
 
org.apache.ignite.tx - package org.apache.ignite.tx
Contains Transaction API classes and interfaces.
org.apache.ignite3.internal.catalog.sql - package org.apache.ignite3.internal.catalog.sql
 
origin() - Method in interface org.apache.ignite.sql.ColumnMetadata
Returns a column origin.
Ouput(String, Path) - Constructor for class org.apache.ignite.migrationtools.cli.persistence.calls.MigrateCacheCall.Ouput
 
Output(String, int) - Constructor for class org.apache.ignite.migrationtools.cli.persistence.calls.ListCachesCall.Output
 
outputClusterConfigFilePath() - Method in class org.apache.ignite.migrationtools.cli.configs.calls.ConfigurationConverterCall.Input
 
outputNodeConfigFilePath() - Method in class org.apache.ignite.migrationtools.cli.configs.calls.ConfigurationConverterCall.Input
 

P

PACK_EXTRA - Enum constant in enum class org.apache.ignite.migrationtools.cli.persistence.params.MigrationMode
Any additional columns/fields in the cache record will be serialized to JSON and stored in the `__EXTRA__` column.
packClusterNode(ClusterNode, ClientMessagePacker) - Static method in class org.apache.ignite.client.handler.requests.cluster.ClientClusterGetNodesRequest
Pack ClusterNode instance to client message.
packIntoMany(BinaryObjectImpl, AbstractSchemaColumnsProcessor.TypeProcessingResult, boolean) - Method in class org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor
 
pageSize() - Method in interface org.apache.ignite.sql.Statement
Returns a page size - the maximum number of result rows that can be fetched at a time.
pageSize() - Method in class org.apache.ignite.table.criteria.CriteriaQueryOptions
Returns a page size - the maximum number of result rows that can be fetched at a time.
pageSize() - Method in class org.apache.ignite.table.DataStreamerOptions
Gets the page size (the number of entries that will be sent to the cluster in one network call).
pageSize(int) - Method in interface org.apache.ignite.sql.Statement.StatementBuilder
Sets a page size - the maximum number of result rows that can be fetched at a time.
pageSize(int) - Method in class org.apache.ignite.table.criteria.CriteriaQueryOptions.Builder
Sets a page size - the maximum number of result rows that can be fetched at a time.
pageSize(int) - Method in class org.apache.ignite.table.DataStreamerOptions.Builder
Sets the page size (the number of entries that will be sent to the cluster in one network call).
Parameter<T> - Class in org.apache.ignite.table.criteria
Represents a parameter for criteria query.
params() - Method in class org.apache.ignite.migrationtools.cli.persistence.commands.PersistenceBaseCmd
 
parse(String) - Static method in enum class org.apache.ignite.security.AuthenticationType
Parses AuthenticationType from the given string.
parse(String) - Static method in class org.apache.ignite.table.QualifiedName
Factory method that creates qualified name object by parsing given simple or canonical object name.
parseIdentifier(String) - Static method in class org.apache.ignite.lang.util.IgniteNameUtils
Parses an SQL-compliant object identifier.
parseName(String) - Static method in class org.apache.ignite.lang.util.IgniteNameUtils
Parses the canonical name of an object.
parseVersion(String) - Static method in interface org.apache.ignite.deployment.version.Version
Parse version from String.
partition() - Method in interface org.apache.ignite.compute.JobExecutionContext
Partition associated with this job.
Partition - Interface in org.apache.ignite.table.partition
Marker interface which represents a partition reference.
PARTITION_STATE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
Error while returning partition states.
partitionAsync(K, Mapper<K>) - Method in interface org.apache.ignite.table.partition.PartitionManager
Returns partition instance for provided table key.
partitionAsync(Tuple) - Method in interface org.apache.ignite.table.partition.PartitionManager
Returns partition instance for provided table key.
partitionAwarenessMetadata() - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcQueryCursor
partitionManager() - Method in interface org.apache.ignite.table.Table
Gets the partition manager.
PartitionManager - Interface in org.apache.ignite.table.partition
The partition manager provides the ability to obtain information about table partitions.
partitions() - Element in annotation interface org.apache.ignite.catalog.annotations.Zone
Number of partitions.
partitions() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns number of partitions.
partitions() - Method in class org.apache.ignite.client.handler.ClientPrimaryReplicaTracker.PrimaryReplicasResult
 
partitions(Integer) - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Sets the number of partitions.
password(String) - Method in class org.apache.ignite.client.BasicAuthenticator.Builder
Sets password.
patchConfigurationWithDynamicDefaults(SuperRootChange) - Method in interface org.apache.ignite.configuration.ConfigurationModule
Patches the provided configuration with dynamic default values.
patchWithDynamicDefaults(String) - Method in interface org.apache.ignite.configuration.ConfigurationDynamicDefaultsPatcher
Patches the configuration with the dynamic default values that are not known at the compile time.
path() - Method in class org.apache.ignite.deployment.DeploymentUnitInfo
Returns the path to the deployment unit resources.
payloadMarshaller() - Method in interface org.apache.ignite.table.DataStreamerReceiver
Marshaller for the receiver payload (batch items).
payloadMarshaller() - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor
Payload marshaller.
payloadMarshaller(Marshaller<T, byte[]>) - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor.Builder
Sets the payload marshaller.
performQueryAsync(Table) - Static method in class org.apache.ignite.example.table.QueryExample
 
performQueryWithoutTransaction(Table) - Static method in class org.apache.ignite.example.table.QueryExample
Demonstrates querying with an implicit transaction.
performQueryWithTransaction(IgniteClient, Table) - Static method in class org.apache.ignite.example.table.QueryExample
Demonstrates querying with an explicit transaction.
PERIOD - Enum constant in enum class org.apache.ignite.sql.ColumnType
Date interval.
perPartitionParallelOperations() - Method in class org.apache.ignite.table.DataStreamerOptions
Gets the number of parallel operations per partition (how many in-flight requests can be active for a given partition).
perPartitionParallelOperations(int) - Method in class org.apache.ignite.table.DataStreamerOptions.Builder
Sets the number of parallel operations per partition (how many in-flight requests can be active for a given partition).
PersistenceBaseCmd - Class in org.apache.ignite.migrationtools.cli.persistence.commands
Base for all the Persistence commands.
PersistenceBaseCmd() - Constructor for class org.apache.ignite.migrationtools.cli.persistence.commands.PersistenceBaseCmd
 
persistenceParams() - Method in class org.apache.ignite.migrationtools.cli.persistence.calls.ListCachesCall.Input
 
PersistenceParams - Class in org.apache.ignite.migrationtools.cli.persistence.params
Persistence Command parameters.
PersistenceParams() - Constructor for class org.apache.ignite.migrationtools.cli.persistence.params.PersistenceParams
 
persistentCaches() - Method in class org.apache.ignite.migrationtools.persistence.MigrationCacheProcessor
 
persistentCaches(List<MigrationKernalContext>) - Static method in class org.apache.ignite.migrationtools.persistence.Ignite2PersistentCacheTools
List the persistent caches in the provided nodes.
PersistentPageMemoryStorageExample - Class in org.apache.ignite.example.storage
This example demonstrates a usage of the PageMemory storage engine configured with a persistent data region.
PersistentPageMemoryStorageExample() - Constructor for class org.apache.ignite.example.storage.PersistentPageMemoryStorageExample
 
PersistentTableTypeRegistryImpl - Class in org.apache.ignite.migrationtools.tablemanagement
TableTypeRegistry implementation backed by a table.
PersistentTableTypeRegistryImpl(IgniteClient) - Constructor for class org.apache.ignite.migrationtools.tablemanagement.PersistentTableTypeRegistryImpl
 
Person - Class in org.apache.ignite.example.table
Represents a Person entity with database mapping.
Person() - Constructor for class org.apache.ignite.example.table.Person
 
Person(int, String, String, int, String) - Constructor for class org.apache.ignite.example.table.Person
 
PersonCacheTest - Class in org.apache.ignite.migrationtools.tests.e2e.impl
PersonCacheTest.
PersonCacheTest() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.PersonCacheTest
 
PhraseWordLengthCountMapReduceTask() - Constructor for class org.apache.ignite.example.compute.ComputeMapReduceExample.PhraseWordLengthCountMapReduceTask
 
PLACEMENT_DRIVER_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.PlacementDriver
Placement driver error group.
PlacementDriver() - Constructor for class org.apache.ignite.lang.ErrorGroups.PlacementDriver
 
POJO_ATTRIBUTE - Enum constant in enum class org.apache.ignite.migrationtools.types.InspectedFieldType
 
PojoAutoSerializationExample - Class in org.apache.ignite.example.serialization
 
PojoAutoSerializationExample() - Constructor for class org.apache.ignite.example.serialization.PojoAutoSerializationExample
 
PojoAutoSerializationJob - Class in org.apache.ignite.example.serialization
 
PojoAutoSerializationJob() - Constructor for class org.apache.ignite.example.serialization.PojoAutoSerializationJob
 
PojoMapper<T> - Interface in org.apache.ignite.table.mapper
Maps fields of objects of type PojoMapper to columns by name.
PolymorphicChange - Interface in org.apache.ignite.configuration
Marker interface for *Node classes whose schemas are marked with annotation PolymorphicConfigInstance, this will allow at the compilation stage to distinguish an instance of a polymorphic configuration from the polymorphic configuration itself.
PolymorphicConfig - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation marks the class as a polymorphic configuration schema.
PolymorphicConfigInstance - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation marks the class as an instance of polymorphic configuration schema.
PolymorphicId - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation marks the polymorphic configuration schema field as a special (read only) leaf that will store the current polymorphic configuration type.
polymorphicSchemaExtensions() - Method in interface org.apache.ignite.configuration.ConfigurationModule
Returns classes of polymorphic schema extensions (annotated with PolymorphicConfig) provided by this module.
port - Variable in class org.apache.ignite.client.handler.configuration.ClientConnectorConfigurationSchema
TCP port.
port() - Method in class org.apache.ignite.network.NetworkAddress
Returns the network port.
PORT_IN_USE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Network
Deprecated.
postProcessMappedTuple(Tuple, Collection<String>, Collection<String>) - Method in class org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor
 
postProcessMappedTuple(Tuple, Collection<String>, Collection<String>) - Method in class org.apache.ignite.migrationtools.persistence.mappers.IgnoreMismatchesSchemaColumnProcessor
 
postProcessMappedTuple(Tuple, Collection<String>, Collection<String>) - Method in class org.apache.ignite.migrationtools.persistence.mappers.SimpleSchemaColumnsProcessor
 
PowerOfTwo - Annotation Interface in org.apache.ignite.configuration.validation
Signifies that this value must be a power of two.
precision() - Element in annotation interface org.apache.ignite.catalog.annotations.Column
The precision of the numeric type.
precision() - Method in class org.apache.ignite.catalog.ColumnType
Returns precision of the column type.
precision() - Method in interface org.apache.ignite.sql.ColumnMetadata
Returns an SQL column precision or -1 if precision is not applicable to the column's type.
precision(Integer) - Method in class org.apache.ignite.catalog.ColumnType
Sets precision for this column type.
precision(Integer, Integer) - Method in class org.apache.ignite.catalog.ColumnType
Sets precision and scale for this column type.
precisionAllowed() - Method in enum class org.apache.ignite.sql.ColumnType
If true precision need to be specified, false otherwise.
PRIMARY_REPLICA_AWAIT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.PlacementDriver
Primary replica await error.
PRIMARY_REPLICA_AWAIT_TIMEOUT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.PlacementDriver
Primary replica await timeout error.
PRIMARY_REPLICA_RESOLVE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Cannot resolve primary replica for colocated execution.
PRIMARY_REPLICAS_GET - Enum constant in enum class org.apache.ignite.client.ClientOperationType
Get all primary replicas mapping to cluster nodes (PartitionManager.primaryReplicasAsync()).
primaryKey(String...) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets primary key columns using default index type.
primaryKey(IndexType, List<ColumnSorted>) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets primary key columns.
primaryKey(IndexType, ColumnSorted...) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets primary key columns.
primaryKeyColumns() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns a list of columns used in the primary key.
primaryKeysMetaAsync(JdbcMetaPrimaryKeysRequest) - Method in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
primaryKeyType() - Element in annotation interface org.apache.ignite.catalog.annotations.Table
Primary key type.
primaryKeyType() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns primary key type.
primaryReplicaAsync(Partition) - Method in interface org.apache.ignite.table.partition.PartitionManager
Returns location of primary replica for provided partition.
primaryReplicasAsync() - Method in interface org.apache.ignite.table.partition.PartitionManager
Returns map with all partitions and their locations.
primaryReplicasAsync(int, Long) - Method in class org.apache.ignite.client.handler.ClientPrimaryReplicaTracker
Gets primary replicas by partition for the table.
PRIMITIVE - Enum constant in enum class org.apache.ignite.migrationtools.types.InspectedFieldType
 
PRIMITIVE_TO_WRAPPER - Static variable in class org.apache.ignite.migrationtools.utils.ClassnameUtils
 
PrimitiveTest() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.PrimitiveTest
 
priority() - Method in class org.apache.ignite.compute.JobExecutionOptions
Gets the job execution priority.
priority() - Method in class org.apache.ignite.table.ReceiverExecutionOptions
Gets the receiver execution priority.
priority(int) - Method in class org.apache.ignite.compute.JobExecutionOptions.Builder
Sets the job execution priority.
priority(int) - Method in class org.apache.ignite.table.ReceiverExecutionOptions.Builder
Sets the receiver execution priority.
process(Executor, ClientMessageUnpacker, long, Map<Long, CancelHandle>, QueryProcessor, ClientResourceRegistry, ClientHandlerMetricSource, HybridTimestampTracker, boolean, boolean, TxManager, ClockService, NotificationSender, String) - Static method in class org.apache.ignite.client.handler.requests.sql.ClientSqlExecuteRequest
Processes the request.
process(Executor, ClientMessageUnpacker, QueryProcessor, long, Map<Long, CancelHandle>, HybridTimestampTracker, String) - Static method in class org.apache.ignite.client.handler.requests.sql.ClientSqlExecuteScriptRequest
Processes the request.
process(Executor, ClientMessageUnpacker, QueryProcessor, ClientResourceRegistry, long, Map<Long, CancelHandle>, HybridTimestampTracker, String) - Static method in class org.apache.ignite.client.handler.requests.sql.ClientSqlExecuteBatchRequest
Processes the request.
process(Executor, ClientMessageUnpacker, QueryProcessor, ClientResourceRegistry, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.sql.ClientSqlQueryMetadataRequest
Processes the request.
process(Set<? extends TypeElement>, RoundEnvironment) - Method in class org.apache.ignite.migrationtools.tests.e2e.framework.core.MyAnnotationProcessor
 
process(ClientMessageUnpacker, Map<Long, CancelHandle>) - Static method in class org.apache.ignite.client.handler.requests.ClientOperationCancelRequest
Processes the request.
process(ClientMessageUnpacker, ClientPrimaryReplicaTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTablePartitionPrimaryReplicasGetRequest
Processes the request.
process(ClientMessageUnpacker, ClientResourceRegistry) - Static method in class org.apache.ignite.client.handler.requests.sql.ClientSqlCursorCloseRequest
Processes the request.
process(ClientMessageUnpacker, ClientResourceRegistry) - Static method in class org.apache.ignite.client.handler.requests.sql.ClientSqlCursorNextPageRequest
Processes the request.
process(ClientMessageUnpacker, ClientResourceRegistry, ClientHandlerMetricSource, ClockService, IgniteTablesInternal, boolean, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.tx.ClientTransactionCommitRequest
Processes the request.
process(ClientMessageUnpacker, ClientResourceRegistry, ClientHandlerMetricSource, IgniteTablesInternal, boolean) - Static method in class org.apache.ignite.client.handler.requests.tx.ClientTransactionRollbackRequest
Processes the request.
process(ClientMessageUnpacker, JdbcQueryEventHandlerImpl, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcExecuteBatchRequest
Processes remote JdbcBatchExecuteRequest.
process(ClientMessageUnpacker, JdbcQueryEventHandlerImpl, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcFinishTxRequest
Processes a remote JDBC request to complete explicit transaction.
process(ClientMessageUnpacker, JdbcQueryEventHandlerImpl, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcPreparedStmntBatchRequest
Processes remote BatchPreparedStmntRequest.
process(ClientMessageUnpacker, IgniteComputeInternal) - Static method in class org.apache.ignite.client.handler.requests.compute.ClientComputeCancelRequest
Processes the request.
process(ClientMessageUnpacker, IgniteComputeInternal) - Static method in class org.apache.ignite.client.handler.requests.compute.ClientComputeChangePriorityRequest
Processes the request.
process(ClientMessageUnpacker, IgniteComputeInternal) - Static method in class org.apache.ignite.client.handler.requests.compute.ClientComputeGetStateRequest
Processes the request.
process(ClientMessageUnpacker, IgniteComputeInternal, NotificationSender, ClientContext) - Static method in class org.apache.ignite.client.handler.requests.compute.ClientComputeExecuteMapReduceRequest
Processes the request.
process(ClientMessageUnpacker, IgniteComputeInternal, ClusterService, NotificationSender, ClientContext) - Static method in class org.apache.ignite.client.handler.requests.compute.ClientComputeExecuteRequest
Processes the request.
process(ClientMessageUnpacker, IgniteComputeInternal, IgniteTables, ClusterService, NotificationSender, ClientContext) - Static method in class org.apache.ignite.client.handler.requests.compute.ClientComputeExecuteColocatedRequest
Processes the request.
process(ClientMessageUnpacker, IgniteComputeInternal, IgniteTables, ClusterService, NotificationSender, ClientContext) - Static method in class org.apache.ignite.client.handler.requests.compute.ClientComputeExecutePartitionedRequest
Processes the request.
process(ClientMessageUnpacker, JdbcQueryCursorHandler) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcCloseRequest
Processes remote JdbcQueryCloseRequest.
process(ClientMessageUnpacker, JdbcQueryCursorHandler) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcFetchRequest
Processes remote JdbcQueryFetchRequest.
process(ClientMessageUnpacker, JdbcQueryCursorHandler) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcHasMoreRequest
Processes remote JdbcGetMoreResultsRequest.
process(ClientMessageUnpacker, JdbcQueryEventHandler) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcColumnMetadataRequest
Processes remote JdbcMetaColumnsRequest.
process(ClientMessageUnpacker, JdbcQueryEventHandler) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcPrimaryKeyMetadataRequest
Processes remote JdbcMetaPrimaryKeysRequest.
process(ClientMessageUnpacker, JdbcQueryEventHandler) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcSchemasMetadataRequest
Processes remote JdbcMetaSchemasRequest.
process(ClientMessageUnpacker, JdbcQueryEventHandler) - Static method in class org.apache.ignite.client.handler.requests.jdbc.ClientJdbcTableMetadataRequest
Processes remote JdbcMetaTablesRequest.
process(ClientMessageUnpacker, TxManager, ClientResourceRegistry, ClientHandlerMetricSource, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.tx.ClientTransactionBeginRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables) - Static method in class org.apache.ignite.client.handler.requests.table.ClientStreamerBatchSendRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTableGetQualifiedRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTableGetRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables) - Static method in class org.apache.ignite.client.handler.requests.table.partition.ClientTablePartitionPrimaryReplicasNodesGetRequest
Process the request.
process(ClientMessageUnpacker, IgniteTables, boolean, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientStreamerWithReceiverBatchSendRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleDeleteAllExactRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleDeleteAllRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleDeleteExactRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleDeleteRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleGetAndDeleteRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleGetAndReplaceRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleGetAndUpsertRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleInsertAllRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleInsertRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleReplaceExactRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleReplaceRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleUpsertAllRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, NotificationSender, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleUpsertRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleContainsAllKeysRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleContainsKeyRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleGetAllRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, ClientResourceRegistry, TxManager, ClockService, HybridTimestampTracker) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTupleGetRequest
Processes the request.
process(ClientMessageUnpacker, IgniteTables, SchemaVersions) - Static method in class org.apache.ignite.client.handler.requests.table.ClientSchemasGetRequest
Processes the request.
process(IgniteCluster) - Static method in class org.apache.ignite.client.handler.requests.cluster.ClientClusterGetNodesRequest
Processes the request.
process(IgniteTables) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTablesGetQualifiedRequest
Processes the request.
process(IgniteTables) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTablesGetRequest
Processes the request.
progressFileToRead() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.MigrateCacheParams
 
PROTOCOL_COMPATIBILITY_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
Incompatible protocol version.
PROTOCOL_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
Protocol breakdown.
provideTestArgs() - Static method in class org.apache.ignite.migrationtools.tests.e2e.framework.runners.JdbcTestBootstrap
Arguments provider.
provideTestClasses() - Method in interface org.apache.ignite.migrationtools.tests.e2e.framework.core.ExampleBasedCacheTestProvider
 
PublicName - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation allows defining configuration property name that is otherwise impossible to define in configuration schema.
publishCacheCursor(List<MigrationKernalContext>, String, BiFunction<Flow.Publisher<Map.Entry<Object, Object>>, Integer, Optional<CompletableFuture<Void>>>) - Static method in class org.apache.ignite.migrationtools.persistence.Ignite2PersistentCacheTools
Publishes a cache cursor on the given nodes.
publishCacheCursorAtNode(MigrationKernalContext, DynamicCacheDescriptor, BiFunction<Flow.Publisher<Map.Entry<Object, Object>>, Integer, Optional<CompletableFuture<Void>>>) - Static method in class org.apache.ignite.migrationtools.persistence.Ignite2PersistentCacheTools
Publishes a cache cursor on the given node.
put(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Puts into a table a value associated with the given key.
put(ClientResource) - Method in class org.apache.ignite.client.handler.ClientResourceRegistry
Stores the resource and returns the generated id.
PUT - Enum constant in enum class org.apache.ignite.table.DataStreamerOperationType
Put operation.
putAll(Transaction, Map<K, V>) - Method in interface org.apache.ignite.table.KeyValueView
Puts associated key-value pairs.
putAllAsync(Transaction, Map<K, V>) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously puts associated key-value pairs.
putAsync(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously puts into a table a value associated with the given key.
putIfAbsent(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Puts into a table a value associated with the given key if this value does not exists.
putIfAbsentAsync(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously puts into a table a value associated with the given key if this value does not exist.

Q

qualifiedName() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns qualified table name.
qualifiedName() - Method in interface org.apache.ignite.table.Table
Gets the qualified name of the table.
qualifiedName(CacheConfiguration<?, ?>) - Static method in class org.apache.ignite.migrationtools.sql.SqlDdlGenerator
Computes the cache qualified name from a cache configuration.
QualifiedName - Class in org.apache.ignite.table
Class represents a catalog object name (table, index and etc.) and provides factory methods.
QualifiedNameHelper - Class in org.apache.ignite.table
Utility class to provide direct access to internals of QualifiedName.
query() - Method in interface org.apache.ignite.sql.Statement
Returns a string representation of an SQL statement.
query(Transaction, Criteria) - Method in interface org.apache.ignite.table.criteria.CriteriaQuerySource
Executes predicate-based criteria query.
query(Transaction, Criteria, String) - Method in interface org.apache.ignite.table.criteria.CriteriaQuerySource
Executes predicate-based criteria query.
query(Transaction, Criteria, String, CriteriaQueryOptions) - Method in interface org.apache.ignite.table.criteria.CriteriaQuerySource
Executes a predicate-based criteria query.
query(String) - Method in interface org.apache.ignite.sql.Statement.StatementBuilder
Sets an SQL statement string.
QUERY_NO_RESULT_SET_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
Query without a result set error.
queryAsync(long, JdbcQueryExecuteRequest) - Method in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
queryAsync(Transaction, Criteria) - Method in interface org.apache.ignite.table.criteria.CriteriaQuerySource
Executes a predicate-based criteria query in an asynchronous way.
queryAsync(Transaction, Criteria, String) - Method in interface org.apache.ignite.table.criteria.CriteriaQuerySource
Executes a predicate-based criteria query in an asynchronous way.
queryAsync(Transaction, Criteria, String, CriteriaQueryOptions) - Method in interface org.apache.ignite.table.criteria.CriteriaQuerySource
Executes a predicate-based criteria query in an asynchronous way.
QueryExample - Class in org.apache.ignite.example.table
 
QueryExample() - Constructor for class org.apache.ignite.example.table.QueryExample
 
queryTimeout(long, TimeUnit) - Method in interface org.apache.ignite.sql.Statement.StatementBuilder
Sets a query timeout.
queryTimeout(TimeUnit) - Method in interface org.apache.ignite.sql.Statement
Returns a query timeout.
queryType() - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcQueryCursor
QUEUE_OVERFLOW_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Compute execution queue overflow error.
QUEUED - Enum constant in enum class org.apache.ignite.compute.JobStatus
The job is submitted and waiting for an execution start.
QUEUED - Enum constant in enum class org.apache.ignite.compute.TaskStatus
The task is submitted and waiting for an execution start.
quorumSize() - Element in annotation interface org.apache.ignite.catalog.annotations.Zone
Quorum size.
quorumSize() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns quorum size.
quorumSize(Integer) - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Sets quorum size.
quoteIfNeeded(String) - Static method in class org.apache.ignite.lang.util.IgniteNameUtils
Wraps the given name with double quotes if it is not uppercased non-quoted name, e.g.

R

Range - Annotation Interface in org.apache.ignite.configuration.validation
Signifies that this value has lower limit (inclusive) and has upper limit (inclusive).
rateLimiter() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.MigrateCacheParams
 
RateLimiterProcessor<S> - Class in org.apache.ignite.migrationtools.persistence.utils.pubsub
Limits the upstream rate of the downstream processor/publisher.
RateLimiterProcessor(long, TimeUnit, int) - Constructor for class org.apache.ignite.migrationtools.persistence.utils.pubsub.RateLimiterProcessor
Constructor.
readDataOnRecovery() - Method in class org.apache.ignite.migrationtools.config.storage.NoDefaultsStorageConfiguration
 
readOnly() - Method in class org.apache.ignite.tx.TransactionOptions
Returns a value indicating whether a read-only transaction should be used.
readOnly(boolean) - Method in class org.apache.ignite.tx.TransactionOptions
Sets a value indicating whether a read-only transaction should be used.
readTableAsync(int, IgniteTables) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTableCommon
Reads a table.
readTuple(int, BitSet, byte[], TableViewInternal, boolean) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTableCommon
 
readTuple(BitSet, byte[], boolean, SchemaDescriptor) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTableCommon
Reads a tuple.
readTx(ClientMessageUnpacker, HybridTimestampTracker, ClientResourceRegistry, TxManager, NotificationSender, long[]) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTableCommon
Reads transaction.
REAL - Static variable in class org.apache.ignite.catalog.ColumnType
REAL SQL column type.
receive(List<Tuple>, DataStreamerReceiverContext, Void) - Method in class org.apache.ignite.example.streaming.TwoTableReceiver
 
receive(List<T>, DataStreamerReceiverContext, A) - Method in interface org.apache.ignite.table.DataStreamerReceiver
receiverClassName() - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor
Streamer receiver class name.
receiverClassName() - Method in class org.apache.ignite.table.ReceiverDescriptor
Deprecated.
Streamer receiver class name.
ReceiverDescriptor<A> - Class in org.apache.ignite.table
Deprecated.
ReceiverDescriptor.Builder<A> - Class in org.apache.ignite.table
Deprecated.
Builder.
ReceiverExecutionOptions - Class in org.apache.ignite.table
Streamer receiver execution options.
ReceiverExecutionOptions.Builder - Class in org.apache.ignite.table
ReceiverExecutionOptions builder.
RECIPIENT_LEFT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Network
Recipient node has left the physical topology.
record(Class<?>) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets record class to generate columns.
RecordAndTableSchemaMismatchException - Exception in org.apache.ignite.migrationtools.persistence.mappers
RecordAndTableSchemaMismatchException.
RecordAndTableSchemaMismatchException(Collection<String>, Collection<String>) - Constructor for exception org.apache.ignite.migrationtools.persistence.mappers.RecordAndTableSchemaMismatchException
Constructor.
RecordAndTableSchemaMismatchExceptionHandler - Class in org.apache.ignite.migrationtools.cli.exceptions
RecordAndTableSchemaMismatchExceptionHandler.
RecordAndTableSchemaMismatchExceptionHandler() - Constructor for class org.apache.ignite.migrationtools.cli.exceptions.RecordAndTableSchemaMismatchExceptionHandler
 
RecordMappingException(String) - Constructor for exception org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor.RecordMappingException
 
recordView() - Method in interface org.apache.ignite.table.Table
Gets a record view of the table.
recordView(Class<R>) - Method in interface org.apache.ignite.table.Table
Gets a record view of the table using the default mapper for the specified record class.
recordView(Mapper<R>) - Method in interface org.apache.ignite.table.Table
Gets a record view of the table using the specified record class mapper.
RecordView<R> - Interface in org.apache.ignite.table
Table view interface provides methods to access table records.
RecordViewExample - Class in org.apache.ignite.example.table
This example demonstrates the usage of the RecordView API.
RecordViewExample() - Constructor for class org.apache.ignite.example.table.RecordViewExample
 
RecordViewPojoExample - Class in org.apache.ignite.example.table
This example demonstrates the usage of the RecordView API with user-defined POJOs.
RecordViewPojoExample() - Constructor for class org.apache.ignite.example.table.RecordViewPojoExample
 
RECOVERY_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
Disaster recovery group.
reduceAsync(TaskExecutionContext, Map<UUID, Integer>) - Method in class org.apache.ignite.example.compute.ComputeMapReduceExample.PhraseWordLengthCountMapReduceTask
This is a finishing step in the task execution.
reduceAsync(TaskExecutionContext, Map<UUID, T>) - Method in interface org.apache.ignite.compute.task.MapReduceTask
This is a finishing step in the task execution.
reduceJobResultClass() - Method in class org.apache.ignite.compute.TaskDescriptor
Reduce job result class.
reduceJobResultClass(Class<R>) - Method in class org.apache.ignite.compute.TaskDescriptor.Builder
Sets the reduce job result class.
reduceJobResultMarshaller() - Method in interface org.apache.ignite.compute.task.MapReduceTask
The marshaller that is called to marshal reduce job result if not null.
reduceJobResultMarshaller() - Method in class org.apache.ignite.compute.TaskDescriptor
Marshaller for reduce job result.
reduceJobResultMarshaller(Marshaller<R, byte[]>) - Method in class org.apache.ignite.compute.TaskDescriptor.Builder
Sets the marshaller for reduce job result.
registerComputeExecutorId(String) - Method in class org.apache.ignite.client.handler.ClientHandlerModule
 
registerConfigurationListener(ConfigurationStorageListener) - Method in class org.apache.ignite.migrationtools.config.storage.NoDefaultsStorageConfiguration
 
registerCustomEditor(Class<?>, PropertyEditor) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
registerCustomEditor(Class<?>, String, PropertyEditor) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
registerErrorCode(short) - Method in class org.apache.ignite.lang.ErrorGroup
Registers a new error code within this error group.
registerGroup(String, short) - Static method in class org.apache.ignite.lang.ErrorGroups
Creates a new error group with the given groupName and groupCode and default error prefix.
registerGroup(String, String, short) - Static method in class org.apache.ignite.lang.ErrorGroups
Creates a new error group with the given groupName and groupCode.
RegisterOnlyTableTypeRegistry - Class in org.apache.ignite.migrationtools.tablemanagement
Decorator for TableTypeRegistry that only registers new hints.
RegisterOnlyTableTypeRegistry(TableTypeRegistry) - Constructor for class org.apache.ignite.migrationtools.tablemanagement.RegisterOnlyTableTypeRegistry
 
registerTypesForTable(String, TableTypeDescriptor) - Method in class org.apache.ignite.migrationtools.tablemanagement.PersistentTableTypeRegistryImpl
 
registerTypesForTable(String, TableTypeDescriptor) - Method in class org.apache.ignite.migrationtools.tablemanagement.RegisterOnlyTableTypeRegistry
 
registerTypesForTable(String, TableTypeDescriptor) - Method in interface org.apache.ignite.migrationtools.tablemanagement.TableTypeRegistry
Registers the supplied type hints for the given table.
registerTypesForTable(String, TableTypeDescriptor) - Method in class org.apache.ignite.migrationtools.tablemanagement.TableTypeRegistryMapImpl
 
release() - Method in class org.apache.ignite.client.handler.ClientResource
Releases resources.
remoteAddress() - Method in class org.apache.ignite.client.handler.ClientContext
 
remove(long) - Method in class org.apache.ignite.client.handler.ClientResourceRegistry
Removes the resource.
remove(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Removes from a table a value associated with the given key.
remove(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Removes from a table an expected value associated with the given key.
REMOVE - Enum constant in enum class org.apache.ignite.table.DataStreamerOperationType
Remove operation.
removeAll(Transaction) - Method in interface org.apache.ignite.table.KeyValueView
Removes all entries from a table.
removeAll(Transaction, Collection<K>) - Method in interface org.apache.ignite.table.KeyValueView
Removes from a table values associated with the given keys.
removeAllAsync(Transaction) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously remove all entries from a table.
removeAllAsync(Transaction, Collection<K>) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously remove from a table values associated with the given keys.
removeAsync(Transaction, K) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously removes from a table a value associated with the given key.
removeAsync(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously removes from a table an expected value associated with the given key.
removed(T) - Static method in interface org.apache.ignite.table.DataStreamerItem
Creates a new data streamer item with the given data and DataStreamerOperationType.REMOVE operation type.
rename(String, String) - Method in interface org.apache.ignite.configuration.NamedListChange
Renames the existing value in the named list configuration.
render() - Method in class org.apache.ignite.deployment.DeploymentUnit
 
render() - Method in interface org.apache.ignite.deployment.version.Version
Render version representation in String format.
replace(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Replaces a value for a key if it exists.
replace(Transaction, K, V, V) - Method in interface org.apache.ignite.table.KeyValueView
Replaces an expected value for a key.
replace(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Replaces an existing record associated with the same key column values as the given record.
replace(Transaction, R, R) - Method in interface org.apache.ignite.table.RecordView
Replaces an expected record in the table with the given new one.
replaceAsync(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously replaces a value for a key if it exists.
replaceAsync(Transaction, K, V, V) - Method in interface org.apache.ignite.table.KeyValueView
Asynchronously replaces an expected value for a key.
replaceAsync(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Asynchronously replaces an existing record associated with the same key columns values as the given record.
replaceAsync(Transaction, R, R) - Method in interface org.apache.ignite.table.RecordView
Asynchronously replaces an existing record in the table with the given new one.
REPLICA_COMMON_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Replicator
Common error for the replication procedure.
REPLICA_IS_ALREADY_STARTED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Replicator
Replica with the same identifier is already existed.
REPLICA_MISS_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Replicator
The error happens when the replica is not the current primary replica.
REPLICA_STOPPING_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Replicator
Stopping replica exception code.
REPLICA_TIMEOUT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Replicator
Timeout has happened during the replication procedure.
REPLICA_UNAVAILABLE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Replicator
The error happens when the replica is not ready to handle a request.
REPLICA_UNSUPPORTED_REQUEST_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Replicator
The error happens when the replication level try to handle an unsupported request.
replicas() - Element in annotation interface org.apache.ignite.catalog.annotations.Zone
Number of replicas.
replicas() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns number of replicas.
replicas(Integer) - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Sets the number of replicas.
Replicator() - Constructor for class org.apache.ignite.lang.ErrorGroups.Replicator
 
REPLICATOR_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Replicator
Replicator error group.
request(long) - Method in class org.apache.ignite.migrationtools.persistence.utils.pubsub.StreamerPublisher
 
requestNextAsync(int) - Method in class org.apache.ignite.client.handler.requests.jdbc.JdbcQueryCursor
requestsActive() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets active requests.
requestsFailed() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets failed requests.
requestsProcessed() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets processed requests.
resolveTableName(String) - Static method in class org.apache.ignite.migrationtools.tablemanagement.Namespace
Resolves the full table name for a table inside our namespace.
RESOURCE_CLOSING_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
Resource closing error.
resources - Variable in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
Client registry resources.
resources() - Method in class org.apache.ignite.client.handler.ClientInboundMessageHandler
 
ResponseWriter - Interface in org.apache.ignite.client.handler
Response writer.
Rest() - Constructor for class org.apache.ignite.lang.ErrorGroups.Rest
 
REST_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Rest
REST service error group.
restHost() - Method in class org.apache.ignite.network.NodeMetadata
 
RESTORING_STORAGE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.MetaStorage
Failed to restore the underlying key value storage.
RESULT_NOT_FOUND_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Compute
Compute job result not found error.
resultAsync() - Method in interface org.apache.ignite.compute.JobExecution
Returns job's execution result.
resultAsync() - Method in interface org.apache.ignite.compute.task.TaskExecution
Returns task's execution result.
resultClass() - Method in class org.apache.ignite.compute.JobDescriptor
 
resultClass(Class<R>) - Method in class org.apache.ignite.compute.JobDescriptor.Builder
Sets the result class.
resultMarshaller() - Method in interface org.apache.ignite.compute.ComputeJob
Marshaller for the job result.
resultMarshaller() - Method in class org.apache.ignite.compute.JobDescriptor
 
resultMarshaller() - Method in class org.apache.ignite.example.compute.ComputeWithCustomResultMarshallerExample.WordInfoJob
Marshaller for the job result.
resultMarshaller() - Method in class org.apache.ignite.example.serialization.CustomPojoSerializationJob
 
resultMarshaller() - Method in interface org.apache.ignite.table.DataStreamerReceiver
Marshaller for the job result.
resultMarshaller() - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor
Result marshaller.
resultMarshaller(Marshaller<R, byte[]>) - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor.Builder
Sets the result marshaller.
resultMarshaller(Marshaller<R, byte[]>) - Method in class org.apache.ignite.compute.JobDescriptor.Builder
Sets the result marshaller.
resultsAsync() - Method in interface org.apache.ignite.compute.BroadcastExecution
Returns all jobs execution results.
ResultSet<T> - Interface in org.apache.ignite.sql
Provides methods to access SQL query results represented by a collection of SqlRow.
ResultSetMetadata - Interface in org.apache.ignite.sql
ResultSet metadata.
RetriableMigrateCacheCall - Class in org.apache.ignite.migrationtools.cli.persistence.calls
Call for the Retrieable Migrate Cache Command.
RetriableMigrateCacheCall(MigrateCacheCall) - Constructor for class org.apache.ignite.migrationtools.cli.persistence.calls.RetriableMigrateCacheCall
 
RetriableMigrateCacheCall.Input - Class in org.apache.ignite.migrationtools.cli.persistence.calls
Inputs.
RetriableTransactionException - Interface in org.apache.ignite.tx
RetrieableMigrateCacheParams - Class in org.apache.ignite.migrationtools.cli.persistence.params
Parameter for the Retriable Migrate Cache command.
RetrieableMigrateCacheParams(int, int) - Constructor for class org.apache.ignite.migrationtools.cli.persistence.params.RetrieableMigrateCacheParams
 
retryBackoffSeconds() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.RetrieableMigrateCacheParams
 
retryLimit() - Method in class org.apache.ignite.client.RetryLimitPolicy
Gets the retry limit.
retryLimit() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.RetrieableMigrateCacheParams
 
retryLimit() - Method in class org.apache.ignite.table.DataStreamerOptions
Gets the retry limit for a page.
retryLimit(int) - Method in class org.apache.ignite.client.RetryLimitPolicy
Sets the retry limit.
retryLimit(int) - Method in class org.apache.ignite.table.DataStreamerOptions.Builder
Sets the retry limit for a page.
RetryLimitPolicy - Class in org.apache.ignite.client
Retry policy that returns true when RetryPolicyContext.iteration() is less than the specified RetryLimitPolicy.retryLimit().
RetryLimitPolicy() - Constructor for class org.apache.ignite.client.RetryLimitPolicy
 
retryPolicy() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the retry policy.
retryPolicy(RetryPolicy) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the retry policy.
RetryPolicy - Interface in org.apache.ignite.client
Client retry policy determines whether client operations that have failed due to a connection issue should be retried.
RetryPolicyContext - Interface in org.apache.ignite.client
Retry policy context.
RetryReadPolicy - Class in org.apache.ignite.client
Retry policy that returns true for all read-only operations that do not modify data.
RetryReadPolicy() - Constructor for class org.apache.ignite.client.RetryReadPolicy
 
RocksDbStorageExample - Class in org.apache.ignite.example.storage
This example demonstrates a usage of the RocksDB storage engine.
RocksDbStorageExample() - Constructor for class org.apache.ignite.example.storage.RocksDbStorageExample
 
rollback() - Method in interface org.apache.ignite.tx.Transaction
Synchronously rolls back a transaction.
rollbackAsync() - Method in interface org.apache.ignite.tx.Transaction
Asynchronously rolls back a transaction.
RootKey<T extends ConfigurationTree<? super VIEWT,? super CHANGET>,VIEWT,CHANGET extends VIEWT> - Class in org.apache.ignite.configuration
Configuration root selector.
RootKey(String, ConfigurationType, Class<?>, boolean) - Constructor for class org.apache.ignite.configuration.RootKey
Constructor with explicit fields values.
rootKeys() - Method in interface org.apache.ignite.configuration.ConfigurationModule
Returns keys of configuration roots provided by this module.
rootName() - Element in annotation interface org.apache.ignite.configuration.annotation.ConfigurationRoot
Returns the unique root name.
RunIgnite2Cluster - Class in org.apache.ignite.migrationtools.tests.utils
RunIgnite2Cluster.
RunIgnite2Cluster() - Constructor for class org.apache.ignite.migrationtools.tests.utils.RunIgnite2Cluster
 
RunIgnite3Cluster - Class in org.apache.ignite.migrationtools.tests.utils
RunIgnite3Cluster.
RunIgnite3Cluster() - Constructor for class org.apache.ignite.migrationtools.tests.utils.RunIgnite3Cluster
 
runInTransaction(Consumer<Transaction>) - Method in interface org.apache.ignite.tx.IgniteTransactions
Executes a closure within a transaction.
runInTransaction(Consumer<Transaction>, TransactionOptions) - Method in interface org.apache.ignite.tx.IgniteTransactions
Executes a closure within a transaction.
runInTransaction(Function<Transaction, T>) - Method in interface org.apache.ignite.tx.IgniteTransactions
Executes a closure within a transaction and returns a result.
runInTransaction(Function<Transaction, T>, TransactionOptions) - Method in interface org.apache.ignite.tx.IgniteTransactions
Executes a closure within a transaction and returns a result.
runInTransactionAsync(Function<Transaction, CompletableFuture<T>>) - Method in interface org.apache.ignite.tx.IgniteTransactions
Executes a closure within a transaction asynchronously.
runInTransactionAsync(Function<Transaction, CompletableFuture<T>>, TransactionOptions) - Method in interface org.apache.ignite.tx.IgniteTransactions
Executes a closure within a transaction asynchronously.
runTest(SqlTest) - Method in class org.apache.ignite.migrationtools.tests.e2e.framework.runners.JdbcTestBootstrap
 
RUNTIME_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
Runtime error.

S

SAMPLE_CLUSTERS_PATH - Static variable in class org.apache.ignite.migrationtools.tests.clusters.FullSampleCluster
 
saveProgressFileDisabled() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.MigrateCacheParams
 
scale() - Element in annotation interface org.apache.ignite.catalog.annotations.Column
The scale of the numeric type.
scale() - Method in class org.apache.ignite.catalog.ColumnType
Returns scale of the column type.
scale() - Method in interface org.apache.ignite.sql.ColumnMetadata
Returns an SQL column scale or -1 if scale is not applicable to the column's type.
scaleAllowed() - Method in enum class org.apache.ignite.sql.ColumnType
If true scale need to be specified, false otherwise.
schema(String) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets schema name.
SCHEMA_NOT_FOUND_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
Deprecated.
SCHEMA_VERSION_MISMATCH_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Table
Schema version mismatch.
schemaClass() - Method in class org.apache.ignite.configuration.RootKey
Returns the schema class for the root.
SchemaColumnProcessorStats - Class in org.apache.ignite.migrationtools.persistence.mappers
SchemaColumnProcessorStats.
SchemaColumnProcessorStats(long) - Constructor for class org.apache.ignite.migrationtools.persistence.mappers.SchemaColumnProcessorStats
 
SchemaColumnsProcessor - Interface in org.apache.ignite.migrationtools.persistence.mappers
SchemaColumnsProcessor.
schemaExtensions() - Method in class org.apache.ignite.client.handler.configuration.ClientHandlerConfigurationModule
 
schemaExtensions() - Method in interface org.apache.ignite.configuration.ConfigurationModule
Returns classes of schema extensions (annotated with ConfigurationExtension) provided by this module, including internal extensions.
schemaName() - Element in annotation interface org.apache.ignite.catalog.annotations.Table
The schema name.
schemaName() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns schema name.
schemaName() - Method in interface org.apache.ignite.sql.ColumnMetadata.ColumnOrigin
Returns a column table's schema.
schemaName() - Method in class org.apache.ignite.table.QualifiedName
Returns normalized schema name.
SchemaNotFoundException - Exception in org.apache.ignite.lang
Deprecated.
No longer used. Use SqlException with ErrorGroups.Sql.STMT_VALIDATION_ERR error code.
SchemaNotFoundException(String) - Constructor for exception org.apache.ignite.lang.SchemaNotFoundException
Deprecated.
Creates an exception with the given schema name.
SchemaNotFoundException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.SchemaNotFoundException
Deprecated.
Creates an exception with the given trace ID, error code, detailed message, and cause.
schemasMetaAsync(JdbcMetaSchemasRequest) - Method in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
SchemaUtils - Class in org.apache.ignite.migrationtools.tablemanagement
Utility methods to interact with internal client schemas.
secret() - Method in class org.apache.ignite.client.BasicAuthenticator
 
secret() - Method in interface org.apache.ignite.client.IgniteClientAuthenticator
Secret.
Secret - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation is used to mark a configuration field as sensitive information.
SELECT_STATEMENT_QUERIES - Static variable in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
SqlQueryTypes allowed in JDBC select statements.
sendNotification(Consumer<ClientMessagePacker>, Throwable, long) - Method in interface org.apache.ignite.client.handler.NotificationSender
 
sendServerExceptionStackTraceToClient - Variable in class org.apache.ignite.client.handler.configuration.ClientConnectorConfigurationSchema
Server exception stack trace visibility.
SerializationExample - Class in org.apache.ignite.example.serialization
 
SerializationExample() - Constructor for class org.apache.ignite.example.serialization.SerializationExample
 
SERVER_TO_CLIENT_REQUEST_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
Server to client request failed.
serverAddress() - Method in class org.apache.ignite.client.handler.ClientHandlerModule
 
serviceLoaderClassLoader(ClassLoader) - Method in class org.apache.ignite.IgniteServer.Builder
Specifies class loader to use when loading components via ServiceLoader.
sessionsAccepted() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets total accepted sessions.
sessionsActive() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets active sessions.
sessionsRejected() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets total rejected sessions.
sessionsRejectedTimeout() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets sessions rejected due to a timeout.
sessionsRejectedTls() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets sessions rejected due to TLS errors.
set(int, Object) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
set(String, Object) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
set(String, Object) - Method in interface org.apache.ignite.table.Tuple
Sets a column value.
setActive(boolean) - Method in class org.apache.ignite.example.streaming.Account
 
setAddresses(String[]) - Method in class org.apache.ignite.IgniteClientProperties
Sets connection addresses.
setAddressFinder(IgniteClientAddressFinder) - Method in class org.apache.ignite.IgniteClientProperties
Sets ignite client address finder.
setAge(int) - Method in class org.apache.ignite.example.table.Person
 
setAmount(int) - Method in class org.apache.ignite.migrationtools.tests.models.SimplePojo
 
setAsyncContinuationExecutor(Executor) - Method in class org.apache.ignite.IgniteClientProperties
Sets async continuation executor.
setAuth(IgniteClientProperties.AuthenticationProperties) - Method in class org.apache.ignite.IgniteClientProperties
Sets authentication properties.
setAuthenticator(IgniteClientAuthenticator) - Method in class org.apache.ignite.IgniteClientProperties
Sets ignite client authenticator.
setAutoGrowCollectionLimit(int) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
setAutoGrowNestedPaths(boolean) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
setBackgroundReconnectInterval(Long) - Method in class org.apache.ignite.IgniteClientProperties
Sets reconnect interval.
setBalance(long) - Method in class org.apache.ignite.example.streaming.Account
 
setBasic(IgniteClientProperties.BasicAuthProperties) - Method in class org.apache.ignite.IgniteClientProperties.AuthenticationProperties
 
setCiphers(Iterable<String>) - Method in class org.apache.ignite.SslConfigurationProperties
 
setCityId(String) - Method in class org.apache.ignite.example.table.Person
 
setCompany(String) - Method in class org.apache.ignite.example.table.Person
 
setConnectTimeout(Long) - Method in class org.apache.ignite.IgniteClientProperties
Gets connection timeout.
setConversionService(ConversionService) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
setDecimalAmount(BigDecimal) - Method in class org.apache.ignite.migrationtools.tests.models.SimplePojo
 
setEnabled(Boolean) - Method in class org.apache.ignite.SslConfigurationProperties
 
setExtractOldValueForEditor(boolean) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
setHeartbeatInterval(Long) - Method in class org.apache.ignite.IgniteClientProperties
Sets heartbeat interval.
setHeartbeatTimeout(Long) - Method in class org.apache.ignite.IgniteClientProperties
Sets heartbeat timeout.
setId(int) - Method in class org.apache.ignite.example.streaming.Account
 
setId(int) - Method in class org.apache.ignite.example.table.Person
 
setKeyStorePassword(String) - Method in class org.apache.ignite.SslConfigurationProperties
 
setKeyStorePath(String) - Method in class org.apache.ignite.SslConfigurationProperties
 
setLoggerFactory(LoggerFactory) - Method in class org.apache.ignite.IgniteClientProperties
Sets logger factory.
setMetricsEnabled(Boolean) - Method in class org.apache.ignite.IgniteClientProperties
Sets if metrics enabled.
setName(String) - Method in class org.apache.ignite.example.streaming.Account
 
setName(String) - Method in class org.apache.ignite.example.table.Person
 
setName(String) - Method in class org.apache.ignite.migrationtools.tests.models.SimplePojo
 
setNumberOfSamples() - Static method in class org.apache.ignite.migrationtools.tests.e2e.framework.runners.JdbcTestBootstrap
 
setOperationTimeout(Long) - Method in class org.apache.ignite.IgniteClientProperties
Sets operation timeout.
setPassword(String) - Method in class org.apache.ignite.IgniteClientProperties.BasicAuthProperties
 
setPropertyValue(String, Object) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
setPropertyValue(PropertyValue) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
setPropertyValues(Map<?, ?>) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
setPropertyValues(PropertyValues) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
setPropertyValues(PropertyValues, boolean) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
setPropertyValues(PropertyValues, boolean, boolean) - Method in class org.apache.ignite.migrationtools.config.loader.BeanWrapperSpy
 
setRetryPolicy(RetryPolicy) - Method in class org.apache.ignite.IgniteClientProperties
Sets retry policy.
setSslConfiguration(SslConfigurationProperties) - Method in class org.apache.ignite.IgniteClientProperties
Sets SSL configuration.
setTrustStorePassword(String) - Method in class org.apache.ignite.SslConfigurationProperties
 
setTrustStorePath(String) - Method in class org.apache.ignite.SslConfigurationProperties
 
setupClient() - Method in class org.apache.ignite.migrationtools.tests.e2e.framework.runners.JdbcTestBootstrap
 
setUsername(String) - Method in class org.apache.ignite.IgniteClientProperties.BasicAuthProperties
 
shortValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
shortValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a short column value.
shortValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
shortValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a short column value.
shouldIgnore(String) - Method in interface org.apache.ignite.configuration.KeyIgnorer
Returns true if key should be ignored.
shouldRetry(RetryPolicyContext) - Method in class org.apache.ignite.client.RetryLimitPolicy
Gets a value indicating whether a client operation that has failed due to a connection issue should be retried.
shouldRetry(RetryPolicyContext) - Method in interface org.apache.ignite.client.RetryPolicy
Gets a value indicating whether a client operation that has failed due to a connection issue should be retried.
shouldRetry(RetryPolicyContext) - Method in class org.apache.ignite.client.RetryReadPolicy
Gets a value indicating whether a client operation that has failed due to a connection issue should be retried.
shutdown() - Method in interface org.apache.ignite.IgniteServer
Stops the node synchronously.
shutdownAsync() - Method in interface org.apache.ignite.IgniteServer
Stops the node.
SimplePojo - Class in org.apache.ignite.migrationtools.tests.models
Simple Pojo.
SimplePojo(String, int, BigDecimal) - Constructor for class org.apache.ignite.migrationtools.tests.models.SimplePojo
Constructor.
SimpleSchemaColumnsProcessor - Class in org.apache.ignite.migrationtools.persistence.mappers
Provides a mapping layer between Ignite 2 Tuples (created from Binary Objects) and a Ignite 3 table schema.
SimpleSchemaColumnsProcessor(ClientSchema, Map<String, String>, TypeConverterFactory) - Constructor for class org.apache.ignite.migrationtools.persistence.mappers.SimpleSchemaColumnsProcessor
 
SimpleSchemaColumnsProcessor(ClientSchema, Map<String, String>, TypeConverterFactory, boolean) - Constructor for class org.apache.ignite.migrationtools.persistence.mappers.SimpleSchemaColumnsProcessor
 
simpleTypes() - Method in class org.apache.ignite.data.IgniteDialect
 
SingleTableDataStreamerExample - Class in org.apache.ignite.example.streaming
This example demonstrates how to use the streaming API to configure the data streamer, insert account records into the existing Accounts table and then delete them.
SingleTableDataStreamerExample() - Constructor for class org.apache.ignite.example.streaming.SingleTableDataStreamerExample
 
size() - Method in interface org.apache.ignite.configuration.NamedListView
Returns the number of elements in this list.
size() - Method in class org.apache.ignite.sql.BatchedArguments
Returns the size of this batch.
SKIP_RECORD - Enum constant in enum class org.apache.ignite.migrationtools.cli.persistence.params.MigrationMode
The whole cache record will be ignored (not migrated to the table; lost).
SkippedRecordsStats(long, long) - Constructor for class org.apache.ignite.migrationtools.persistence.mappers.SkipRecordsSchemaColumnsProcessor.SkippedRecordsStats
 
SkipRecordsSchemaColumnsProcessor - Class in org.apache.ignite.migrationtools.persistence.mappers
Provides a mapping layer between Ignite 2 Tuples (created from Binary Objects) and a Ignite 3 table schema.
SkipRecordsSchemaColumnsProcessor(ClientSchema, Map<String, String>, TypeConverterFactory) - Constructor for class org.apache.ignite.migrationtools.persistence.mappers.SkipRecordsSchemaColumnsProcessor
 
SkipRecordsSchemaColumnsProcessor.SkippedRecordsStats - Class in org.apache.ignite.migrationtools.persistence.mappers
SkippedRecordsStats.
SkipUnsupportedOperationsHandlers - Class in org.apache.ignite.migrationtools.handlers
Automatically skips tests if based on exceptions thrown for unimplemented features.
SkipUnsupportedOperationsHandlers() - Constructor for class org.apache.ignite.migrationtools.handlers.SkipUnsupportedOperationsHandlers
 
SMALLINT - Static variable in class org.apache.ignite.catalog.ColumnType
SMALLINT SQL column type.
sort() - Element in annotation interface org.apache.ignite.catalog.annotations.ColumnRef
Sort order.
sort(SortOrder) - Method in class org.apache.ignite.catalog.ColumnSorted
Assigns specified order.
SORTED - Enum constant in enum class org.apache.ignite.catalog.IndexType
 
sortOrder() - Method in class org.apache.ignite.catalog.ColumnSorted
Returns sort order.
SortOrder - Enum Class in org.apache.ignite.catalog
Sort order.
splitAsync(TaskExecutionContext, I) - Method in interface org.apache.ignite.compute.task.MapReduceTask
This method should return a list of compute job execution parameters which will be used to submit compute jobs.
splitAsync(TaskExecutionContext, String) - Method in class org.apache.ignite.example.compute.ComputeMapReduceExample.PhraseWordLengthCountMapReduceTask
This method should return a list of compute job execution parameters which will be used to submit compute jobs.
splitJobArgumentMarshaller() - Method in class org.apache.ignite.compute.TaskDescriptor
Marshaller for split job argument.
splitJobArgumentMarshaller(Marshaller<T, byte[]>) - Method in class org.apache.ignite.compute.TaskDescriptor.Builder
Sets the marshaller for split job argument.
splitJobInputMarshaller() - Method in interface org.apache.ignite.compute.task.MapReduceTask
The marshaller that is called to unmarshal split job argument if not null.
sql() - Method in enum class org.apache.ignite.catalog.SortOrder
Returns SQL string describing this sort order.
sql() - Method in interface org.apache.ignite.Ignite
Returns a facade for the SQL query engine.
Sql() - Constructor for class org.apache.ignite.lang.ErrorGroups.Sql
 
SQL_CURSOR_NEXT_PAGE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
SQL Cursor Next Page (AsyncResultSet.fetchNextPage()).
SQL_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
SQL error group.
SQL_EXECUTE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
SQL_EXECUTE_BATCH - Enum constant in enum class org.apache.ignite.client.ClientOperationType
SQL_EXECUTE_SCRIPT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
SqlApiExample - Class in org.apache.ignite.example.sql
Examples of using SQL API.
SqlApiExample() - Constructor for class org.apache.ignite.example.sql.SqlApiExample
 
SqlBatchException - Exception in org.apache.ignite.sql
Subclass of SqlException is thrown when an error occurs during a batch update operation.
SqlBatchException(UUID, int, long[], String, Throwable) - Constructor for exception org.apache.ignite.sql.SqlBatchException
Creates a grid exception with the given throwable as a cause and source of error message.
SqlBatchException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.sql.SqlBatchException
Creates an exception with the given trace ID, error code, detailed message, and cause.
sqlCountRecordsTest(Connection, String, int) - Static method in class org.apache.ignite.migrationtools.tests.e2e.framework.core.SqlTestUtils
sqlCountRecordsTest.
SqlDateToLocalDateConverter - Class in org.apache.ignite.migrationtools.types.converters
Converts SQL Date to LocalDateTime.
SqlDateToLocalDateConverter() - Constructor for class org.apache.ignite.migrationtools.types.converters.SqlDateToLocalDateConverter
 
SqlDdlGenerator - Class in org.apache.ignite.migrationtools.sql
Generates a SQL DDL Script from Ignite 2 Cache Configurations and custom type hints.
SqlDdlGenerator() - Constructor for class org.apache.ignite.migrationtools.sql.SqlDdlGenerator
 
SqlDdlGenerator(ClassLoader, TableTypeRegistry, boolean) - Constructor for class org.apache.ignite.migrationtools.sql.SqlDdlGenerator
Constructor.
SqlDdlGenerator(TableTypeRegistry) - Constructor for class org.apache.ignite.migrationtools.sql.SqlDdlGenerator
 
SqlDdlGenerator(TableTypeRegistry, boolean) - Constructor for class org.apache.ignite.migrationtools.sql.SqlDdlGenerator
 
SqlDdlGenerator.GenerateTableResult - Class in org.apache.ignite.migrationtools.sql
GenerateTableResult.
SqlDdlGeneratorCall - Class in org.apache.ignite.migrationtools.cli.sql.calls
Call for the SQL Generator command.
SqlDdlGeneratorCall() - Constructor for class org.apache.ignite.migrationtools.cli.sql.calls.SqlDdlGeneratorCall
 
SqlDdlGeneratorCall.Input - Class in org.apache.ignite.migrationtools.cli.sql.calls
Inputs.
SqlDdlGeneratorCmd - Class in org.apache.ignite.migrationtools.cli.sql.commands
SQL Generator command.
SqlDdlGeneratorCmd() - Constructor for class org.apache.ignite.migrationtools.cli.sql.commands.SqlDdlGeneratorCmd
 
SqlException - Exception in org.apache.ignite.sql
SQL exception base class.
SqlException(int) - Constructor for exception org.apache.ignite.sql.SqlException
Creates an exception with the given error code.
SqlException(int, Throwable) - Constructor for exception org.apache.ignite.sql.SqlException
Creates an exception with the given error code and cause.
SqlException(int, String) - Constructor for exception org.apache.ignite.sql.SqlException
Creates an exception with the given error code and detailed message.
SqlException(int, String, Throwable) - Constructor for exception org.apache.ignite.sql.SqlException
Creates an exception with the given error code, detailed message and cause.
SqlException(UUID, int, Throwable) - Constructor for exception org.apache.ignite.sql.SqlException
Creates an exception with the given trace ID, error code, and cause.
SqlException(UUID, int, String) - Constructor for exception org.apache.ignite.sql.SqlException
Creates an exception with the given trace ID, error code, and detailed message.
SqlException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.sql.SqlException
Creates an exception with the given trace ID, error code, detailed message, and cause.
sqlFromTableDefinition(TableDefinition) - Static method in class org.apache.ignite3.internal.catalog.sql.CatalogExtensions
 
SqlJdbcExample - Class in org.apache.ignite.example.sql.jdbc
This example demonstrates the usage of the Apache Ignite JDBC driver.
SqlJdbcExample() - Constructor for class org.apache.ignite.example.sql.jdbc.SqlJdbcExample
 
sqlPartitionAwarenessMetadataCacheSize() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Gets the size of cache to store partition awareness metadata of sql queries, in number of entries.
sqlPartitionAwarenessMetadataCacheSize(int) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the size of cache to store partition awareness metadata of sql queries, in number of entries.
sqlRandomElementTest(Connection, String, String, int, IntFunction<Map.Entry<?, V>>, BiConsumer<V, ResultSet>) - Static method in class org.apache.ignite.migrationtools.tests.e2e.framework.core.SqlTestUtils
sqlRandomElementTest.
SqlRow - Interface in org.apache.ignite.sql
Provides methods to access row data by column name or ID.
SqlTest - Interface in org.apache.ignite.migrationtools.tests.e2e.framework.core
SqlTest.
SqlTestUtils - Class in org.apache.ignite.migrationtools.tests.e2e.framework.core
SqlTestUtils.
SqlTestUtils() - Constructor for class org.apache.ignite.migrationtools.tests.e2e.framework.core.SqlTestUtils
 
SqlTimestampToInstantConverter - Class in org.apache.ignite.migrationtools.types.converters
Converts SQL Timestamp to Instant.
SqlTimestampToInstantConverter() - Constructor for class org.apache.ignite.migrationtools.types.converters.SqlTimestampToInstantConverter
 
SqlTimestampToLocalDateTimeConverter - Class in org.apache.ignite.migrationtools.types.converters
Converts SQL Timestamp to LocalDateTime.
SqlTimestampToLocalDateTimeConverter() - Constructor for class org.apache.ignite.migrationtools.types.converters.SqlTimestampToLocalDateTimeConverter
 
SqlTimeToLocalTimeConverter - Class in org.apache.ignite.migrationtools.types.converters
Converts SQL Time to Local Time.
SqlTimeToLocalTimeConverter() - Constructor for class org.apache.ignite.migrationtools.types.converters.SqlTimeToLocalTimeConverter
 
ssl - Variable in class org.apache.ignite.client.handler.configuration.ClientConnectorConfigurationSchema
SSL configuration schema.
ssl() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
Returns the client SSL configuration.
ssl(SslConfiguration) - Method in class org.apache.ignite.client.IgniteClient.Builder
Sets the SSL configuration.
SSL_CONFIGURATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
SSL can not be configured error.
SslConfiguration - Interface in org.apache.ignite.client
Client SSL configuration.
SslConfiguration.Builder - Class in org.apache.ignite.client
SSL configuration builder.
SslConfigurationProperties - Class in org.apache.ignite
Describes properties for SSL configuration.
SslConfigurationProperties() - Constructor for class org.apache.ignite.SslConfigurationProperties
 
SslContextFactoryConverter - Class in org.apache.ignite.migrationtools.config.converters
SslContextFactoryConverter.
SslContextFactoryConverter() - Constructor for class org.apache.ignite.migrationtools.config.converters.SslContextFactoryConverter
 
sslEnabled() - Method in class org.apache.ignite.client.handler.ClientHandlerModule
 
start() - Method in interface org.apache.ignite.IgniteServer
Starts the node.
start() - Method in class org.apache.ignite.migrationtools.persistence.MigrationCacheProcessor
 
start() - Method in class org.apache.ignite.migrationtools.persistence.MigrationKernalContext
Starts the context.
start() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterContainer
 
start() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
 
start() - Method in class org.apache.ignite.migrationtools.tests.containers.MigrationToolsContainer
 
start(String, Path, Path) - Static method in interface org.apache.ignite.IgniteServer
Starts an embedded Ignite node with a configuration from a HOCON file synchronously.
startAsync() - Method in interface org.apache.ignite.IgniteServer
Starts the node.
startAsync(String, Path, Path) - Static method in interface org.apache.ignite.IgniteServer
Starts an embedded Ignite node with a configuration from a HOCON file.
startAsync(ComponentContext) - Method in class org.apache.ignite.client.handler.ClientHandlerModule
startAsync(ComponentContext) - Method in class org.apache.ignite.migrationtools.config.registry.CombinedConfigRegistry
 
startCache(DynamicCacheDescriptor) - Method in class org.apache.ignite.migrationtools.persistence.MigrationCacheProcessor
Starts a cache.
startExplicitTx(HybridTimestampTracker, TxManager, HybridTimestamp, boolean, InternalTxOptions) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTableCommon
Starts an explicit transaction.
STARTING_STORAGE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.MetaStorage
Failed to start the underlying key value storage.
startTime() - Method in interface org.apache.ignite.compute.JobState
Returns job start time.
startTime() - Method in interface org.apache.ignite.compute.TaskState
Returns task start time.
stateAsync() - Method in interface org.apache.ignite.compute.JobExecution
Returns the current state of the job.
stateAsync() - Method in interface org.apache.ignite.compute.task.TaskExecution
Returns the current state of the task.
Statement - Interface in org.apache.ignite.sql
Object represents an SQL statement.
Statement.StatementBuilder - Interface in org.apache.ignite.sql
Statement builder provides methods for building a statement object, which represents a query and holds query-specific settings that overrides the query execution context defaults.
statementBuilder() - Method in interface org.apache.ignite.sql.IgniteSql
Creates an SQL statement builder, which provides query-specific settings.
statesAsync() - Method in interface org.apache.ignite.compute.task.TaskExecution
Returns a collection of states of the jobs which are executing under this task.
StaticTypeConverterFactory - Class in org.apache.ignite.migrationtools.types.converters
Static Factory for TypeConverter.
status() - Method in interface org.apache.ignite.compute.JobState
Returns job status.
status() - Method in interface org.apache.ignite.compute.TaskState
Returns task status.
STMT_PARSE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
Statement parsing error.
STMT_VALIDATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
Statement validation error.
stop() - Method in class org.apache.ignite.migrationtools.persistence.MigrationKernalContext
Stops the context.
stop() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterContainer
 
stop() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
 
stop() - Method in class org.apache.ignite.migrationtools.tests.containers.MigrationToolsContainer
 
stopAsync(ComponentContext) - Method in class org.apache.ignite.client.handler.ClientHandlerModule
stopAsync(ComponentContext) - Method in class org.apache.ignite.migrationtools.config.registry.CombinedConfigRegistry
 
stopListen(ConfigurationListener<VIEWT>) - Method in interface org.apache.ignite.configuration.ConfigurationProperty
Removes configuration values listener.
stopListenElements(ConfigurationNamedListListener<VIEWT>) - Method in interface org.apache.ignite.configuration.NamedConfigurationTree
Removes named-list-specific configuration values listener.
Storage() - Constructor for class org.apache.ignite.lang.ErrorGroups.Storage
 
STORAGE_CORRUPTED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Storage
Error indicating a possible data corruption in the storage.
STORAGE_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Storage
Storage error group.
storageProfiles() - Element in annotation interface org.apache.ignite.catalog.annotations.Zone
Storage profiles.
storageProfiles() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns storage profiles.
storageProfiles(String) - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
Sets the storage profiles.
storageRevision() - Method in interface org.apache.ignite.configuration.notifications.ConfigurationNotificationEvent
Returns monotonously increasing counter, linked to the specific storage for current configuration values.
stream() - Method in interface org.apache.ignite.configuration.NamedListView
Returns an ordered stream of values from the named list.
streamData(Flow.Publisher<E>, Function<E, T>, Function<E, V>, ReceiverDescriptor<A>, Flow.Subscriber<R>, DataStreamerOptions, A) - Method in interface org.apache.ignite.table.DataStreamerTarget
streamData(Flow.Publisher<E>, DataStreamerReceiverDescriptor<V, A, R>, Function<E, T>, Function<E, V>, A, Flow.Subscriber<R>, DataStreamerOptions) - Method in interface org.apache.ignite.table.DataStreamerTarget
Streams data with receiver.
streamData(Flow.Publisher<DataStreamerItem<T>>, DataStreamerOptions) - Method in interface org.apache.ignite.table.DataStreamerTarget
Streams data into the underlying table.
STREAMER_BATCH_SEND - Enum constant in enum class org.apache.ignite.client.ClientOperationType
STREAMER_WITH_RECEIVER_BATCH_SEND - Enum constant in enum class org.apache.ignite.client.ClientOperationType
StreamerPublisher<T> - Class in org.apache.ignite.migrationtools.persistence.utils.pubsub
Publisher for streamer.
StreamerPublisher() - Constructor for class org.apache.ignite.migrationtools.persistence.utils.pubsub.StreamerPublisher
 
STRING - Enum constant in enum class org.apache.ignite.sql.ColumnType
String.
stringValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
stringValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a String column value.
stringValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
stringValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a String column value.
subFolderFile() - Method in class org.apache.ignite.migrationtools.persistence.Ignite2PersistenceTools.NodeFolderDescriptor
subFolderFile.
submitAsync(BroadcastJobTarget, JobDescriptor<T, R>, T) - Method in interface org.apache.ignite.compute.IgniteCompute
Submits a ComputeJob of the given class for an execution on all nodes in the given node set.
submitAsync(BroadcastJobTarget, JobDescriptor<T, R>, T, CancellationToken) - Method in interface org.apache.ignite.compute.IgniteCompute
Submits a ComputeJob of the given class for an execution on all nodes in the given node set.
submitAsync(JobTarget, JobDescriptor<T, R>, T) - Method in interface org.apache.ignite.compute.IgniteCompute
Submits a ComputeJob of the given class for an execution on a single node from a set of candidate nodes.
submitAsync(JobTarget, JobDescriptor<T, R>, T, CancellationToken) - Method in interface org.apache.ignite.compute.IgniteCompute
Submits a ComputeJob of the given class for an execution on a single node from a set of candidate nodes.
submitMapReduce(TaskDescriptor<T, R>, T) - Method in interface org.apache.ignite.compute.IgniteCompute
Submits a MapReduceTask of the given class for an execution.
submitMapReduce(TaskDescriptor<T, R>, T, CancellationToken) - Method in interface org.apache.ignite.compute.IgniteCompute
Submits a MapReduceTask of the given class for an execution.
subscribe(Flow.Subscriber<? super T>) - Method in class org.apache.ignite.migrationtools.persistence.utils.pubsub.BasicProcessor
 
subscribe(Flow.Subscriber<? super T>) - Method in class org.apache.ignite.migrationtools.persistence.utils.pubsub.StreamerPublisher
 
subscriber - Variable in class org.apache.ignite.migrationtools.persistence.utils.pubsub.BasicProcessor
 
subscription - Variable in class org.apache.ignite.migrationtools.persistence.utils.pubsub.BasicProcessor
 
SuperRootChange - Interface in org.apache.ignite.configuration
Interface that represent a "change" for the conjunction of all roots in the configuration.
supplyExample(int) - Method in interface org.apache.ignite.migrationtools.tests.e2e.framework.core.ExampleBasedCacheTest
 
supplyExample(int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.ListTest
 
supplyExample(int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.PrimitiveTest
 
supplyExample(int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest.MyBinaryOrganizationCache
 
supplyExample(int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest.MyBinaryPersonPojoCache
 
supplyExample(int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyBinaryKeyValueCacheTest.MyBinaryTestCache
 
supplyExample(int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyOrganizationsCacheTest
 
supplyExample(int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MySimpleMapCacheTest
 
supplyExample(int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.PersonCacheTest
 
supportsSingleQueryLoading() - Method in class org.apache.ignite.data.IgniteDialect
 
syntheticKeyName() - Element in annotation interface org.apache.ignite.configuration.annotation.NamedConfigValue
Key that can be used in HOCON configuration syntax to declare named list with fixed order.
SYSTEM_CRITICAL_OPERATION_TIMEOUT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.CriticalWorkers
System-critical operation timed out.
SYSTEM_WORKER_BLOCKED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.CriticalWorkers
System worker does not update its heartbeat for a long time.

T

table(String) - Static method in interface org.apache.ignite.compute.BroadcastJobTarget
Creates a job target for partitioned execution.
table(String) - Method in interface org.apache.ignite.table.IgniteTables
Gets a table with the specified name if that table exists.
table(QualifiedName) - Static method in interface org.apache.ignite.compute.BroadcastJobTarget
Creates a job target for partitioned execution.
table(QualifiedName) - Method in interface org.apache.ignite.table.IgniteTables
Gets a table with the specified name if that table exists.
Table - Interface in org.apache.ignite.table
Table provides different views (key-value vs record) and approaches (mapped-object vs binary) to access the data.
Table - Annotation Interface in org.apache.ignite.catalog.annotations
Describes a table.
Table() - Constructor for class org.apache.ignite.lang.ErrorGroups.Table
 
TABLE_ALREADY_EXISTS_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Table
Deprecated.
TABLE_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Table
Table error group.
TABLE_GET - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TABLE_ID_NOT_FOUND_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
Table not found by ID.
TABLE_NOT_FOUND_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Table
Table not found.
TableAlreadyExistsException - Exception in org.apache.ignite.lang
Deprecated.
No longer used. Use SqlException with ErrorGroups.Sql.STMT_VALIDATION_ERR error code.
TableAlreadyExistsException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.TableAlreadyExistsException
Deprecated.
Creates an exception with the given trace IDS, error code, detailed message, and cause.
TableAlreadyExistsException(QualifiedName) - Constructor for exception org.apache.ignite.lang.TableAlreadyExistsException
Deprecated.
Creates an exception with the given table name.
tableAsync(String) - Method in interface org.apache.ignite.table.IgniteTables
Gets a table with the specified name if that table exists.
tableAsync(QualifiedName) - Method in interface org.apache.ignite.table.IgniteTables
Gets a table with the specified name if that table exists.
tableDefinition() - Method in class org.apache.ignite.migrationtools.sql.SqlDdlGenerator.GenerateTableResult
 
tableDefinition(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Returns definition of the table with provided name or null if table doesn't exist.
tableDefinition(QualifiedName) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Returns definition of the table with provided QualifiedName or null if table doesn't exist.
TableDefinition - Class in org.apache.ignite.catalog.definitions
Definition of the CREATE TABLE statement.
TableDefinition.Builder - Class in org.apache.ignite.catalog.definitions
Builder for the table definition.
tableDefinitionAsync(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Returns definition of the table with provided name or null if table doesn't exist.
tableDefinitionAsync(QualifiedName) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Returns definition of the table with provided QualifiedName or null if table doesn't exist.
TableExample - Class in org.apache.ignite.example.table
This example demonstrates the usage of the KeyValueView API.
TableExample() - Constructor for class org.apache.ignite.example.table.TableExample
 
tableIdNotFoundException(Integer) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTableCommon
Returns a new table id not found exception.
TableJobTarget - Class in org.apache.ignite.compute
Partitioned broadcast execution target.
tableName() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns table name.
tableName() - Method in class org.apache.ignite.compute.ColocatedJobTarget
 
tableName() - Method in class org.apache.ignite.compute.TableJobTarget
 
tableName() - Method in exception org.apache.ignite.migrationtools.persistence.exceptions.MigrateCacheException
Gets the target table name for the underlying migration request.
tableName() - Method in interface org.apache.ignite.sql.ColumnMetadata.ColumnOrigin
Returns a column table's name.
TableNotFoundException - Exception in org.apache.ignite.lang
Exception is thrown when a specified table cannot be found.
TableNotFoundException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.TableNotFoundException
Creates an exception with the given trace ID, error code, detailed message, and cause.
TableNotFoundException(QualifiedName) - Constructor for exception org.apache.ignite.lang.TableNotFoundException
Creates an exception with the given table name.
tables() - Method in interface org.apache.ignite.Ignite
Returns an object for manipulating the Ignite tables.
tables() - Method in interface org.apache.ignite.table.IgniteTables
Gets a list of all tables.
TABLES_GET - Enum constant in enum class org.apache.ignite.client.ClientOperationType
Get tables (IgniteTables.tables()).
tablesAsync() - Method in interface org.apache.ignite.table.IgniteTables
Gets a list of all tables.
tablesMetaAsync(JdbcMetaTablesRequest) - Method in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
tableTypeDescriptor() - Method in class org.apache.ignite.migrationtools.sql.SqlDdlGenerator.GenerateTableResult
 
TableTypeDescriptor - Class in org.apache.ignite.migrationtools.tablemanagement
Describes the key and value types of a Table.
TableTypeDescriptor(String, String, Map<String, String>, Map<String, String>) - Constructor for class org.apache.ignite.migrationtools.tablemanagement.TableTypeDescriptor
Constructor.
TableTypeRegistry - Interface in org.apache.ignite.migrationtools.tablemanagement
This interface provides a registry for mappings between tables and their corresponding java types.
TableTypeRegistryMapImpl - Class in org.apache.ignite.migrationtools.tablemanagement
TableTypeRegistry implementation based on a in-memory map.
TableTypeRegistryMapImpl() - Constructor for class org.apache.ignite.migrationtools.tablemanagement.TableTypeRegistryMapImpl
 
TableTypeRegistryUtils - Class in org.apache.ignite.migrationtools.tablemanagement
Utility class for handling TableTypeRegistries.
TableTypeRegistryUtils() - Constructor for class org.apache.ignite.migrationtools.tablemanagement.TableTypeRegistryUtils
 
targetType() - Method in interface org.apache.ignite.table.mapper.Mapper
Returns a type of the object the mapper handles.
taskClassName() - Method in class org.apache.ignite.compute.TaskDescriptor
Task class name.
TaskDescriptor<T,R> - Class in org.apache.ignite.compute
Compute task descriptor.
TaskDescriptor.Builder<T,R> - Class in org.apache.ignite.compute
Builder.
TaskExecution<R> - Interface in org.apache.ignite.compute.task
Compute task control object.
TaskExecutionContext - Interface in org.apache.ignite.compute.task
Context of the compute task execution.
TaskState - Interface in org.apache.ignite.compute
Task state.
TaskStatus - Enum Class in org.apache.ignite.compute
Compute task's status.
tearDownClient() - Method in class org.apache.ignite.migrationtools.tests.e2e.framework.runners.JdbcTestBootstrap
 
test(Connection, int) - Method in interface org.apache.ignite.migrationtools.tests.e2e.framework.core.SqlTest
 
TEST_CLUSTER_PATH - Static variable in class org.apache.ignite.migrationtools.tests.clusters.FullSampleCluster
 
testIgnite2(IgniteCache<K, V>, int) - Method in interface org.apache.ignite.migrationtools.tests.e2e.framework.core.ExampleBasedCacheTest
 
testIgnite2(IgniteCache<K, V>, int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
 
testIgnite3(Table, int) - Method in interface org.apache.ignite.migrationtools.tests.e2e.framework.core.ExampleBasedCacheTest
 
testIgnite3(Table, int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.ListTest
 
testIgnite3(Table, int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.IntArrayCachesTest.PrimitiveTest
 
testIgnite3(Table, int) - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
 
thinClientMappedPort() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterContainer
Returns host's port which can be used for thin client connection.
time(int) - Static method in class org.apache.ignite.catalog.ColumnType
TIME with specified precision.
TIME - Enum constant in enum class org.apache.ignite.sql.ColumnType
Timezone-free time with precision.
TIME - Static variable in class org.apache.ignite.catalog.ColumnType
TIME SQL column type.
timeoutMillis() - Method in class org.apache.ignite.tx.TransactionOptions
Returns transaction timeout, in milliseconds.
timeoutMillis(long) - Method in class org.apache.ignite.tx.TransactionOptions
Sets transaction timeout, in milliseconds.
timestamp() - Method in class org.apache.ignite.client.handler.ClientPrimaryReplicaTracker.PrimaryReplicasResult
 
timestamp(int) - Static method in class org.apache.ignite.catalog.ColumnType
TIMESTAMP with specified precision.
TIMESTAMP - Enum constant in enum class org.apache.ignite.sql.ColumnType
Point on the time-line.
TIMESTAMP - Static variable in class org.apache.ignite.catalog.ColumnType
TIMESTAMP SQL column type.
TIMESTAMP_WITH_LOCAL_TIME_ZONE - Static variable in class org.apache.ignite.catalog.ColumnType
TIMESTAMP WITH LOCAL TIME ZONE SQL column type.
timestampValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
timestampValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a Instant column value.
timestampValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
timestampValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a Instant column value.
timeValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
timeValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a LocalTime column value.
timeValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
timeValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a LocalTime column value.
timeZoneId() - Method in interface org.apache.ignite.sql.Statement
Returns time zone used for this statement.
timeZoneId(ZoneId) - Method in interface org.apache.ignite.sql.Statement.StatementBuilder
Sets a time zone for this statement.
TINYINT - Static variable in class org.apache.ignite.catalog.ColumnType
TINYINT SQL column type.
toBuilder() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns new builder using this definition.
toBuilder() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns new builder using this definition.
toBuilder() - Method in class org.apache.ignite.compute.task.MapReduceJob
Returns new builder using this definition.
toBuilder() - Method in interface org.apache.ignite.sql.Statement
Creates a statement builder from the current statement.
toCanonicalForm() - Method in class org.apache.ignite.table.QualifiedName
Returns qualified name in canonical form.
toColumnType(Enum<T>) - Method in class org.apache.ignite.migrationtools.types.converters.EnumToStringTypeConverter
 
toColumnType(Date) - Method in class org.apache.ignite.migrationtools.types.converters.SqlDateToLocalDateConverter
 
toColumnType(Time) - Method in class org.apache.ignite.migrationtools.types.converters.SqlTimeToLocalTimeConverter
 
toColumnType(Timestamp) - Method in class org.apache.ignite.migrationtools.types.converters.SqlTimestampToInstantConverter
 
toColumnType(Timestamp) - Method in class org.apache.ignite.migrationtools.types.converters.SqlTimestampToLocalDateTimeConverter
 
toColumnType(Calendar) - Method in class org.apache.ignite.migrationtools.types.converters.CalendarToInstantConverter
 
toColumnType(Calendar) - Method in class org.apache.ignite.migrationtools.types.converters.CalendarToLocalDateTimeConverter
 
toColumnType(Date) - Method in class org.apache.ignite.migrationtools.types.converters.DateToInstantConverter
 
toColumnType(Date) - Method in class org.apache.ignite.migrationtools.types.converters.DateToLocalDateTimeConverter
 
toColumnType(ObjectT) - Method in interface org.apache.ignite.table.mapper.TypeConverter
Converts a given object to a column type.
toColumnType(T) - Method in class org.apache.ignite.migrationtools.types.converters.IdentityConverter
 
token() - Method in interface org.apache.ignite.lang.CancelHandle
Issue a token associated with this handle.
toObjectType(ColumnT) - Method in interface org.apache.ignite.table.mapper.TypeConverter
Transforms to an object of the target type; called after the data is read from a column.
toObjectType(String) - Method in class org.apache.ignite.migrationtools.types.converters.EnumToStringTypeConverter
 
toObjectType(Instant) - Method in class org.apache.ignite.migrationtools.types.converters.CalendarToInstantConverter
 
toObjectType(Instant) - Method in class org.apache.ignite.migrationtools.types.converters.DateToInstantConverter
 
toObjectType(Instant) - Method in class org.apache.ignite.migrationtools.types.converters.SqlTimestampToInstantConverter
 
toObjectType(LocalDate) - Method in class org.apache.ignite.migrationtools.types.converters.SqlDateToLocalDateConverter
 
toObjectType(LocalDateTime) - Method in class org.apache.ignite.migrationtools.types.converters.CalendarToLocalDateTimeConverter
 
toObjectType(LocalDateTime) - Method in class org.apache.ignite.migrationtools.types.converters.DateToLocalDateTimeConverter
 
toObjectType(LocalDateTime) - Method in class org.apache.ignite.migrationtools.types.converters.SqlTimestampToLocalDateTimeConverter
 
toObjectType(LocalTime) - Method in class org.apache.ignite.migrationtools.types.converters.SqlTimeToLocalTimeConverter
 
toObjectType(T) - Method in class org.apache.ignite.migrationtools.types.converters.IdentityConverter
 
TopLevelCliCommand - Class in org.apache.ignite.migrationtools.cli
Top-level command that prints help and declares subcommands.
TopLevelCliCommand() - Constructor for class org.apache.ignite.migrationtools.cli.TopLevelCliCommand
 
toString() - Method in class org.apache.ignite.catalog.ColumnSorted
 
toString() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
 
toString() - Method in class org.apache.ignite.client.handler.ClientContext
 
toString() - Method in class org.apache.ignite.configuration.RootKey
toString() - Method in class org.apache.ignite.configuration.validation.ValidationIssue
toString() - Method in class org.apache.ignite.deployment.DeploymentUnit
 
toString() - Method in class org.apache.ignite.deployment.DeploymentUnitInfo
 
toString() - Method in class org.apache.ignite.example.compute.ComputeWithCustomResultMarshallerExample.WordInfoResult
toString() - Method in class org.apache.ignite.lang.ErrorGroup
toString() - Method in exception org.apache.ignite.lang.IgniteCheckedException
toString() - Method in exception org.apache.ignite.lang.IgniteException
toString() - Method in class org.apache.ignite.lang.NullableValue
toString() - Method in class org.apache.ignite.migrationtools.persistence.mappers.IgnoreMismatchesSchemaColumnProcessor.IgnoredColumnsStats
 
toString() - Method in exception org.apache.ignite.migrationtools.persistence.mappers.RecordAndTableSchemaMismatchException
 
toString() - Method in class org.apache.ignite.migrationtools.persistence.mappers.SchemaColumnProcessorStats
 
toString() - Method in class org.apache.ignite.migrationtools.persistence.mappers.SkipRecordsSchemaColumnsProcessor.SkippedRecordsStats
 
toString() - Method in class org.apache.ignite.migrationtools.types.InspectedField
 
toString() - Method in class org.apache.ignite.network.NetworkAddress
toString() - Method in class org.apache.ignite.network.NodeMetadata
 
toString() - Method in class org.apache.ignite.table.QualifiedName
TraceableException - Interface in org.apache.ignite.lang
Interface representing an exception that can be identified with trace identifier and provides an error code.
traceId() - Method in exception org.apache.ignite.lang.IgniteCheckedException
Returns a unique identifier of the exception.
traceId() - Method in exception org.apache.ignite.lang.IgniteException
Returns a unique identifier of the exception.
traceId() - Method in interface org.apache.ignite.lang.TraceableException
Returns a unique identifier of the exception.
TraceIdUtils - Class in org.apache.ignite.lang.util
This utility class allows to extract trace identifier from an instance of TraceableException or creating a new trace identifier.
TraceIdUtils() - Constructor for class org.apache.ignite.lang.util.TraceIdUtils
 
Transaction - Interface in org.apache.ignite.tx
The transaction.
TransactionException - Exception in org.apache.ignite.tx
This exception is thrown if a transaction can't be finished for some reason.
TransactionException(int, Throwable) - Constructor for exception org.apache.ignite.tx.TransactionException
Creates a new transaction exception with the given error code and cause.
TransactionException(int, String) - Constructor for exception org.apache.ignite.tx.TransactionException
Creates a new transaction exception with the given error code and detail message.
TransactionException(int, String, Throwable) - Constructor for exception org.apache.ignite.tx.TransactionException
Creates a new transaction exception with the given error code, detail message and cause.
TransactionException(UUID, int, Throwable) - Constructor for exception org.apache.ignite.tx.TransactionException
Creates a new transaction exception with the given trace id, error code and cause.
TransactionException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.tx.TransactionException
Creates a new transaction exception with the given trace id, error code, detail message and cause.
TransactionOptions - Class in org.apache.ignite.tx
Ignite transaction options.
TransactionOptions() - Constructor for class org.apache.ignite.tx.TransactionOptions
 
transactions() - Method in interface org.apache.ignite.Ignite
Returns a transaction facade.
Transactions() - Constructor for class org.apache.ignite.lang.ErrorGroups.Transactions
 
transactionsActive() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Gets active transactions.
transactionsActiveDecrement() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Decrements active transactions.
transactionsActiveIncrement() - Method in class org.apache.ignite.client.handler.ClientHandlerMetricSource
Increments active transactions.
TransactionsExample - Class in org.apache.ignite.example.tx
 
TransactionsExample() - Constructor for class org.apache.ignite.example.tx.TransactionsExample
 
trustStorePassword() - Method in interface org.apache.ignite.client.SslConfiguration
Truststore password that will be used to setup the SSL connection.
trustStorePassword() - Method in class org.apache.ignite.SslConfigurationProperties
 
trustStorePassword(String) - Method in class org.apache.ignite.client.SslConfiguration.Builder
Truststore password setter.
trustStorePath() - Method in interface org.apache.ignite.client.SslConfiguration
Truststore path that will be used to setup the SSL connection.
trustStorePath() - Method in class org.apache.ignite.SslConfigurationProperties
 
trustStorePath(String) - Method in class org.apache.ignite.client.SslConfiguration.Builder
Truststore path setter.
tryMarshalOrCast(Marshaller<T, R>, Object) - Static method in interface org.apache.ignite.marshalling.Marshaller
Try to marshal given object if marshaller if not null, else the object is casted directly to the target type.
tryUnmarshalOrCast(Marshaller<T, R>, Object) - Static method in interface org.apache.ignite.marshalling.Marshaller
Try to unmarshal given object if marshaller if not null, else the object is casted directly to the target type.
Tuple - Interface in org.apache.ignite.table
Tuple represents an arbitrary set of columns whose values are accessible by column name.
TUPLE_CONTAINS_ALL_KEYS - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_CONTAINS_KEY - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_DELETE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_DELETE_ALL - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_DELETE_ALL_EXACT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_DELETE_EXACT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_GET - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_GET_ALL - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_GET_AND_DELETE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_GET_AND_REPLACE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_GET_AND_UPSERT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_INSERT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_INSERT_ALL - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_REPLACE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_REPLACE_EXACT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_UPSERT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TUPLE_UPSERT_ALL - Enum constant in enum class org.apache.ignite.client.ClientOperationType
TupleHelper - Class in org.apache.ignite.table
Utility class to provide direct access to internals of TupleImpl.
TupleSerializationExample - Class in org.apache.ignite.example.serialization
 
TupleSerializationExample() - Constructor for class org.apache.ignite.example.serialization.TupleSerializationExample
 
TwoTableReceiver - Class in org.apache.ignite.example.streaming
Custom receiver class that extracts data from the provided source and write it into two separate tables: Customers and Addresses
TwoTableReceiver() - Constructor for class org.apache.ignite.example.streaming.TwoTableReceiver
 
TX_ALREADY_FINISHED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Operation failed because the transaction is already finished.
TX_ALREADY_FINISHED_WITH_TIMEOUT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Operation failed because the transaction is already finished with timeout.
TX_COMMIT_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Failed to commit a transaction.
TX_CONTROL_INSIDE_EXTERNAL_TX_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
Execution of transaction control statement inside an external transaction is forbidden.
TX_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Transactions error group.
TX_FAILED_READ_WRITE_OPERATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Failed to enlist read-write operation into read-only transaction.
TX_INCOMPATIBLE_SCHEMA_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Failure due to an incompatible schema change.
TX_PRIMARY_REPLICA_EXPIRED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Failure due to primary replica expiration.
TX_READ_ONLY_TOO_OLD_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Error occurred when trying to create a read-only transaction with a timestamp older than the data available in the tables.
TX_ROLLBACK_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Failed to rollback a transaction.
TX_STALE_OPERATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Failure due to a stale operation of a completed transaction is detected.
TX_STALE_READ_ONLY_OPERATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Error occurred when trying to execute an operation in a read-only transaction on a node that has already destroyed data for read timestamp of the transaction.
TX_STATE_STORAGE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Error of tx state storage.
TX_STATE_STORAGE_REBALANCE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Tx state storage rebalancing error.
TX_STATE_STORAGE_STOPPED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Tx state storage is stopped.
TX_UNEXPECTED_STATE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Transactions
Error of unexpected tx state on state change.
type() - Element in annotation interface org.apache.ignite.catalog.annotations.Index
The type of the index.
type() - Method in class org.apache.ignite.catalog.ColumnType
Returns Java type of the column type.
type() - Method in class org.apache.ignite.catalog.definitions.ColumnDefinition
Returns type of the column.
type() - Method in class org.apache.ignite.catalog.definitions.IndexDefinition
Returns index type.
type() - Method in class org.apache.ignite.client.BasicAuthenticator
 
type() - Method in class org.apache.ignite.client.handler.configuration.ClientHandlerConfigurationModule
 
type() - Method in interface org.apache.ignite.client.IgniteClientAuthenticator
Authenticator type.
type() - Element in annotation interface org.apache.ignite.configuration.annotation.ConfigurationRoot
Returns the type of the configuration.
type() - Method in interface org.apache.ignite.configuration.ConfigurationModule
Type of the configuration provided by this module.
type() - Method in class org.apache.ignite.configuration.RootKey
Returns the configuration type of the root.
type() - Method in interface org.apache.ignite.sql.ColumnMetadata
Returns an SQL column type.
TypeConverter<ObjectT,ColumnT> - Interface in org.apache.ignite.table.mapper
Type converter interface provides methods for additional data transformation of the field type to a type compatible with the column type, and vice versa.
TypeConverterFactory - Interface in org.apache.ignite.migrationtools.types.converters
Factory for TypeConverter based on the required types.
typeHints() - Method in class org.apache.ignite.migrationtools.sql.SqlDdlGenerator.GenerateTableResult
 
typeHints() - Method in class org.apache.ignite.migrationtools.tablemanagement.TableTypeDescriptor
 
typeHints(Class<?>, Class<?>) - Static method in class org.apache.ignite.migrationtools.tablemanagement.TableTypeRegistryUtils
Creates a table descriptor with just the supplied type hints.
TypeInspector - Class in org.apache.ignite.migrationtools.types
Utility class that provides methods to identify relevant fields in classes.
TypeInspector() - Constructor for class org.apache.ignite.migrationtools.types.TypeInspector
 
typeName() - Method in class org.apache.ignite.catalog.ColumnType
Returns SQL type name of the column type.
typeName() - Method in class org.apache.ignite.migrationtools.types.InspectedField
 
typesForTable(String) - Method in class org.apache.ignite.migrationtools.tablemanagement.PersistentTableTypeRegistryImpl
 
typesForTable(String) - Method in class org.apache.ignite.migrationtools.tablemanagement.RegisterOnlyTableTypeRegistry
 
typesForTable(String) - Method in interface org.apache.ignite.migrationtools.tablemanagement.TableTypeRegistry
Gets the available type hints for the table.
typesForTable(String) - Method in class org.apache.ignite.migrationtools.tablemanagement.TableTypeRegistryMapImpl
 
typesToEntry(TableTypeDescriptor) - Static method in class org.apache.ignite.migrationtools.tablemanagement.TableTypeRegistryUtils
Materializes the table types into a key/value pair.

U

UNDEFINED_PRECISION - Static variable in interface org.apache.ignite.sql.ColumnMetadata
Undefined precision value.
UNDEFINED_SCALE - Static variable in interface org.apache.ignite.sql.ColumnMetadata
Undefined scale value.
UnexpectedNullValueException - Exception in org.apache.ignite.lang
This exception is thrown instead of returning a null value from a method that does not respect null-value to avoid ambiguity (whether the value is absent or is null).
UnexpectedNullValueException(String) - Constructor for exception org.apache.ignite.lang.UnexpectedNullValueException
Creates a new exception.
UnexpectedNullValueException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.UnexpectedNullValueException
Creates a new exception with the given trace id, error code, detail message and cause.
UNIT_ALREADY_EXISTS_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.CodeDeployment
Unit duplicate error.
UNIT_CONTENT_READ_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.CodeDeployment
Deployment unit content read error.
UNIT_NOT_FOUND_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.CodeDeployment
Access to non-existing deployment unit.
UNIT_UNAVAILABLE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.CodeDeployment
Deployment unit is unavailable for computing.
UNIT_WRITE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.CodeDeployment
Deployment unit write to fs error.
UNIT_ZIP_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.CodeDeployment
Deployment unit zip deploy error.
units() - Method in class org.apache.ignite.compute.JobDescriptor
Deployment units.
units() - Method in class org.apache.ignite.compute.TaskDescriptor
Deployment units.
units() - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor
Deployment units.
units() - Method in class org.apache.ignite.table.ReceiverDescriptor
Deprecated.
Deployment units.
units(List<DeploymentUnit>) - Method in class org.apache.ignite.compute.JobDescriptor.Builder
Sets the deployment units.
units(List<DeploymentUnit>) - Method in class org.apache.ignite.compute.TaskDescriptor.Builder
Sets the deployment units.
units(List<DeploymentUnit>) - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor.Builder
Sets the deployment units.
units(List<DeploymentUnit>) - Method in class org.apache.ignite.table.ReceiverDescriptor.Builder
Deprecated.
Sets the deployment units.
units(DeploymentUnit...) - Method in class org.apache.ignite.compute.JobDescriptor.Builder
Sets the deployment units.
units(DeploymentUnit...) - Method in class org.apache.ignite.compute.TaskDescriptor.Builder
Sets the deployment units.
units(DeploymentUnit...) - Method in class org.apache.ignite.table.DataStreamerReceiverDescriptor.Builder
Sets the deployment units.
units(DeploymentUnit...) - Method in class org.apache.ignite.table.ReceiverDescriptor.Builder
Deprecated.
Sets the deployment units.
unmarshal(byte[]) - Method in interface org.apache.ignite.marshalling.ByteArrayMarshaller
 
unmarshal(R) - Method in interface org.apache.ignite.marshalling.Marshaller
Unmarshal the raw type into object.
UNMARSHALLING_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Marshalling
Unmarshalling error.
UnmarshallingException - Exception in org.apache.ignite.marshalling
Exception thrown when unmarshalling failed.
UnmarshallingException(String) - Constructor for exception org.apache.ignite.marshalling.UnmarshallingException
Constructor.
UnmarshallingException(String, Throwable) - Constructor for exception org.apache.ignite.marshalling.UnmarshallingException
Constructor.
UnmarshallingException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.marshalling.UnmarshallingException
Creates an exception with the given trace ID, error code, detailed message, and cause.
UNRESOLVABLE_CONSISTENT_ID_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Network
Unresolvable consistent ID.
UNSUPPORTED_AUTHENTICATION_TYPE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Authentication
Authentication error caused by unsupported authentication type.
UNSUPPORTED_OBJECT_TYPE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Marshalling
Unsupported object type error.
UNSUPPORTED_PARTITION_TYPE_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Table
Unsupported partition type.
UnsupportedAuthenticationTypeException - Exception in org.apache.ignite.security.exception
The exception thrown when authentication type is not supported.
UnsupportedAuthenticationTypeException(String) - Constructor for exception org.apache.ignite.security.exception.UnsupportedAuthenticationTypeException
Creates a new authentication exception.
UnsupportedObjectTypeMarshallingException - Exception in org.apache.ignite.marshalling
Exception thrown when an object type is not supported by the marshaller.
UnsupportedObjectTypeMarshallingException(Class<?>) - Constructor for exception org.apache.ignite.marshalling.UnsupportedObjectTypeMarshallingException
Creates an exception with the given unsupported type.
UnsupportedObjectTypeMarshallingException(String) - Constructor for exception org.apache.ignite.marshalling.UnsupportedObjectTypeMarshallingException
Creates an exception with the given message.
UnsupportedObjectTypeMarshallingException(String, Throwable) - Constructor for exception org.apache.ignite.marshalling.UnsupportedObjectTypeMarshallingException
Creates an exception with the given message and cause.
UnsupportedObjectTypeMarshallingException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.marshalling.UnsupportedObjectTypeMarshallingException
Creates an exception with the given trace ID, error code, detailed message, and cause.
UnsupportedPartitionTypeException - Exception in org.apache.ignite.lang
This exception is thrown when a table does not support the specified partition type.
UnsupportedPartitionTypeException(String) - Constructor for exception org.apache.ignite.lang.UnsupportedPartitionTypeException
Creates a new exception with the given message.
UnsupportedPartitionTypeException(UUID, int, String, Throwable) - Constructor for exception org.apache.ignite.lang.UnsupportedPartitionTypeException
Creates a new exception with the given trace id, error code, detail message and cause.
update(String, Consumer<CHANGET>) - Method in interface org.apache.ignite.configuration.NamedListChange
Updates a value in the named list configuration.
update(VIEWT) - Method in interface org.apache.ignite.configuration.ConfigurationValue
Update this configuration node value.
UPDATE_STATEMENT_QUERIES - Static variable in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
SqlQueryTypes allowed in JDBC update statements.
updateCounters() - Method in exception org.apache.ignite.sql.SqlBatchException
Returns an array that describes the outcome of a batch execution.
upsert(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Inserts a record into a table, if it does not exist, or replaces an existing one.
upsertAll(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Inserts records into a table, if they do not exist, or replaces the existing ones.
upsertAllAsync(Transaction, Collection<R>) - Method in interface org.apache.ignite.table.RecordView
Asynchronously inserts a record into a table, if it does not exist, or replaces the existing one.
upsertAsync(Transaction, R) - Method in interface org.apache.ignite.table.RecordView
Asynchronously inserts a record into a table, if it does not exist, or replaces the existing one.
USER_OBJECT_SERIALIZATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
Can't marshal/unmarshal a user object.
userDetails() - Method in class org.apache.ignite.client.handler.ClientContext
 
username(String) - Method in class org.apache.ignite.client.BasicAuthenticator.Builder
Sets username.
UUID - Enum constant in enum class org.apache.ignite.sql.ColumnType
128-bit UUID.
UUID - Static variable in class org.apache.ignite.catalog.ColumnType
UUID SQL column type.
uuidValue(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
uuidValue(int) - Method in interface org.apache.ignite.table.Tuple
Gets a UUID column value.
uuidValue(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
uuidValue(String) - Method in interface org.apache.ignite.table.Tuple
Gets a UUID column value.

V

valClassName() - Method in class org.apache.ignite.migrationtools.tablemanagement.TableTypeDescriptor
 
valFieldNameForColumn() - Method in class org.apache.ignite.migrationtools.tablemanagement.TableTypeDescriptor
 
validate(A, ValidationContext<VIEWT>) - Method in interface org.apache.ignite.configuration.validation.Validator
Perform validation.
validateConfigurations(IgniteConfiguration) - Static method in class org.apache.ignite.migrationtools.persistence.MigrationKernalContext
Validates the provided cache configuration.
VALIDATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Catalog
Command to the catalog has not passed the validation.
ValidationContext<VIEWT> - Interface in org.apache.ignite.configuration.validation
Validation context for the validators.
ValidationIssue - Class in org.apache.ignite.configuration.validation
Class that stores information about issues found during the configuration validation.
ValidationIssue(String, String) - Constructor for class org.apache.ignite.configuration.validation.ValidationIssue
Constructor.
Validator<A extends Annotation,VIEWT> - Interface in org.apache.ignite.configuration.validation
Interface for all configuration validators.
validators() - Method in interface org.apache.ignite.configuration.ConfigurationModule
Returns configuration validators provided by this module.
valMapper() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.MyOrganizationsCacheTest
 
valMapper() - Method in class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
 
value() - Element in annotation interface org.apache.ignite.catalog.annotations.Column
The name of the column.
value() - Element in annotation interface org.apache.ignite.catalog.annotations.ColumnRef
Column name.
value() - Element in annotation interface org.apache.ignite.catalog.annotations.Id
Sort order.
value() - Element in annotation interface org.apache.ignite.catalog.annotations.Index
The name of the index.
value() - Element in annotation interface org.apache.ignite.catalog.annotations.Table
The name of the table.
value() - Element in annotation interface org.apache.ignite.catalog.annotations.Zone
The name of the zone.
value() - Element in annotation interface org.apache.ignite.configuration.annotation.Name
Returns the default value for InjectedName.
value() - Element in annotation interface org.apache.ignite.configuration.annotation.PolymorphicConfigInstance
Unique identifier for an extension within a single polymorphic configuration.
value() - Element in annotation interface org.apache.ignite.configuration.annotation.PublicName
Public configuration property name.
value() - Method in interface org.apache.ignite.configuration.ConfigurationProperty
Get value of this property.
value() - Element in annotation interface org.apache.ignite.configuration.validation.ExceptKeys
Returns list of reserved names.
value() - Element in annotation interface org.apache.ignite.configuration.validation.OneOf
Returns list of possible values.
value() - Method in class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel.Value
 
value(int) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
value(int) - Method in interface org.apache.ignite.table.Tuple
Gets a column value for the given column index.
value(Class<?>) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets value class to generate columns.
value(String) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
value(String) - Method in interface org.apache.ignite.table.Tuple
Gets a column value for the given column name.
Value - Annotation Interface in org.apache.ignite.configuration.annotation
This annotation marks configuration schema field as a configuration tree leaf.
Value() - Constructor for class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel.Value
 
Value(long, long, String) - Constructor for class org.apache.ignite.migrationtools.tests.models.InterceptingFieldsModel.Value
Default constructor.
valueClass() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns a class to use to generate columns.
valueClass() - Method in interface org.apache.ignite.sql.ColumnMetadata
Returns a class of column values.
valueOf(String) - Static method in enum class org.apache.ignite.catalog.IndexType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.catalog.SortOrder
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.client.ClientOperationType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.compute.JobExecutorType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.compute.JobStatus
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.compute.TaskStatus
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.configuration.annotation.ConfigurationType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.migrationtools.cli.persistence.params.MigrationMode
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.migrationtools.types.InspectedFieldType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.security.AuthenticationType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.sql.ColumnType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.table.criteria.Operator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.apache.ignite.table.DataStreamerOperationType
Returns the enum constant of this class with the specified name.
valueOrDefault(String, T) - Method in class org.apache.ignite.migrationtools.persistence.mappers.CustomTupleImpl
 
valueOrDefault(String, T) - Method in interface org.apache.ignite.table.Tuple
Gets a column value if the column with the specified name is present in the tuple; returns a default value otherwise.
valueOrDefault(Tuple, String, T) - Static method in class org.apache.ignite.table.TupleHelper
Returns value from a given tuple which corresponds to a specified column.
values() - Static method in enum class org.apache.ignite.catalog.IndexType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.catalog.SortOrder
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.client.ClientOperationType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.compute.JobExecutorType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.compute.JobStatus
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.compute.TaskStatus
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.configuration.annotation.ConfigurationType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.migrationtools.cli.persistence.params.MigrationMode
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.migrationtools.types.InspectedFieldType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.security.AuthenticationType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.sql.ColumnType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.table.criteria.Operator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.apache.ignite.table.DataStreamerOperationType
Returns an array containing the constants of this enum class, in the order they are declared.
varbinary(int) - Static method in class org.apache.ignite.catalog.ColumnType
VARBINARY with specified length.
VARBINARY - Static variable in class org.apache.ignite.catalog.ColumnType
VARBINARY SQL column type.
varchar(int) - Static method in class org.apache.ignite.catalog.ColumnType
VARCHAR with specified length.
VARCHAR - Static variable in class org.apache.ignite.catalog.ColumnType
VARCHAR SQL column type.
version() - Method in class org.apache.ignite.client.handler.ClientContext
Gets the protocol version.
version() - Method in class org.apache.ignite.deployment.DeploymentUnit
Returns version of the deployment unit.
version() - Method in class org.apache.ignite.deployment.DeploymentUnitInfo
Returns the version of the deployment unit.
Version - Interface in org.apache.ignite.deployment.version
Unit version interface.
VersionParseException - Exception in org.apache.ignite.deployment.version
Throws when Version of deployment unit not parsable.
VersionParseException(String, String) - Constructor for exception org.apache.ignite.deployment.version.VersionParseException
Constructor.
VersionParseException(String, Throwable) - Constructor for exception org.apache.ignite.deployment.version.VersionParseException
Constructor.
VeryBasicAbstractCacheTest<K,V> - Class in org.apache.ignite.migrationtools.tests.e2e.impl
VeryBasicAbstractCacheTest.
VeryBasicAbstractCacheTest(Class<K>, Class<V>) - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
 
VeryBasicAbstractCacheTest(Class<K>, Class<V>, String) - Constructor for class org.apache.ignite.migrationtools.tests.e2e.impl.VeryBasicAbstractCacheTest
Constructor.
viewRoot(RootKey<?, V, ?>) - Method in interface org.apache.ignite.configuration.SuperRootChange
Returns a root view for the root key.
visit(Column, C) - Method in interface org.apache.ignite.table.criteria.CriteriaVisitor
Visit a Column instance with the given context.
visit(Criteria, C) - Method in interface org.apache.ignite.table.criteria.CriteriaVisitor
Visit a Criteria instance with the given context.
visit(Expression, C) - Method in interface org.apache.ignite.table.criteria.CriteriaVisitor
Visit a Expression instance with the given context.
visit(Parameter<T>, C) - Method in interface org.apache.ignite.table.criteria.CriteriaVisitor
Visit a Parameter instance with the given context.
VolatilePageMemoryStorageExample - Class in org.apache.ignite.example.storage
This example demonstrates a usage of the PageMemory storage engine configured with an in-memory data region.
VolatilePageMemoryStorageExample() - Constructor for class org.apache.ignite.example.storage.VolatilePageMemoryStorageExample
 

W

waitForCondition(BooleanSupplier, long, long) - Static method in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterWithSamples
TODO: Copied from IgniteTestUtils should reuse this.
waitForInitAsync() - Method in interface org.apache.ignite.IgniteServer
Waits for the cluster initialization.
waitForNextCheckpoint() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite2ClusterContainer
Waits for the next checkpoint to happen.
wasApplied() - Method in interface org.apache.ignite.sql.async.AsyncResultSet
Indicates whether the query that had produced the result was a conditional query.
wasApplied() - Method in interface org.apache.ignite.sql.ResultSet
Indicates whether the query that had produced the result was a conditional query.
withComputeAdapterLibs(Collection<MountableFile>) - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
Adds the compute adapter libraries to the container.
withCredentials(Map.Entry<String, String>) - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
Sets the credentials for this cluster.
withDebug() - Method in class org.apache.ignite.migrationtools.tests.containers.Ignite3ClusterContainer
Enables debug.
withDebug() - Method in class org.apache.ignite.migrationtools.tests.containers.MigrationToolsContainer
Enables debugging on port 5005.
WordInfoJob() - Constructor for class org.apache.ignite.example.compute.ComputeWithCustomResultMarshallerExample.WordInfoJob
 
WordInfoResult() - Constructor for class org.apache.ignite.example.compute.ComputeWithCustomResultMarshallerExample.WordInfoResult
Constructor.
WordInfoResultMarshaller() - Constructor for class org.apache.ignite.example.compute.ComputeWithCustomResultMarshallerExample.WordInfoResultMarshaller
 
workDir() - Method in class org.apache.ignite.migrationtools.cli.persistence.params.PersistenceParams
 
WrapperClass(BinaryObjectImpl, List<String>) - Constructor for class org.apache.ignite.migrationtools.persistence.mappers.AbstractSchemaColumnsProcessor.WrapperClass
 
write(Map<String, ? extends Serializable>, long) - Method in class org.apache.ignite.migrationtools.config.storage.NoDefaultsStorageConfiguration
 
write(ClientMessagePacker) - Method in interface org.apache.ignite.client.handler.ResponseWriter
Write response.
writeTxMeta(ClientMessagePacker, HybridTimestampTracker, ClockService, InternalTransaction, long) - Static method in class org.apache.ignite.client.handler.requests.table.ClientTableCommon
Write tx metadata.

Z

ZERO_UPDATE_COUNT_QUERIES - Static variable in class org.apache.ignite.client.handler.JdbcQueryEventHandlerImpl
SqlQueryTypes types that return 0 in executeUpdate and execute / getUpdateCount.
zone() - Element in annotation interface org.apache.ignite.catalog.annotations.Table
Class annotated with Zone annotation to create a zone.
zone(String) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
Sets primary zone name.
Zone - Annotation Interface in org.apache.ignite.catalog.annotations
Describes a distribution zone.
ZONE_NOT_FOUND_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.DistributionZones
Distribution zone was not found.
zoneDefinition(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Returns definition of the zone with provided name or null if zone doesn't exist.
ZoneDefinition - Class in org.apache.ignite.catalog.definitions
Definition of the CREATE ZONE statement.
ZoneDefinition.Builder - Class in org.apache.ignite.catalog.definitions
Builder for the zone definition.
zoneDefinitionAsync(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
Returns definition of the zone with provided name or null if zone doesn't exist.
zoneName() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
Returns primary zone name.
zoneName() - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition
Returns zone name.
A B C D E F G H I J K L M N O P Q R S T U V W Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form