Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- 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
- 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.
- 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(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. - 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
- 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.
- appendClusterConfiguration(String) - Method in class org.apache.ignite.InitParametersBuilder
-
Append provided cluster configuration
clusterConfiguration
to current cluster config. - ARCHIVED - Enum constant in enum class org.apache.ignite.table.TableRowEventType
-
Row archived.
- 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.
- 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
- ASYNC - Enum constant in enum class org.apache.ignite.cache.CacheWriteMode
-
Cache store writes are asynchronous and performed in background.
- 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.
- AuthenticationType - Enum Class in org.apache.ignite.security
-
Authentication types.
- authenticator() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
-
Gets the authenticator.
- 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.
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.
- BatchedArguments - Class in org.apache.ignite.sql
-
Arguments for batch query execution.
- 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.
- beginSession() - Method in interface org.apache.ignite.cache.CacheStore
-
Begin a store session.
- 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 interface org.apache.ignite.table.Tuple
-
Gets
boolean
column value. - 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.CacheDefinition.Builder
-
Builds the cache definition.
- 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.ClientCacheConfiguration.Builder
-
Build configuration instance.
- 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
-
Builds
InitParameters
. - build() - Method in interface org.apache.ignite.sql.Statement.StatementBuilder
-
Creates an SQL statement abject.
- build() - Method in class org.apache.ignite.table.ContinuousQueryOptions.Builder
-
Builds the options.
- 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.NearCacheOptions.Builder
-
Builds the options.
- 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.
- build() - Method in class org.apache.ignite.table.TableViewOptions.Builder
-
Builds the options.
- buildAsync() - Method in class org.apache.ignite.client.IgniteClient.Builder
-
Builds the client.
- builder() - Static method in class org.apache.ignite.client.BasicAuthenticator
-
Creates a new builder.
- builder() - Static method in interface org.apache.ignite.client.ClientCacheConfiguration
-
Configuration 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.ContinuousQueryOptions
-
Creates a new builder.
- 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.NearCacheOptions
-
Creates a new builder.
- builder() - Static method in class org.apache.ignite.table.ReceiverExecutionOptions
-
Creates the builder for job execution options.
- builder() - Static method in class org.apache.ignite.table.TableViewOptions
-
Creates a new builder.
- 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.CacheDefinition
-
Creates a builder for the cache with the specified name.
- 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.CacheDefinition
-
Creates a builder for the cache with the specified qualified name.
- 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.ClientCacheConfiguration.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.ContinuousQueryOptions.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.NearCacheOptions.Builder
- Builder() - Constructor for class org.apache.ignite.table.ReceiverExecutionOptions.Builder
- Builder() - Constructor for class org.apache.ignite.table.TableViewOptions.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.
- bytesValue(int) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
byte[]
column value. - bytesValue(String) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
byte[]
column value. - byteValue(int) - Method in interface org.apache.ignite.table.Tuple
-
Gets
byte
column value. - byteValue(String) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
byte
column value.
C
- cache(ClientCacheConfiguration) - Method in class org.apache.ignite.client.IgniteClient.Builder
-
Sets the cache configuration.
- cache(String) - Method in interface org.apache.ignite.cache.manager.IgniteCaches
-
Gets a cache with the specified name if that cache exists.
- cache(QualifiedName) - Method in interface org.apache.ignite.cache.manager.IgniteCaches
-
Gets a cache with the specified name if that cache exists.
- Cache - Interface in org.apache.ignite.cache
-
A cache is a data structure backed by in-memory distributed table which is used to speed up the access to some external "slow" resource.
- Cache - Annotation Interface in org.apache.ignite.catalog.annotations
-
Describes a cache.
- CACHE_GET - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Get cache (
IgniteCaches.cache(String)
). - cacheAsync(String) - Method in interface org.apache.ignite.cache.manager.IgniteCaches
-
Gets a cache with the specified name if that cache exists.
- cacheAsync(QualifiedName) - Method in interface org.apache.ignite.cache.manager.IgniteCaches
-
Gets a cache with the specified name if that cache exists.
- cacheConfiguration() - Method in interface org.apache.ignite.client.IgniteClientConfiguration
-
Returns the client cache configuration.
- cacheDefinition(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Returns definition of the cache with provided name or
null
if cache doesn't exist. - cacheDefinition(QualifiedName) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Returns definition of the cache with provided name or
null
if cache doesn't exist. - CacheDefinition - Class in org.apache.ignite.catalog.definitions
-
Definition of the
CREATE CACHE
statement. - CacheDefinition.Builder - Class in org.apache.ignite.catalog.definitions
-
Builder for the cache definition.
- cacheDefinitionAsync(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Returns definition of the cache with the provided name or
null
if cache doesn't exist. - cacheDefinitionAsync(QualifiedName) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Returns definition of the cache with provided
QualifiedName
ornull
if cache doesn't exist. - cacheName() - Method in class org.apache.ignite.catalog.definitions.CacheDefinition
-
Returns cache name.
- cacheOnly() - Method in class org.apache.ignite.tx.TransactionOptions
-
Returns a value indicating whether a cache-only transaction should be used.
- cacheOnly(boolean) - Method in class org.apache.ignite.tx.TransactionOptions
-
Sets a value indicating whether a cache-only transaction should be used.
- caches() - Method in interface org.apache.ignite.cache.manager.IgniteCaches
-
Gets a list of all started caches.
- caches() - Method in interface org.apache.ignite.Ignite
-
Returns an object for manipulating Ignite caches.
- CACHES_GET - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Get caches (
IgniteCaches.caches()
). - cachesAsync() - Method in interface org.apache.ignite.cache.manager.IgniteCaches
-
Gets a list of all started caches.
- CacheStore<K,
V> - Interface in org.apache.ignite.cache -
Interface for a generic store which contents is cached by GridGain cache.
- CacheStoreFactory - Interface in org.apache.ignite.cache
-
Cache store factory.
- CacheStoreSession - Interface in org.apache.ignite.cache
-
Cache store session.
- cacheWriteBehindParallelOperations() - Method in interface org.apache.ignite.client.ClientCacheConfiguration
-
Gets the maximum number of parallel write behind operations.
- cacheWriteBehindParallelOperations() - Method in class org.apache.ignite.client.ClientCacheConfiguration.ClientCacheConfigurationImpl
- cacheWriteBehindParallelOperations(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration.Builder
-
Sets the maximum number of parallel write behind operations for
CacheStore
. - CacheWriteMode - Enum Class in org.apache.ignite.cache
-
Cache store write mode.
- cancel() - Method in interface org.apache.ignite.lang.CancelHandle
-
Abruptly terminates an execution of an associated process.
- cancelAsync() - Method in interface org.apache.ignite.lang.CancelHandle
-
Abruptly terminates an execution of a associated process.
- 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
. - 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.
- 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.
- 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.
- CHANNEL_CONNECT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Connect channel.
- 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.
- 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.
- ClientCacheConfiguration - Interface in org.apache.ignite.client
-
Client cache configuration.
- ClientCacheConfiguration.Builder - Class in org.apache.ignite.client
-
Cache configuration builder.
- ClientCacheConfiguration.ClientCacheConfigurationImpl - Class in org.apache.ignite.client
-
Cache configuration.
- ClientOperationType - Enum Class in org.apache.ignite.client
-
Client operation type.
- 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 interface org.apache.ignite.sql.ResultSet
-
Invalidates result set and cleans up remote resources.
- 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.
- CLOSED_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.GarbageCollector
-
Garbage collector closed 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_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.
- 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.
- clusterNodes() - Method in interface org.apache.ignite.Ignite
-
Deprecated.
- clusterNodesAsync() - Method in interface org.apache.ignite.Ignite
-
Deprecated.Use
IgniteCluster.nodesAsync()
instead. - 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
- colocateBy() - Element in annotation interface org.apache.ignite.catalog.annotations.Cache
-
References to colocation columns.
- 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.CacheDefinition.Builder
-
Sets 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.CacheDefinition.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.CacheDefinition
-
Returns a list of colocation column names.
- 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.Unused. Replaced with
ErrorGroups.Sql.STMT_VALIDATION_ERR
. - 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
withErrorGroups.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 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 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 interface org.apache.ignite.table.Tuple
-
Gets a name of the column with the specified index.
- columnNames() - Method in class org.apache.ignite.table.ContinuousQueryOptions
-
Gets the column names to include in the result.
- columnNames(Set<String>) - Method in class org.apache.ignite.table.ContinuousQueryOptions.Builder
-
Sets the column names to include in the result.
- 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.CacheDefinition
-
Returns definitions of the columns.
- 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.CacheDefinition.Builder
-
Sets definitions of the columns.
- 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.CacheDefinition.Builder
-
Sets definitions of the columns.
- columns(ColumnDefinition...) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
-
Sets definitions of the columns.
- 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.
- 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
- 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.
- 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 (
IgniteCompute.submitAsync(JobTarget, JobDescriptor, Object)
). - COMPUTE_EXECUTE_MAPREDUCE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Compute Execute MapReduce (
IgniteCompute.submitMapReduce(org.apache.ignite.compute.TaskDescriptor<T, R>, T)
). - 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.
- 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.
- ComputeJobRunnerBuilder() - Constructor for class org.apache.ignite.compute.task.MapReduceJob.ComputeJobRunnerBuilder
- Condition - Class in org.apache.ignite.table.criteria
-
Represents an condition with operator and elements for criteria query.
- 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.
- 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.
- connect(String, Properties) - Method in class org.apache.ignite.jdbc.IgniteJdbcDriver
- 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.
- 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.
- 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.
- CONSTRAINT_VIOLATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
-
Constraint violation error such as primary key violation.
- 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.
- CONTINUOUS_QUERY_SCAN_PARTITION - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Continuous query partition scan (
ContinuousQuerySource.queryContinuously(Subscriber, ContinuousQueryOptions)
). - ContinuousQueryOptions - Class in org.apache.ignite.table
-
Continuous query options.
- ContinuousQueryOptions.Builder - Class in org.apache.ignite.table
-
Builder.
- ContinuousQueryPhysicalTimeWatermark - Class in org.apache.ignite.table
-
Continuous query watermark based on physical time (wall clock).
- ContinuousQuerySource<T> - Interface in org.apache.ignite.table
-
Represents an object which can be queried continuously.
- ContinuousQueryWatermark - Interface in org.apache.ignite.table
-
Continuous query watermark.
- 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".
- converter() - Method in interface org.apache.ignite.table.mapper.OneColumnMapper
-
Returns a type converter for the mapped column.
- converterForColumn(String) - Method in interface org.apache.ignite.table.mapper.PojoMapper
-
Returns a type converter for a given column.
- copy(Tuple) - Static method in interface org.apache.ignite.table.Tuple
-
Creates a tuple copy.
- copyColumns(Tuple, List<String>) - Static method in class org.apache.ignite.table.TupleHelper
-
Copy the specified columns into a new tuple.
- 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 interface org.apache.ignite.marshalling.NoopMarshaller
- 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(Class<K>, Class<V>) - Method in interface org.apache.ignite.cache.CacheStoreFactory
-
Create a cache store suitable to work with given key and value types.
- create(Map<String, Object>) - Static method in interface org.apache.ignite.table.Tuple
-
Creates a tuple from a given mapping.
- createCache(Class<?>, Class<?>) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Creates a
Cache
from the annotated key and value classes. - createCache(CacheDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Creates a
Cache
from the cache definition. - createCacheAsync(Class<?>, Class<?>) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Creates a
Cache
from the annotated key and value classes. - createCacheAsync(CacheDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Creates a
Cache
from the cache definition. - CREATED - Enum constant in enum class org.apache.ignite.table.TableRowEventType
-
Row created.
- createIgniteClient(IgniteClientProperties, IgniteClientPropertiesCustomizer) - Method in class org.apache.ignite.IgniteClientAutoConfiguration
-
Creates Ignite client.
- createStatement(String) - Method in interface org.apache.ignite.sql.IgniteSql
-
Creates an SQL statement from a given query string.
- 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.
- 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
- 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.
- customizer() - Method in class org.apache.ignite.IgniteClientAutoConfiguration
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.
- 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.
- 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 interface org.apache.ignite.table.Tuple
-
Gets a
LocalDateTime
column value. - datetimeValue(String) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
LocalDateTime
column value. - dateValue(int) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
LocalDate
column value. - 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 interface org.apache.ignite.table.Tuple
-
Gets a
BigDecimal
column value. - 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.ContinuousQueryOptions
- 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.NearCacheOptions
-
Default options.
- DEFAULT - Static variable in class org.apache.ignite.table.ReceiverExecutionOptions
-
Default receiver execution options.
- DEFAULT - Static variable in class org.apache.ignite.table.TableViewOptions
- 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.Cache
-
Default schema name.
- 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.Cache
-
Default zone 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.
- 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.
- 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.
- deleteAllAsync(CacheStoreSession, Collection<? extends K>) - Method in interface org.apache.ignite.cache.CacheStore
-
Delete a batch from the store.
- 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.
- deleteAsync(CacheStoreSession, K) - Method in interface org.apache.ignite.cache.CacheStore
-
Delete a key from the store.
- 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.
- 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.
- 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
- 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.
- DFLT_WRITE_BEHIND_PARALLEL_OPERATIONS - Static variable in interface org.apache.ignite.client.ClientCacheConfiguration
-
Default write behind parallel operations.
- DisasterRecovery() - Constructor for class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
- 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.
- 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 interface org.apache.ignite.table.Tuple
-
Gets a
double
column value. - doubleValue(String) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
double
column value. - dropCache(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Drops cache with the provided name.
- dropCache(CacheDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Drops cache with the provided cache definition.
- dropCache(QualifiedName) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Drops cache with the provided name.
- dropCacheAsync(String) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Drops cache with the provided name.
- dropCacheAsync(CacheDefinition) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Drops cache with the provided name.
- dropCacheAsync(QualifiedName) - Method in interface org.apache.ignite.catalog.IgniteCatalog
-
Drops cache with the provided name.
- 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 theQualifiedName
. - 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 theQualifiedName
. - 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.
- enabled() - Method in interface org.apache.ignite.client.SslConfiguration
-
When
true
, an SSL/TLS connection will be established. - enabled() - Method in class org.apache.ignite.SslConfigurationProperties
- enabled(boolean) - Method in class org.apache.ignite.client.SslConfiguration.Builder
-
Enabled/disabled setter.
- enableEmptyBatches() - Method in class org.apache.ignite.table.ContinuousQueryOptions
-
Gets the flag that indicates whether empty batches are enabled.
- enableEmptyBatches(boolean) - Method in class org.apache.ignite.table.ContinuousQueryOptions.Builder
-
Sets the flag that indicates whether empty batches are enabled.
- endpoint() - Method in exception org.apache.ignite.client.IgniteClientConnectionException
-
Returns the endpoint that caused the exception.
- 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.
- entry() - Method in interface org.apache.ignite.table.TableRowEvent
-
Gets the resulting entry value.
- 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.CacheDefinition
- 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.deployment.DeploymentUnit
- equals(Object) - Method in class org.apache.ignite.lang.NullableValue
- 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.
- 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.
- 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.
- eventTypes() - Method in class org.apache.ignite.table.ContinuousQueryOptions
-
Gets the included event types.
- eventTypes(EnumSet<TableRowEventType>) - Method in class org.apache.ignite.table.ContinuousQueryOptions.Builder
-
Sets the included event types.
- eventTypes(TableRowEventType...) - Method in class org.apache.ignite.table.ContinuousQueryOptions.Builder
-
Sets the included event types.
- ExampleApplication - Class in org.apache.ignite
-
Example application.
- ExampleApplication() - Constructor for class org.apache.ignite.ExampleApplication
- exception() - Method in interface org.apache.ignite.client.RetryPolicyContext
-
Gets the connection exception that caused current retry iteration.
- 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. - 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, 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.
- 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.
- executor() - Method in class org.apache.ignite.table.ContinuousQueryOptions
-
Returns the executor that is going to be used for async delivery and execution of subscriber methods.
- executor(Executor) - Method in class org.apache.ignite.table.ContinuousQueryOptions.Builder
-
Sets the executor that is going to be used for async delivery and execution of subscriber methods.
- 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.
- expireAfterAccess() - Method in class org.apache.ignite.table.NearCacheOptions
-
Gets the entry expiration interval after the last read operation, in milliseconds.
- expireAfterAccess(int) - Method in class org.apache.ignite.table.NearCacheOptions.Builder
-
Sets the entry expiration interval after read, in milliseconds.
- expireAfterUpdate() - Method in class org.apache.ignite.table.NearCacheOptions
-
Gets the entry expiration interval after the last read operation, in milliseconds.
- expireAfterUpdate(int) - Method in class org.apache.ignite.table.NearCacheOptions.Builder
-
Sets the entry expiration interval after update, in milliseconds.
- Expression - Class in org.apache.ignite.table.criteria
-
Defines a expression for a criteria query with operator and it's arguments.
- extractCauseMessage(String) - Static method in class org.apache.ignite.lang.ErrorGroups
-
Returns a message extracted from the given
errorMessage
if thiserrorMessage
matchesErrorGroups.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.
- 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.
- fields() - Method in interface org.apache.ignite.table.mapper.PojoMapper
-
Returns all fields that should be mapped to columns.
- file(InputFile) - Static method in class org.apache.iceberg.parquet.ParquetIoPublic
- 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.
- finishAsync(boolean) - Method in interface org.apache.ignite.cache.CacheStoreSession
-
Finish the current session.
- 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.
- 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 interface org.apache.ignite.table.Tuple
-
Gets a
float
column value. - 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.
- 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 aInetSocketAddress
. - from(List<List<Object>>) - Static method in class org.apache.ignite.sql.BatchedArguments
-
Creates batched arguments.
- fromId(int) - Static method in enum class org.apache.ignite.table.TableRowEventType
-
Find TableRowEventType by corresponding id.
- 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.cache.CacheWriteMode
-
Efficiently gets enumerated value from its ordinal.
- 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.
- fromString(String) - Static method in enum class org.apache.ignite.cache.CacheWriteMode
-
Reads WRITE MODE from the string representation as described in the
Enum.name()
method.
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.
- 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 class org.apache.ignite.sql.BatchedArguments
-
Returns the arguments list at the specified position.
- 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.
- 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.
- 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.
- 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.
- getAuthenticator() - Method in class org.apache.ignite.IgniteClientProperties
-
Gets ignite client authenticator.
- getBackgroundReconnectInterval() - Method in class org.apache.ignite.IgniteClientProperties
-
Gets reconnect interval.
- getById(int) - Static method in enum class org.apache.ignite.sql.ColumnType
-
Returns the
ColumnType
instance by its id, ornull
if the id is invalid. - getConnectTimeout() - Method in class org.apache.ignite.IgniteClientProperties
-
Sets connection timeout.
- getDialect(JdbcOperations) - Method in class org.apache.ignite.data.IgniteDialectProvider
- 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.
- getIdentifierProcessing() - Method in class org.apache.ignite.data.IgniteDialect
- getLoggerFactory() - Method in class org.apache.ignite.IgniteClientProperties
-
Gets logger factory.
- getMajorVersion() - Method in class org.apache.ignite.jdbc.IgniteJdbcDriver
- getMinorVersion() - Method in class org.apache.ignite.jdbc.IgniteJdbcDriver
- getName() - Method in class org.apache.ignite.table.criteria.Column
-
Gets column name.
- 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.
- 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 ofTraceableException
. - 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
- getPropertyInfo(String, Properties) - Method in class org.apache.ignite.jdbc.IgniteJdbcDriver
- getRawVersion() - Method in exception org.apache.ignite.deployment.version.VersionParseException
- getRetryPolicy() - Method in class org.apache.ignite.IgniteClientProperties
-
Gets retry policy.
- getSslConfiguration() - Method in class org.apache.ignite.IgniteClientProperties
-
Gets SSL configuration.
- getTransaction() - Method in interface org.apache.ignite.cache.CacheStoreSession
-
Get attached transaction.
- getValue() - Method in class org.apache.ignite.table.criteria.Parameter
-
Gets parameter value.
- 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
- HANDSHAKE_HEADER_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
-
Client handshake header error.
- 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.CacheDefinition
- 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.deployment.DeploymentUnit
- hashCode() - Method in class org.apache.ignite.lang.NullableValue
- 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.
- 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.
- 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.
- 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() - Method in enum class org.apache.ignite.table.TableRowEventType
- 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.
- 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.CacheDefinition.Builder
-
Sets not exists flag.
- ifNotExists() - Method in class org.apache.ignite.catalog.definitions.CacheDefinition
-
Returns not exists flag.
- 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.
- IgniteCaches - Interface in org.apache.ignite.cache.manager
-
Interface that provides methods for managing caches.
- 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.
- 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.
- 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
- IgniteClientPropertiesCustomizer - Interface in org.apache.ignite
-
Interface that can be implemented by beans wishing to customize the auto-configured
IgniteClientProperties
. - 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.
- IgniteExperimental - Annotation Interface in org.apache.ignite.lang
-
This annotation marks API elements (such as interfaces, methods, annotations and whole API packages) as experimental meaning that the API is not finalized yet and may be changed or replaced in future Ignite releases.
- 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.
- 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_PARTITION_ID_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
-
Partition ID is not in valid range.
- 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
- 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.CacheDefinition.Builder
-
Adds an index on this cache using specified columns with sort order and index type.
- 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.CacheDefinition.Builder
-
Adds an index on this cache 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.CacheDefinition.Builder
-
Adds an index on this cache using specified columns and default index type and sort order.
- 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
withErrorGroups.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.Cache
-
Indexes to create on this cache.
- 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.CacheDefinition
-
Returns a list of indexes to create on this cache.
- 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
withErrorGroups.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
- inputMarshaller() - Method in interface org.apache.ignite.compute.ComputeJob
-
Marshaller for the input argument.
- 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.
- INSTANCE - Static variable in class org.apache.ignite.data.IgniteDialect
-
Singleton instance.
- 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.
- INTEGER - Static variable in class org.apache.ignite.catalog.ColumnType
-
INTEGER
SQL column type. - 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.
- intValue(int) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
int
column value. - 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.
- 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
- 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 class org.apache.ignite.sql.BatchedArguments
-
Returns
true
if this batch contains is empty. - isMetricsEnabled() - Method in class org.apache.ignite.IgniteClientProperties
-
Returns
true
if metrics enabled. - isReadOnly() - Method in interface org.apache.ignite.tx.Transaction
-
Returns
true
if given transaction is a read-only,false
otherwise. - isValidNormalizedIdentifier(String) - Static method in class org.apache.ignite.lang.util.IgniteNameUtils
-
Returns
true
if given string is valid normalized identifier,false
otherwise. - iteration() - Method in interface org.apache.ignite.client.RetryPolicyContext
-
Gets the current iteration number (zero-based).
- 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
- 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.
K
- key() - Method in class org.apache.ignite.compute.ColocatedJobTarget
- key(Class<?>) - Method in class org.apache.ignite.catalog.definitions.CacheDefinition.Builder
-
Sets key class to generate columns.
- key(Class<?>) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
-
Sets key class to generate columns.
- keyClass() - Method in class org.apache.ignite.catalog.definitions.CacheDefinition
-
Returns a class to use to generate columns.
- keyClass() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
-
Returns a class to use to generate columns.
- keyMapper() - Method in class org.apache.ignite.compute.ColocatedJobTarget
- 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(CacheStoreFactory) - Method in interface org.apache.ignite.cache.Cache
-
Creates a key-value view of a cache using tuple mapping.
- keyValueView(CacheStoreFactory, Mapper<K>, Mapper<V>) - Method in interface org.apache.ignite.cache.Cache
-
Creates a key-value view of a cache using object mapping.
- 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(Mapper<K>, Mapper<V>, TableViewOptions) - Method in interface org.apache.ignite.table.Table
-
Gets a key-value view of the table using the specified key-value class mappers.
- keyValueView(TableViewOptions) - Method in interface org.apache.ignite.table.Table
-
Gets a key-value view of the table.
- KeyValueView<K,
V> - Interface in org.apache.ignite.table -
Key-Value view of a table provides methods to access table records.
L
- LATEST - Static variable in interface org.apache.ignite.deployment.version.Version
-
Implementation of
Version
interface with special latest logic. - LDAP - Enum constant in enum class org.apache.ignite.security.AuthenticationType
- 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
. - license() - Method in class org.apache.ignite.InitParameters
- license(String) - Method in class org.apache.ignite.InitParametersBuilder
- limit() - Method in class org.apache.ignite.data.IgniteDialect
- loadAllAsync(Iterable<? extends K>) - Method in interface org.apache.ignite.cache.CacheStore
-
Load a batch.
- loadAsync(K) - Method in interface org.apache.ignite.cache.CacheStore
-
Load a single key.
- loadAsync(CacheStoreFactory, BiPredicate<Tuple, Tuple>, Object...) - Method in interface org.apache.ignite.cache.Cache
-
Loads a GridGain cache from cache store.
- loadAsync(CacheStoreFactory, Mapper<K>, Mapper<V>, BiPredicate<K, V>, Object...) - Method in interface org.apache.ignite.cache.Cache
-
Loads a GridGain cache from cache store.
- loadCacheAsync(BiConsumer<K, V>, Object...) - Method in interface org.apache.ignite.cache.CacheStore
-
Load a cache.
- 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 interface org.apache.ignite.table.Tuple
-
Gets a
long
column value. - 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.ExampleApplication
- 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.
- MAP_GET_OR_CREATE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Create or get a map (
IgniteStructures.getOrCreateMap(org.gridgain.structure.MapConfiguration)
). - 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.
- 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.
- marshal(T) - Method in interface org.apache.ignite.marshalling.NoopMarshaller
- 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, Throwable) - Constructor for exception org.apache.ignite.lang.MarshallerException
-
Creates a new exception with the given error message.
- MarshallerException(Throwable) - Constructor for exception org.apache.ignite.lang.MarshallerException
-
Deprecated.
- 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.
- maxEntries() - Method in class org.apache.ignite.table.NearCacheOptions
-
Gets the maximum size of the near cache.
- maxEntries(long) - Method in class org.apache.ignite.table.NearCacheOptions.Builder
-
Sets the maximum size of the near cache.
- 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.
- META_STORAGE_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.MetaStorage
-
Meta storage error group.
- 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()
returnstrue
). - 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.
- 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.
- 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.
N
- name() - Method in interface org.apache.ignite.cache.Cache
-
Gets the canonical name of the cache ([schema_name].[cache_name]) with SQL-parser style quotation.
- 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.deployment.DeploymentUnit
-
Returns 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.
- nativelySupported(Class<?>) - Static method in interface org.apache.ignite.table.mapper.Mapper
-
Checks if a class is of natively supported type.
- nearCacheOptions() - Method in class org.apache.ignite.table.TableViewOptions
-
Gets options for Near Cache.
- nearCacheOptions(NearCacheOptions) - Method in class org.apache.ignite.table.TableViewOptions.Builder
-
Sets options for Near Cache.
- NearCacheOptions - Class in org.apache.ignite.table
-
Near cache options.
- NearCacheOptions.Builder - Class in org.apache.ignite.table
-
Builder.
- 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.
- 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_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
- 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.
- 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
- NoopMarshaller<T> - Interface in org.apache.ignite.marshalling
-
Noop marshaller that does not perform any transformation on the object.
- 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_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
- 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
. - 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 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 isnull
). - 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.
- ofInstant(Instant) - Static method in interface org.apache.ignite.table.ContinuousQueryWatermark
-
Creates a new watermark based on specified time (wall clock).
- oldEntry() - Method in interface org.apache.ignite.table.TableRowEvent
-
Gets the previous entry value.
- OneColumnMapper<ObjectT> - Interface in org.apache.ignite.table.mapper
-
Maps the entire object of a natively supported type to a single column.
- 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.iceberg.parquet - package org.apache.iceberg.parquet
- org.apache.ignite - package org.apache.ignite
-
Contains the Ignite node API and classes for node lifecycle management.
- org.apache.ignite.cache - package org.apache.ignite.cache
-
Cache access API.
- org.apache.ignite.cache.manager - package org.apache.ignite.cache.manager
-
Contains API classes for cache 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.compute - package org.apache.ignite.compute
- org.apache.ignite.compute.task - package org.apache.ignite.compute.task
- 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.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.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.
- origin() - Method in interface org.apache.ignite.sql.ColumnMetadata
-
Returns a column origin.
P
- 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.ContinuousQueryOptions
-
Gets the per-partition page size.
- 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.ContinuousQueryOptions.Builder
-
Sets the per-partition page size.
- 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.
- ParquetIoPublic - Class in org.apache.iceberg.parquet
-
ParquetIO
with public methods instead of package-private. - 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.
- 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.table.ContinuousQueryOptions
-
Gets the partitions to subscribe to.
- partitions(Set<Partition>) - Method in class org.apache.ignite.table.ContinuousQueryOptions.Builder
-
Sets the partitions to subscribe to.
- partitions(Integer) - Method in class org.apache.ignite.catalog.definitions.ZoneDefinition.Builder
-
Sets the number of partitions.
- partitions(Partition...) - Method in class org.apache.ignite.table.ContinuousQueryOptions.Builder
-
Sets the partitions to subscribe to.
- password(String) - Method in class org.apache.ignite.client.BasicAuthenticator.Builder
-
Sets password.
- 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.
- 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).
- 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
- PojoMapper<T> - Interface in org.apache.ignite.table.mapper
-
Maps fields of objects of type
PojoMapper
to columns by name. - pollIntervalMs() - Method in class org.apache.ignite.table.ContinuousQueryOptions
-
Gets the poll interval in milliseconds.
- pollIntervalMs(int) - Method in class org.apache.ignite.table.ContinuousQueryOptions.Builder
-
Sets the poll interval in milliseconds.
- 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.
- 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.CacheDefinition.Builder
-
Sets primary key columns using default index type.
- 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.CacheDefinition.Builder
-
Sets primary key columns.
- 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.CacheDefinition.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.CacheDefinition
-
Returns a list of columns used in the primary key.
- primaryKeyColumns() - Method in class org.apache.ignite.catalog.definitions.TableDefinition
-
Returns a list of columns used in the primary key.
- primaryKeyType() - Element in annotation interface org.apache.ignite.catalog.annotations.Cache
-
Primary key type.
- primaryKeyType() - Element in annotation interface org.apache.ignite.catalog.annotations.Table
-
Primary key type.
- primaryKeyType() - Method in class org.apache.ignite.catalog.definitions.CacheDefinition
-
Returns 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.
- 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.
- 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.
- put(Transaction, K, V) - Method in interface org.apache.ignite.table.KeyValueView
-
Puts into a table a value associated with the given key.
- 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 interface org.apache.ignite.cache.Cache
-
Gets the qualified name of the cache.
- qualifiedName() - Method in class org.apache.ignite.catalog.definitions.CacheDefinition
-
Returns qualified table name.
- 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 - 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(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.
- queryContinuously(Flow.Subscriber<TableRowEventBatch<T>>) - Method in interface org.apache.ignite.table.ContinuousQuerySource
-
Starts a continuous query which listens to data events within the underlying table.
- queryContinuously(Flow.Subscriber<TableRowEventBatch<T>>, ContinuousQueryOptions) - Method in interface org.apache.ignite.table.ContinuousQuerySource
-
Starts a continuous query which listens to data events within the underlying table.
- 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.
- 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.
- quote(String) - Static method in class org.apache.ignite.lang.util.IgniteNameUtils
-
Wraps the given name with double quotes.
- 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
- 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.
- REAL - Static variable in class org.apache.ignite.catalog.ColumnType
-
REAL
SQL column type. - receive(List<T>, DataStreamerReceiverContext, A) - Method in interface org.apache.ignite.table.DataStreamerReceiver
-
Receives an item from the data streamer (see
DataStreamerTarget.streamData(Publisher, DataStreamerReceiverDescriptor, Function, Function, Object, Subscriber, DataStreamerOptions)
). - 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.Replaced by
DataStreamerReceiverDescriptor
. - 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.
- 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(Mapper<R>, TableViewOptions) - Method in interface org.apache.ignite.table.Table
-
Gets a record view of the table using the specified record class mapper.
- recordView(TableViewOptions) - Method in interface org.apache.ignite.table.Table
-
Gets a record view of the table.
- RecordView<R> - Interface in org.apache.ignite.table
-
Table view interface provides methods to access table records.
- RECOVERY_ERR_GROUP - Static variable in class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
-
Disaster recovery group.
- 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.
- 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
andgroupCode
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
andgroupCode
. - 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. - REMOVED - Enum constant in enum class org.apache.ignite.table.TableRowEventType
-
Row removed.
- 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.
- RESOURCE_CLOSING_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Common
-
Resource closing error.
- 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.
- RESTART_WITH_CLEAN_UP_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.DisasterRecovery
-
Error while restarting the cluster with clean up.
- 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 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.
- RetriableTransactionException - Interface in org.apache.ignite.tx
-
This is the marker interface for exceptions that can be retried if happened in
IgniteTransactions.runInTransaction(java.util.function.Consumer<org.apache.ignite.tx.Transaction>)
andIgniteTransactions.runInTransactionAsync(java.util.function.Function<org.apache.ignite.tx.Transaction, java.util.concurrent.CompletableFuture<T>>)
. - retryLimit() - Method in class org.apache.ignite.client.RetryLimitPolicy
-
Gets the retry limit.
- 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 specifiedRetryLimitPolicy.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
- 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.
- rows() - Method in interface org.apache.ignite.table.TableRowEventBatch
-
Gets the events.
- 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.
- RUNTIME_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Sql
-
Runtime error.
S
- 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.CacheDefinition.Builder
-
Sets schema name.
- 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.Unused. Replaced with
ErrorGroups.Sql.STMT_VALIDATION_ERR
. - SCHEMA_VERSION_MISMATCH_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Table
-
Schema version mismatch.
- schemaName() - Element in annotation interface org.apache.ignite.catalog.annotations.Cache
-
The schema name.
- schemaName() - Element in annotation interface org.apache.ignite.catalog.annotations.Table
-
The schema name.
- schemaName() - Method in class org.apache.ignite.catalog.definitions.CacheDefinition
-
Returns 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
withErrorGroups.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.
- secret() - Method in class org.apache.ignite.client.BasicAuthenticator
- secret() - Method in interface org.apache.ignite.client.IgniteClientAuthenticator
-
Secret.
- SERVER_TO_CLIENT_REQUEST_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Client
-
Server to client request failed.
- serviceLoaderClassLoader(ClassLoader) - Method in class org.apache.ignite.IgniteServer.Builder
-
Specifies class loader to use when loading components via
ServiceLoader
. - set(String, Object) - Method in interface org.apache.ignite.table.Tuple
-
Sets a column value.
- 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.
- setAsyncContinuationExecutor(Executor) - Method in class org.apache.ignite.IgniteClientProperties
-
Sets async continuation executor.
- setAuthenticator(IgniteClientAuthenticator) - Method in class org.apache.ignite.IgniteClientProperties
-
Sets ignite client authenticator.
- setBackgroundReconnectInterval(Long) - Method in class org.apache.ignite.IgniteClientProperties
-
Sets reconnect interval.
- setCiphers(Iterable<String>) - Method in class org.apache.ignite.SslConfigurationProperties
- setConnectTimeout(Long) - Method in class org.apache.ignite.IgniteClientProperties
-
Gets connection timeout.
- setEnabled(Boolean) - Method in class org.apache.ignite.SslConfigurationProperties
- setHeartbeatInterval(Long) - Method in class org.apache.ignite.IgniteClientProperties
-
Sets heartbeat interval.
- setHeartbeatTimeout(Long) - Method in class org.apache.ignite.IgniteClientProperties
-
Sets heartbeat timeout.
- 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.
- setNormalized(Tuple, String, Object) - Static method in class org.apache.ignite.table.TupleHelper
-
An alternative to
Tuple.set(java.lang.String, java.lang.Object)
that allows to set a value for a column, which name is already normalized. - setOperationTimeout(Long) - Method in class org.apache.ignite.IgniteClientProperties
-
Sets operation timeout.
- setRetryPolicy(RetryPolicy) - Method in class org.apache.ignite.IgniteClientProperties
-
Sets retry policy.
- setSslConfiguration(SslConfigurationProperties) - Method in class org.apache.ignite.IgniteClientProperties
-
Sets SSL configuration.
- setTransaction(Transaction) - Method in interface org.apache.ignite.cache.CacheStoreSession
-
Attaches corresponding Ignite transaction to a session.
- setTrustStorePassword(String) - Method in class org.apache.ignite.SslConfigurationProperties
- setTrustStorePath(String) - Method in class org.apache.ignite.SslConfigurationProperties
- shortValue(int) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
short
column value. - shortValue(String) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
short
column value. - 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.
- simpleTypes() - Method in class org.apache.ignite.data.IgniteDialect
- size() - Method in class org.apache.ignite.sql.BatchedArguments
-
Returns the size of this batch.
- skipOldEntries() - Method in class org.apache.ignite.table.ContinuousQueryOptions
-
Gets the flag that indicates whether old entries should be skipped for
TableRowEventType.UPDATED
events. - skipOldEntries(boolean) - Method in class org.apache.ignite.table.ContinuousQueryOptions.Builder
-
Sets the flag that indicates whether old entries should be skipped for
TableRowEventType.UPDATED
events. - 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.
- 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 (
IgniteSql.executeAsync(Transaction, String, Object...)
). - SQL_EXECUTE_BATCH - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
SQL Execute batch (
IgniteSql.executeBatchAsync(Transaction, String, BatchedArguments)
). - SQL_EXECUTE_SCRIPT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
SQL Execute (
IgniteSql.executeScriptAsync(String, Object...)
). - 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.
- 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.
- 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.
- SqlRow - Interface in org.apache.ignite.sql
-
Provides methods to access row data by column name or ID.
- 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
- start() - Method in interface org.apache.ignite.IgniteServer
-
Starts the node.
- 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.
- 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.
- startTime() - Method in class org.apache.ignite.table.ContinuousQueryPhysicalTimeWatermark
- 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.
- 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.
- 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.
- 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
- STRING - Enum constant in enum class org.apache.ignite.sql.ColumnType
-
String.
- stringValue(int) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
String
column value. - stringValue(String) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
String
column value. - structures() - Method in interface org.apache.ignite.Ignite
-
Returns
IgniteStructures
which can be used to create and access to different distributed structes. - 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. - supportsSingleQueryLoading() - Method in class org.apache.ignite.data.IgniteDialect
- SYNC - Enum constant in enum class org.apache.ignite.cache.CacheWriteMode
-
Cache store writes are synchronous.
- 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.Unused. Replaced with
ErrorGroups.Sql.STMT_VALIDATION_ERR
. - 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
-
Get table (
IgniteTables.table(String)
). - 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
withErrorGroups.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(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
ornull
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
ornull
if table doesn't exist. - 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 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.
- TableNotFoundException(QualifiedName, Throwable) - Constructor for exception org.apache.ignite.lang.TableNotFoundException
-
Creates an exception with the given table name.
- TableRowEvent<T> - Interface in org.apache.ignite.table
-
Table row event.
- TableRowEventBatch<T> - Interface in org.apache.ignite.table
-
Table row event batch.
- TableRowEventType - Enum Class in org.apache.ignite.table
-
Table row event type.
- tables() - Method in interface org.apache.ignite.Ignite
-
Returns an object for manipulating 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.
- TableViewOptions - Class in org.apache.ignite.table
-
Table view options.
- TableViewOptions.Builder - Class in org.apache.ignite.table
-
Builder.
- 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.
- 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(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 interface org.apache.ignite.table.Tuple
-
Gets a
Instant
column value. - timestampValue(String) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
Instant
column value. - timeValue(int) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
LocalTime
column value. - 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.CacheDefinition
-
Returns new builder using this definition.
- 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(ObjectT) - Method in interface org.apache.ignite.table.mapper.TypeConverter
-
Converts a given object to a column type.
- 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.
- 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.deployment.DeploymentUnit
- 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.network.NetworkAddress
- toString() - Method in class org.apache.ignite.network.NodeMetadata
- toString() - Method in class org.apache.ignite.table.NearCacheOptions
- toString() - Method in class org.apache.ignite.table.QualifiedName
- toString() - Method in class org.apache.ignite.table.TableViewOptions
- 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
- 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
-
Contains All Keys (
KeyValueView.containsAll(Transaction, Collection)
). - TUPLE_CONTAINS_KEY - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Contains Key (
KeyValueView.contains(Transaction, Object)
). - TUPLE_DELETE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Delete (
RecordView.delete(Transaction, Object)
). - TUPLE_DELETE_ALL - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Delete All (
RecordView.deleteAll(Transaction, Collection)
). - TUPLE_DELETE_ALL_EXACT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Delete All Exact (
RecordView.deleteAllExact(Transaction, Collection)
). - TUPLE_DELETE_EXACT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Delete Exact (
RecordView.deleteExact(Transaction, Object)
). - 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
-
Get All (
RecordView.getAll(Transaction, Collection)
). - TUPLE_GET_AND_DELETE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Get and Delete (
RecordView.getAndDelete(Transaction, Object)
). - TUPLE_GET_AND_REPLACE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Get and Replace (
RecordView.getAndReplace(Transaction, Object)
). - TUPLE_GET_AND_UPSERT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Get and Upsert (
RecordView.getAndUpsert(Transaction, Object)
). - TUPLE_INSERT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Insert (
RecordView.insert(Transaction, Object)
). - TUPLE_INSERT_ALL - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Insert All (
RecordView.insertAll(Transaction, Collection)
). - TUPLE_REPLACE - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Replace (
RecordView.replace(Transaction, Object)
). - TUPLE_REPLACE_EXACT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Replace Exact (
RecordView.replace(Transaction, Object, Object)
). - TUPLE_UPSERT - Enum constant in enum class org.apache.ignite.client.ClientOperationType
-
Upsert (
RecordView.upsert(Transaction, Object)
). - 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
. - 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 interface org.apache.ignite.client.IgniteClientAuthenticator
-
Authenticator type.
- type() - Method in interface org.apache.ignite.sql.ColumnMetadata
-
Returns an SQL column type.
- type() - Method in interface org.apache.ignite.table.TableRowEvent
-
Gets the event 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.
- typeName() - Method in class org.apache.ignite.catalog.ColumnType
-
Returns SQL type name of the column type.
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 isnull
). - 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.
- 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(Object) - Method in interface org.apache.ignite.marshalling.NoopMarshaller
- 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.
- updateCounters() - Method in exception org.apache.ignite.sql.SqlBatchException
-
Returns an array that describes the outcome of a batch execution.
- UPDATED - Enum constant in enum class org.apache.ignite.table.TableRowEventType
-
Row updated.
- updatePollInterval() - Method in class org.apache.ignite.table.NearCacheOptions
-
The period of time with which updates are requested from the server in milliseconds.
- updatePollInterval(int) - Method in class org.apache.ignite.table.NearCacheOptions.Builder
-
Sets the period of time with which updates are requested from the server, in milliseconds.
- 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.
- 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 interface org.apache.ignite.table.Tuple
-
Gets a
UUID
column value. - uuidValue(String) - Method in interface org.apache.ignite.table.Tuple
-
Gets a
UUID
column value.
V
- VALIDATION_ERR - Static variable in class org.apache.ignite.lang.ErrorGroups.Catalog
-
Command to the catalog has not passed the validation.
- value() - Element in annotation interface org.apache.ignite.catalog.annotations.Cache
-
The name of the cache.
- 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(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.CacheDefinition.Builder
-
Sets value class to generate columns.
- value(Class<?>) - Method in class org.apache.ignite.catalog.definitions.TableDefinition.Builder
-
Sets value class to generate columns.
- value(String) - Method in interface org.apache.ignite.table.Tuple
-
Gets a column value for the given column name.
- valueClass() - Method in class org.apache.ignite.catalog.definitions.CacheDefinition
-
Returns a class to use to generate columns.
- 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.cache.CacheWriteMode
-
Returns the enum constant of this class with the specified name.
- 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.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.
- valueOf(String) - Static method in enum class org.apache.ignite.table.TableRowEventType
-
Returns the enum constant of this class with the specified name.
- 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.cache.CacheWriteMode
-
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.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.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.
- values() - Static method in enum class org.apache.ignite.table.TableRowEventType
-
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.deployment.DeploymentUnit
-
Returns 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.
- 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.
W
- waitForInitAsync() - Method in interface org.apache.ignite.IgniteServer
-
Waits for the cluster initialization.
- 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.
- watermark() - Method in class org.apache.ignite.table.ContinuousQueryOptions
-
Gets the starting watermark.
- watermark() - Method in interface org.apache.ignite.table.TableRowEvent
-
Gets the event watermark for resume and failover purposes.
- watermark() - Method in interface org.apache.ignite.table.TableRowEventBatch
-
Gets the batch watermark for resume and failover purposes.
- watermark(ContinuousQueryWatermark) - Method in class org.apache.ignite.table.ContinuousQueryOptions.Builder
-
Sets the starting watermark.
- writeAllAsync(CacheStoreSession, Collection<Map.Entry<? extends K, ? extends V>>) - Method in interface org.apache.ignite.cache.CacheStore
-
Write a batch to the store.
- writeAsync(CacheStoreSession, Map.Entry<? extends K, ? extends V>) - Method in interface org.apache.ignite.cache.CacheStore
-
Write a single entry to the store.
Z
- zone() - Element in annotation interface org.apache.ignite.catalog.annotations.Cache
-
Class annotated with
Zone
annotation to create a zone. - 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.CacheDefinition.Builder
-
Sets primary zone name.
- 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.CacheDefinition
-
Returns primary zone name.
- 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.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
IgniteCluster.nodes()
instead.