Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Z 

A

AboutDialog - Class in org.apache.ignite.startup.cmdline
About dialog.
AbstractContinuousQuery<K,V> - Class in org.apache.ignite.cache.query
Base class for continuous query.
AbstractContinuousQuery() - Constructor for class org.apache.ignite.cache.query.AbstractContinuousQuery
 
AbstractEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction
Common functionality implementation for eviction policies with max size/max memory and batch eviction support.
AbstractEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
 
AbstractEvictionPolicyFactory<T> - Class in org.apache.ignite.cache.eviction
Common functionality implementation for eviction policies factories.
AbstractEvictionPolicyFactory() - Constructor for class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
 
AbstractFailureHandler - Class in org.apache.ignite.failure
Abstract superclass for FailureHandler implementations.
AbstractFailureHandler() - Constructor for class org.apache.ignite.failure.AbstractFailureHandler
 
AbstractMarshaller - Class in org.apache.ignite.marshaller
Base class for marshallers.
AbstractMarshaller() - Constructor for class org.apache.ignite.marshaller.AbstractMarshaller
 
AbstractNodeNameAwareMarshaller - Class in org.apache.ignite.marshaller
Marshaller allowing for Ignition.localIgnite() calls.
AbstractNodeNameAwareMarshaller() - Constructor for class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
 
AbstractSslContextFactory - Class in org.apache.ignite.ssl
Represents abstract implementation of SSL Context Factory that caches the result of the first successful attempt to create an SSLContext and always returns it as a result of further invocations of the AbstractSslContextFactory.create()} method.
AbstractSslContextFactory() - Constructor for class org.apache.ignite.ssl.AbstractSslContextFactory
 
accept(int, String, Class<T>) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeVisitor
Visit some object property.
accept(int, String, Class<T>, T) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptBoolean(int, String, boolean) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptByte(int, String, byte) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptChar(int, String, char) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptDouble(int, String, double) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptFloat(int, String, float) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptInt(int, String, int) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptLong(int, String, long) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptShort(int, String, short) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker.AttributeWithValueVisitor
Visit attribute.
acceptsURL(String) - Method in class org.apache.ignite.IgniteJdbcDriver
acceptsURL(String) - Method in class org.apache.ignite.IgniteJdbcThinDriver
ackMessage() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiCustomMessage
Called when custom message has been handled by all nodes.
acquire() - Method in interface org.apache.ignite.IgniteSemaphore
Acquires a permit from this semaphore, blocking until one is available, or the thread is interrupted.
acquire(int) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given number of permits from this semaphore, blocking until all are available, or the thread is interrupted.
acquireAndExecute(IgniteCallable<T>, int) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given semaphore, executes the given callable and schedules the release of permits asynchronously
acquireUninterruptibly() - Method in interface org.apache.ignite.IgniteSemaphore
Acquires a permit from this semaphore, blocking until one is available.
acquireUninterruptibly(int) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given number of permits from this semaphore, blocking until all are available.
actionsForMaintenanceTask(String) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
All MaintenanceActions provided by a component for MaintenanceTask with a given name.
activate() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Activates the job.
active() - Method in enum org.apache.ignite.cluster.ClusterState
 
active() - Method in interface org.apache.ignite.Ignite
Deprecated.
active(boolean) - Method in interface org.apache.ignite.Ignite
Deprecated.
active() - Method in interface org.apache.ignite.IgniteCluster
Deprecated.
active(boolean) - Method in interface org.apache.ignite.IgniteCluster
Deprecated.
active() - Method in class org.apache.ignite.IgniteSpringBean
Checks Ignite grid is active or not active.
active(boolean) - Method in class org.apache.ignite.IgniteSpringBean
Changes Ignite grid state to active or inactive.
active(boolean) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
active() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.active" instead.
ACTIVE_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
ACTIVE_JOBS_THRESHOLD_NODE_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Threshold of maximum jobs executing concurrently.
activeJobs() - Method in interface org.apache.ignite.spi.collision.CollisionContext
Gets ordered collection of collision contexts for jobs that are currently executing.
activeMaintenanceTask(String) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Returns active MaintenanceTask by its name.
activeTaskFutures() - Method in interface org.apache.ignite.IgniteCompute
Gets tasks future for active tasks started on local node.
AdaptiveCpuLoadProbe - Class in org.apache.ignite.spi.loadbalancing.adaptive
Implementation of node load probing based on CPU load.
AdaptiveCpuLoadProbe() - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Initializes CPU load probe to use CPU load average by default.
AdaptiveCpuLoadProbe(boolean, boolean) - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Specifies whether to use average CPU load vs. current and whether or not to take number of processors into account.
AdaptiveCpuLoadProbe(boolean, boolean, double) - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Specifies whether to use average CPU load vs. current and whether or not to take number of processors into account.
AdaptiveJobCountLoadProbe - Class in org.apache.ignite.spi.loadbalancing.adaptive
Implementation of node load probing based on active and waiting job count.
AdaptiveJobCountLoadProbe() - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
Initializes active job probe.
AdaptiveJobCountLoadProbe(boolean) - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
Creates new active job prove specifying whether to use average job counts vs. current.
AdaptiveLoadBalancingSpi - Class in org.apache.ignite.spi.loadbalancing.adaptive
Load balancing SPI that adapts to overall node performance.
AdaptiveLoadBalancingSpi() - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
 
AdaptiveLoadBalancingSpiMBean - Interface in org.apache.ignite.spi.loadbalancing.adaptive
Management MBean for AdaptiveLoadBalancingSpi SPI.
AdaptiveLoadProbe - Interface in org.apache.ignite.spi.loadbalancing.adaptive
Pluggable implementation of node load probing.
AdaptiveProcessingTimeLoadProbe - Class in org.apache.ignite.spi.loadbalancing.adaptive
Implementation of node load probing based on total job processing time.
AdaptiveProcessingTimeLoadProbe() - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
Initializes execution time load probe to use execution time average by default.
AdaptiveProcessingTimeLoadProbe(boolean) - Constructor for class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
Specifies whether to use average execution time vs. current.
add(T) - Method in interface org.apache.ignite.client.ClientIgniteSet
add(T) - Method in interface org.apache.ignite.IgniteQueue
add(T) - Method in interface org.apache.ignite.IgniteSet
add(Throwable) - Method in exception org.apache.ignite.spi.IgniteSpiMultiException
Adds a new cause for multi-exception.
addAll(Collection<? extends T>) - Method in interface org.apache.ignite.client.ClientIgniteSet
addAll(Collection<? extends T>) - Method in interface org.apache.ignite.IgniteQueue
addAll(Collection<? extends T>) - Method in interface org.apache.ignite.IgniteSet
addAndGet(long) - Method in interface org.apache.ignite.client.ClientAtomicLong
Adds l and gets current value of atomic long.
addAndGet(long) - Method in interface org.apache.ignite.IgniteAtomicLong
Adds l and gets current value of atomic long.
addAndGet(long) - Method in interface org.apache.ignite.IgniteAtomicSequence
Adds l elements to atomic sequence and gets value of atomic sequence.
addAttributeListener(ComputeTaskSessionAttributeListener, boolean) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Add listener for the session attributes.
addCacheConfiguration(CacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Adds cache configuration template.
addCacheConfiguration(CacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Adds cache configuration template.
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
addConsoleAppender(boolean) - Method in class org.apache.ignite.logger.java.JavaLogger
Adds console appender to the logger.
addConsoleAppender(boolean) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Adds console appender to the logger.
addData(K, V) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
addData(Map.Entry<K, V>) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
addData(Collection<? extends Map.Entry<K, V>>) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
addData(Map<K, V>) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds data for streaming on remote node.
addGridCommonData(Integer, Serializable) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
addIncomeConnectionListener(IgniteInClosure<Socket>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
addJoiningNodeData(Integer, Serializable) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
addListener(IgnitionListener) - Static method in class org.apache.ignite.Ignition
Adds a lsnr for grid life cycle events.
addLocalEventListener(GridLocalEventListener, int...) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Adds an event listener for local events.
addLocalMessageListener(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Register an local message listener to receive messages sent by remote nodes.
addLog(String) - Method in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
Logs work to span.
addLog(String) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
Logs work to span.
addLog(String) - Method in interface org.apache.ignite.spi.tracing.SpiSpecificSpan
Logs work to span.
addMessage(T) - Method in class org.apache.ignite.stream.StreamAdapter
Converts given message to 1 or many tuples (depending on the type of extractor) and adds it/them to the underlying streamer.
addMessageListener(GridMessageListener, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
addMeta(T) - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Adds a new metadata.
addMetricRegistryCreationListener(Consumer<ReadOnlyMetricRegistry>) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Register listener which will be notified on metric registry creation.
addMetricRegistryCreationListener(Consumer<ReadOnlyMetricRegistry>) - Method in interface org.apache.ignite.spi.metric.ReadOnlyMetricManager
Adds listener of metrics registry creation events.
addMetricRegistryRemoveListener(Consumer<ReadOnlyMetricRegistry>) - Method in interface org.apache.ignite.spi.metric.ReadOnlyMetricManager
Adds listener of metrics registry remove events.
addNodeSpecificData(Integer, Serializable) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
addQueryField(String, String, String) - Method in class org.apache.ignite.cache.QueryEntity
Utility method for building query entities programmatically.
address() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets subject network address.
address(InetSocketAddress) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets subject network address.
address() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Gets subject connection address.
addresses() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets collection of addresses this node is known by.
addresses() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
addresses() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets collection of addresses this node is known by.
addresses() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
AddressResolver - Interface in org.apache.ignite.configuration
Provides resolution between external and internal addresses.
addSendMessageListener(IgniteInClosure<TcpDiscoveryAbstractMessage>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
addSystemViewCreationListener(Consumer<SystemView<?>>) - Method in interface org.apache.ignite.spi.systemview.ReadOnlySystemViewRegistry
Adds listener of view creation events.
addTag(String, String) - Method in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
Adds tag to span with String value.
addTag(String, String) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
Adds tag to span with String value.
addTag(String, String) - Method in interface org.apache.ignite.spi.tracing.SpiSpecificSpan
Adds tag to span with String value.
addTimeoutObject(IgniteSpiTimeoutObject) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
 
addTimeoutObject(IgniteSpiTimeoutObject) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
Affinity<K> - Interface in org.apache.ignite.cache.affinity
Provides affinity information to detect which node is primary and which nodes are backups for a partitioned or replicated cache.
affinity(String) - Method in interface org.apache.ignite.Ignite
Gets affinity service to provide information about data partitioning and distribution.
affinity(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets affinity service to provide information about data partitioning and distribution.
affinity() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
affinity() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
AFFINITY_CALL_ATTEMPT - Static variable in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Name of job context attribute containing number of affinity call attempts.
affinityCacheIds() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
affinityCacheName() - Method in interface org.apache.ignite.spi.failover.FailoverContext
affinityCacheName() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
affinityCall(String, Object, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityCall(Collection<String>, Object, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityCall(Collection<String>, int, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where partition is located (the partition is primary on the node) It's guaranteed that the data of all the partitions of all participating caches, the affinity key belongs to, will present on the destination node throughout the job execution.
affinityCall(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteQueue
Executes given job on collocated queue on the node where the queue is located (a.k.a. affinity co-location).
affinityCall(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteSet
Executes given job on collocated set on the node where the set is located (a.k.a. affinity co-location).
affinityCallAsync(String, Object, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityCallAsync(Collection<String>, Object, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityCallAsync(Collection<String>, int, IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where partition is located (the partition is primary on the node) The data of the partition will not be migrated from the target node while the job is executed.
AffinityCentralizedFunction - Annotation Type in org.apache.ignite.cache.affinity
Annotation marker which identifies affinity function that must be calculated on one centralized node instead of independently on each node.
affinityColumn() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
AffinityFunction - Interface in org.apache.ignite.cache.affinity
Cache key affinity which maps keys to nodes.
AffinityFunctionContext - Interface in org.apache.ignite.cache.affinity
Affinity function context.
affinityKey(K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Maps passed in key to a key which will be used for node affinity.
AffinityKey<K> - Class in org.apache.ignite.cache.affinity
Optional wrapper for cache keys to provide support for custom affinity mapping.
AffinityKey() - Constructor for class org.apache.ignite.cache.affinity.AffinityKey
Empty constructor.
AffinityKey(K) - Constructor for class org.apache.ignite.cache.affinity.AffinityKey
Initializes key wrapper for a given key.
AffinityKey(K, Object) - Constructor for class org.apache.ignite.cache.affinity.AffinityKey
Initializes key together with its affinity key counter-part.
affinityKey() - Method in class org.apache.ignite.cache.affinity.AffinityKey
Gets affinity key to use for affinity mapping.
affinityKey(Object) - Method in class org.apache.ignite.cache.affinity.AffinityKey
Sets affinity key to use for affinity mapping.
affinityKey(Object) - Method in interface org.apache.ignite.cache.affinity.AffinityKeyMapper
Deprecated.
Maps passed in key to an alternate key which will be used for node affinity.
affinityKey() - Method in interface org.apache.ignite.services.ServiceContext
Gets affinity key used for key-to-node affinity calculation.
affinityKey() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets affinity key used for key-to-node affinity calculation.
affinityKey() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
affinityKeyColumn() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns name of affinity key column.
affinityKeyFieldName() - Method in interface org.apache.ignite.binary.BinaryType
Binary objects can optionally specify custom key-affinity mapping in the configuration.
AffinityKeyMapped - Annotation Type in org.apache.ignite.cache.affinity
Optional annotation to specify custom key-to-node affinity.
AffinityKeyMapper - Interface in org.apache.ignite.cache.affinity
affinityMapper() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
affinityPartitionId() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
affinityPartitionId() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
affinityRun(String, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRun(Collection<String>, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRun(Collection<String>, int, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job on the node where partition is located (the partition is primary on the node) It's guaranteed that the data of all the partitions of all participating caches, the affinity key belongs to, will present on the destination node throughout the job execution.
affinityRun(IgniteRunnable) - Method in interface org.apache.ignite.IgniteQueue
Executes given job on collocated queue on the node where the queue is located (a.k.a. affinity co-location).
affinityRun(IgniteRunnable) - Method in interface org.apache.ignite.IgniteSet
Executes given job on collocated set on the node where the set is located (a.k.a. affinity co-location).
affinityRunAsync(String, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRunAsync(Collection<String>, Object, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where data for provided affinity key is located (a.k.a. affinity co-location).
affinityRunAsync(Collection<String>, int, IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes given job asynchronously on the node where partition is located (the partition is primary on the node) The data of the partition will not be migrated from the target node while the job is executed.
AffinityUuid - Class in org.apache.ignite.cache.affinity
Guaranteed unique affinity-based key.
AffinityUuid() - Constructor for class org.apache.ignite.cache.affinity.AffinityUuid
Empty constructor.
AffinityUuid(Object) - Constructor for class org.apache.ignite.cache.affinity.AffinityUuid
Constructs unique affinity UUID based on affinity key.
affKey - Variable in class org.apache.ignite.services.ServiceConfiguration
Affinity key.
affKeyFieldName() - Method in class org.apache.ignite.spi.systemview.view.BinaryMetadataView
 
afterExecute(Runnable, Throwable) - Method in class org.apache.ignite.thread.IgniteThreadPoolExecutor
afterInnerMessageRead(boolean) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Callback called after inner message is read.
afterInnerMessageWrite(boolean) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Callback called after inner message is written.
afterMessageRead(Class<? extends Message>) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Callback that must be invoked by a message implementation after message body finished decoding.
afterSingletonsInstantiated() - Method in class org.apache.ignite.IgniteSpringBean
alias() - Method in class org.apache.ignite.events.DeploymentEvent
Gets deployment alias for this event.
alias(String) - Method in class org.apache.ignite.events.DeploymentEvent
Sets deployment alias for this event.
alive() - Method in interface org.apache.ignite.cdc.CdcConsumer
Checks that consumer still alive.
ALL_NODES - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Filter that accepts all nodes.
ALL_PERMISSIONS - Static variable in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
 
allActions() - Method in interface org.apache.ignite.maintenance.MaintenanceWorkflowCallback
Supplies list of MaintenanceActions that user can call to fix maintenance situation for the component or get information about ongoing actions.
allGrids() - Static method in class org.apache.ignite.Ignition
Gets a list of all grids started so far.
allNodesSupport(IgniteFeatures) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
allNodesSupport(IgniteFeatures) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
allNodesSupport(IgniteFeatures) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
allocateMemory(long) - Method in interface org.apache.ignite.mem.MemoryAllocator
 
allowOverwrite() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets flag enabling overwriting existing values in cache.
allowOverwrite(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets flag enabling overwriting existing values in cache.
allPartitions(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets partition ids for which given cluster node has any ownership (either primary or backup).
ALREADY_CONNECTED - Static variable in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
 
AlwaysFailoverSpi - Class in org.apache.ignite.spi.failover.always
Failover SPI that always reroutes a failed job to another node.
AlwaysFailoverSpi() - Constructor for class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
 
AlwaysFailoverSpiMBean - Interface in org.apache.ignite.spi.failover.always
Management bean for AlwaysFailoverSpi.
and(IgniteBiPredicate<E1, E2>) - Method in interface org.apache.ignite.lang.IgniteBiPredicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
ANONYMOUS_LOGGER_NAME - Static variable in class org.apache.ignite.logger.java.JavaLoggerFormatter
Name for anonymous loggers.
appendCachePermissions(String, SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append permission set form cache with name.
appendServicePermissions(String, SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append permission set form service with name.
appendSystemPermissions(SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append system permission set.
appendTaskPermissions(String, SecurityPermission...) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append permission set form task with name.
apply(ClusterNode, List<ClusterNode>) - Method in class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeAffinityBackupFilter
Defines a predicate which returns true if a node is acceptable for a backup or false otherwise.
apply(ClusterNode, List<ClusterNode>) - Method in class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeColocatedBackupFilter
Defines a predicate which returns true if a node is acceptable for a backup or false otherwise.
apply(ClusterNode) - Method in class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
Predicate body.
apply(IgniteClosure<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on a node within the underlying cluster group.
apply(IgniteClosure<T, R>, Collection<? extends T>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on nodes within the underlying cluster group.
apply(IgniteClosure<T, R1>, Collection<? extends T>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job on nodes within the underlying cluster group.
apply(E1, E2) - Method in interface org.apache.ignite.lang.IgniteBiClosure
Closure body.
apply(E1, E2) - Method in interface org.apache.ignite.lang.IgniteBiInClosure
Closure body.
apply(E1, E2) - Method in interface org.apache.ignite.lang.IgniteBiPredicate
Predicate body.
apply(E) - Method in interface org.apache.ignite.lang.IgniteClosure
Closure body.
apply(E) - Method in interface org.apache.ignite.lang.IgniteInClosure
Closure body.
apply() - Method in interface org.apache.ignite.lang.IgniteOutClosure
Closure body.
apply(E) - Method in interface org.apache.ignite.lang.IgnitePredicate
Predicate body.
apply(UUID, T) - Method in class org.apache.ignite.messaging.MessagingListenActor
Predicate body.
apply(Object) - Method in class org.apache.ignite.spi.indexing.IndexingQueryCacheFilter
Apply filter.
apply(IgniteConfiguration) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Closure body.
applyAsync(IgniteClosure<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job asynchronously on a node within the underlying cluster group.
applyAsync(IgniteClosure<T, R>, Collection<? extends T>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job asynchronously on nodes within the underlying cluster group.
applyAsync(IgniteClosure<T, R1>, Collection<? extends T>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided closure job asynchronously on nodes within the underlying cluster group.
applyPartition(int) - Method in class org.apache.ignite.spi.indexing.IndexingQueryCacheFilter
Apply filter.
argument(int) - Method in class org.apache.ignite.compute.ComputeJobAdapter
Gets job argument.
arguments() - Method in class org.apache.ignite.compute.ComputeJobAdapter
Gets array of job arguments.
arguments() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets query arguments.
arguments() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets query arguments.
arguments() - Method in class org.apache.ignite.events.SqlQueryExecutionEvent
Gets query arguments.
assertParameter(boolean, String) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Throws exception with uniform error message if given parameter's assertion condition is false.
assignPartition(int, List<ClusterNode>, int, Map<UUID, Collection<ClusterNode>>) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Returns collection of nodes (primary first) for specified partition.
assignPartitions(AffinityFunctionContext) - Method in interface org.apache.ignite.cache.affinity.AffinityFunction
Gets affinity nodes for a partition.
assignPartitions(AffinityFunctionContext) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets affinity nodes for a partition.
assignPartitions(AffinityFunctionContext) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Gets affinity nodes for a partition.
AtomicConfiguration - Class in org.apache.ignite.configuration
Configuration for atomic data structures.
AtomicConfiguration() - Constructor for class org.apache.ignite.configuration.AtomicConfiguration
 
atomicityMode() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
atomicityMode() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
atomicLong(String, long, boolean) - Method in interface org.apache.ignite.client.IgniteClient
Gets an atomic long from cache and creates one if it has not been created yet and create flag is true.
atomicLong(String, ClientAtomicConfiguration, long, boolean) - Method in interface org.apache.ignite.client.IgniteClient
Gets an atomic long from cache and creates one if it has not been created yet and create flag is true.
atomicLong(String, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic long from cache and create one if it has not been created yet and create flag is true.
atomicLong(String, AtomicConfiguration, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic long from cache and create one if it has not been created yet and create flag is true.
atomicLong(String, long, boolean) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets an atomic long from cache and creates one if it has not been created yet and create flag is true.
atomicLong(String, ClientAtomicConfiguration, long, boolean) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets an atomic long from cache and creates one if it has not been created yet and create flag is true.
atomicLong(String, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic long from cache and create one if it has not been created yet and create flag is true.
atomicLong(String, AtomicConfiguration, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic long from cache and create one if it has not been created yet and create flag is true.
AtomicLongView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicLong representation for a SystemView.
AtomicLongView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicLongView
 
atomicReference(String, T, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
atomicReference(String, AtomicConfiguration, T, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
atomicReference(String, T, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
atomicReference(String, AtomicConfiguration, T, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic reference from cache and create one if it has not been created yet and create flag is true.
AtomicReferenceView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicReference representation for a SystemView.
AtomicReferenceView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicReferenceView
 
atomicSequence(String, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
atomicSequence(String, AtomicConfiguration, long, boolean) - Method in interface org.apache.ignite.Ignite
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
atomicSequence(String, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
atomicSequence(String, AtomicConfiguration, long, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get an atomic sequence from cache and create one if it has not been created yet and create flag is true.
AtomicSequenceView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicSequence representation for a SystemView.
AtomicSequenceView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicSequenceView
 
atomicStamped(String, T, S, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic stamped from cache and create one if it has not been created yet and create flag is true.
atomicStamped(String, AtomicConfiguration, T, S, boolean) - Method in interface org.apache.ignite.Ignite
Will get a atomic stamped from cache and create one if it has not been created yet and create flag is true.
atomicStamped(String, T, S, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic stamped from cache and create one if it has not been created yet and create flag is true.
atomicStamped(String, AtomicConfiguration, T, S, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Will get a atomic stamped from cache and create one if it has not been created yet and create flag is true.
AtomicStampedView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteAtomicStamped representation for a SystemView.
AtomicStampedView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.AtomicStampedView
 
attach(Object) - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Attaches the given object to this session.
attachment() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Retrieves the current attachment or null if there is no attachment.
ATTR_ADDRS - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node IP addresses (value is comm.tcp.addrs).
ATTR_CONN_PROP - Static variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Connection attribute property name.
ATTR_EXT_ADDRS - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node's external addresses (value is comm.tcp.ext-addrs).
ATTR_EXT_ADDRS - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Node attribute that is mapped to node's external addresses (value is disc.tcp.ext-addrs).
ATTR_FORCE_CLIENT_SERVER_CONNECTIONS - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
ATTR_HOST_NAMES - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node host names (value is comm.tcp.host.names).
ATTR_PAIRED_CONN - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Attr paired connection.
ATTR_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node attribute that is mapped to node port number (value is comm.tcp.port).
ATTR_SHMEM_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Deprecated.
This constant is not used and will be removed in future releases.
attribute(String) - Method in interface org.apache.ignite.cluster.BaselineNode
Gets a node attribute.
attribute(String) - Method in interface org.apache.ignite.cluster.ClusterNode
Gets a node attribute.
attribute(String) - Method in interface org.apache.ignite.services.ServiceCallContext
Get the string attribute.
attribute(String) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets a node attribute.
attributeNames() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
 
AttributeNames - Class in org.apache.ignite.spi.communication.tcp
Deprecated.
fix it in the ticket https://ggsystems.atlassian.net/browse/GG-29546
AttributeNames(String, String, String, String, String, String) - Constructor for class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
attributes() - Method in interface org.apache.ignite.cluster.BaselineNode
Gets all node attributes.
attributes() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets all node attributes.
attributes() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets all node attributes.
attributeValues(String) - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
 
authenticatedSubject(UUID) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets security subject based on subject ID.
authenticatedSubjects() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets collection of authenticated subjects together with their permissions.
authenticateNode(ClusterNode, SecurityCredentials) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiNodeAuthenticator
Security credentials.
AuthenticationContext - Class in org.apache.ignite.plugin.security
Authentication context.
AuthenticationContext() - Constructor for class org.apache.ignite.plugin.security.AuthenticationContext
 
authenticationFailedError(TcpDiscoveryAuthFailedMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
autoAdjustTimeout() - Method in class org.apache.ignite.events.BaselineConfigurationChangedEvent
 
autoDelete() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets autoDelete flag.
autoDelete() - Method in class org.apache.ignite.spi.systemview.view.datastructures.CountDownLatchView
 
autoFlushFrequency() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets automatic flush frequency.
autoFlushFrequency(long) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets automatic flush frequency.
autoIncrement() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
automaticAction() - Method in interface org.apache.ignite.maintenance.MaintenanceWorkflowCallback
Component can provide optional MaintenanceAction that will be executed automatically by MaintenanceRegistry when node enters maintenance mode.
autoUnsubscribe() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
AVAILABLE_PROC_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default core size of public thread pool.
availablePermits() - Method in interface org.apache.ignite.IgniteSemaphore
Returns the current number of permits available in this semaphore.
availablePermits() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
averageExecutionTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets average execution time in milliseconds since future was created.
averageIdleTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets average idle time for this scheduled task.
averageTime() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets average execution time of query.
averageTime() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets average execution time of query.
avgActiveJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgCanceledJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgCpuLoad() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgJobsExecuteTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgJobsWaitTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgRejectedJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
avgWaitingJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
await() - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted.
await(long, TimeUnit) - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted, or the specified waiting time elapses.
await() - Method in interface org.apache.ignite.IgniteCountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless current thread is interrupted.
await(long) - Method in interface org.apache.ignite.IgniteCountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted, or the specified waiting time elapses.
await(long, TimeUnit) - Method in interface org.apache.ignite.IgniteCountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted, or the specified waiting time elapses.
awaitNanos(long) - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted, or the specified waiting time elapses.
awaitTermination(long, TimeUnit) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
awaitUninterruptibly() - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled.
awaitUntil(Date) - Method in interface org.apache.ignite.IgniteCondition
Causes the current thread to wait until it is signalled or interrupted, or the specified deadline elapses.

B

backoffTimeout(long, long) - Static method in class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
 
backupPartitions(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets partition ids for which given cluster node has backup ownership.
backups() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets number of backups for new assignment.
backups() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
backups() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
baselineAutoAdjustEnabled(boolean) - Method in interface org.apache.ignite.IgniteCluster
 
BaselineAutoAdjustMXBean - Interface in org.apache.ignite.mxbean
This interface defines JMX view on DistributedBaselineConfiguration.
baselineAutoAdjustStatus() - Method in interface org.apache.ignite.IgniteCluster
 
baselineAutoAdjustTimeout() - Method in interface org.apache.ignite.IgniteCluster
 
baselineAutoAdjustTimeout(long) - Method in interface org.apache.ignite.IgniteCluster
 
BaselineChangedEvent - Class in org.apache.ignite.events
Baseline changed event.
BaselineChangedEvent(ClusterNode, String, int, Collection<BaselineNode>) - Constructor for class org.apache.ignite.events.BaselineChangedEvent
Creates baseline changed event with given parameters.
BaselineConfigurationChangedEvent - Class in org.apache.ignite.events
Baseline configuration changed event.
BaselineConfigurationChangedEvent(ClusterNode, String, int, boolean, long) - Constructor for class org.apache.ignite.events.BaselineConfigurationChangedEvent
Creates baseline configuration changed event with given parameters.
BaselineNode - Interface in org.apache.ignite.cluster
Interface representing a single node from baseline topology.
BaselineNodeAttributeView - Class in org.apache.ignite.spi.systemview.view
Baseline node attribute representation for a SystemView.
BaselineNodeAttributeView(Object, String, Object) - Constructor for class org.apache.ignite.spi.systemview.view.BaselineNodeAttributeView
 
baselineNodes() - Method in class org.apache.ignite.events.BaselineChangedEvent
 
baselineNodes() - Method in class org.apache.ignite.events.ClusterActivationEvent
Deprecated.
Gets baseline nodes.
baselineNodes() - Method in class org.apache.ignite.events.ClusterStateChangeEvent
Gets baseline nodes.
baselineNodes() - Method in class org.apache.ignite.spi.systemview.view.SnapshotView
 
BaselineNodeView - Class in org.apache.ignite.spi.systemview.view
Baseline topology node representation for a SystemView.
BaselineNodeView(Object, boolean) - Constructor for class org.apache.ignite.spi.systemview.view.BaselineNodeView
 
BasicAddressResolver - Class in org.apache.ignite.configuration
Basic implementation of AddressResolver.
BasicAddressResolver(Map<String, String>) - Constructor for class org.apache.ignite.configuration.BasicAddressResolver
Created the address resolver.
BasicJdbcDialect - Class in org.apache.ignite.cache.store.jdbc.dialect
Basic implementation of dialect based on JDBC specification.
BasicJdbcDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
 
BasicJdbcIpFinderDialect - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
Basic JDBC dialect to use along with TcpDiscoveryJdbcIpFinder.
BasicJdbcIpFinderDialect() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.BasicJdbcIpFinderDialect
 
BasicWarmupClosure - Class in org.apache.ignite.startup
Basic warm-up closure which warm-ups cache operations.
BasicWarmupClosure() - Constructor for class org.apache.ignite.startup.BasicWarmupClosure
 
batchSize() - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets local batch size for this atomic sequence.
batchSize(int) - Method in interface org.apache.ignite.IgniteAtomicSequence
Sets local batch size for atomic sequence.
batchSize() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicSequenceView
 
beforeExecute(Thread, Runnable) - Method in class org.apache.ignite.thread.IgniteThreadPoolExecutor
beforeInnerMessageRead() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Callback called before inner message is read.
beforeInnerMessageWrite() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Callback called before inner message is written.
beforeMessageRead() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Callback that must be invoked by a message implementation before message body started decoding.
between(String, Object, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Between.
binary() - Method in interface org.apache.ignite.client.IgniteClient
 
binary() - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteBinary interface.
binary() - Method in class org.apache.ignite.IgniteClientSpringBean
binary() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteBinary interface.
binaryAttribute(String) - Method in interface org.apache.ignite.services.ServiceCallContext
Get the binary attribute.
BinaryBasicIdMapper - Class in org.apache.ignite.binary
Base binary ID mapper implementation.
BinaryBasicIdMapper() - Constructor for class org.apache.ignite.binary.BinaryBasicIdMapper
Default constructor.
BinaryBasicIdMapper(boolean) - Constructor for class org.apache.ignite.binary.BinaryBasicIdMapper
 
BinaryBasicNameMapper - Class in org.apache.ignite.binary
Base binary name mapper implementation.
BinaryBasicNameMapper() - Constructor for class org.apache.ignite.binary.BinaryBasicNameMapper
Default constructor.
BinaryBasicNameMapper(boolean) - Constructor for class org.apache.ignite.binary.BinaryBasicNameMapper
 
BinaryCollectionFactory<K> - Interface in org.apache.ignite.binary
Collection factory.
BinaryConfiguration - Class in org.apache.ignite.configuration
Configuration object for Ignite Binary Objects.
BinaryConfiguration() - Constructor for class org.apache.ignite.configuration.BinaryConfiguration
 
BinaryField - Interface in org.apache.ignite.binary
Binary object field.
BinaryIdMapper - Interface in org.apache.ignite.binary
Type and field ID mapper for binary objects.
BinaryInvalidTypeException - Exception in org.apache.ignite.binary
Exception indicating that class needed for deserialization of binary object does not exist.
BinaryInvalidTypeException(String) - Constructor for exception org.apache.ignite.binary.BinaryInvalidTypeException
Creates invalid class exception with error message.
BinaryInvalidTypeException(Throwable) - Constructor for exception org.apache.ignite.binary.BinaryInvalidTypeException
Creates invalid class exception with Throwable as a cause.
BinaryInvalidTypeException(String, Throwable) - Constructor for exception org.apache.ignite.binary.BinaryInvalidTypeException
Creates invalid class exception with error message and Throwable as a cause.
Binarylizable - Interface in org.apache.ignite.binary
Interface that allows to implement custom serialization logic for binary objects.
BinaryMapFactory<K,V> - Interface in org.apache.ignite.binary
Map factory.
BinaryMetadataView - Class in org.apache.ignite.spi.systemview.view
BinaryMetadata representation for the SystemView.
BinaryMetadataView(BinaryMetadata) - Constructor for class org.apache.ignite.spi.systemview.view.BinaryMetadataView
 
BinaryNameMapper - Interface in org.apache.ignite.binary
Maps type and field names to different names.
BinaryObject - Interface in org.apache.ignite.binary
Wrapper for binary object in binary format.
BinaryObjectBuilder - Interface in org.apache.ignite.binary
Binary object builder.
BinaryObjectException - Exception in org.apache.ignite.binary
Exception indicating binary object serialization error.
BinaryObjectException(String) - Constructor for exception org.apache.ignite.binary.BinaryObjectException
Creates binary exception with error message.
BinaryObjectException(Throwable) - Constructor for exception org.apache.ignite.binary.BinaryObjectException
Creates binary exception with Throwable as a cause.
BinaryObjectException(String, Throwable) - Constructor for exception org.apache.ignite.binary.BinaryObjectException
Creates binary exception with error message and Throwable as a cause.
BinaryRawReader - Interface in org.apache.ignite.binary
Raw reader for binary objects.
BinaryRawWriter - Interface in org.apache.ignite.binary
Raw writer for binary object.
BinaryReader - Interface in org.apache.ignite.binary
Reader for binary objects used in Binarylizable implementations.
BinaryReflectiveSerializer - Class in org.apache.ignite.binary
Binary serializer which writes object fields using reflection.
BinaryReflectiveSerializer() - Constructor for class org.apache.ignite.binary.BinaryReflectiveSerializer
 
BinarySerializer - Interface in org.apache.ignite.binary
Interface that allows to implement custom serialization logic for binary objects.
BinaryType - Interface in org.apache.ignite.binary
Binary type meta data.
BinaryTypeConfiguration - Class in org.apache.ignite.binary
Defines configuration properties for a specific binary type.
BinaryTypeConfiguration() - Constructor for class org.apache.ignite.binary.BinaryTypeConfiguration
Constructor.
BinaryTypeConfiguration(BinaryTypeConfiguration) - Constructor for class org.apache.ignite.binary.BinaryTypeConfiguration
Copying constructor.
BinaryTypeConfiguration(String) - Constructor for class org.apache.ignite.binary.BinaryTypeConfiguration
 
BinaryWriter - Interface in org.apache.ignite.binary
Writer for binary object used in Binarylizable implementations.
blockSize() - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
 
blockSize() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
blockSize() - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
body() - Method in class org.apache.ignite.spi.IgniteSpiThread
Body of SPI thread.
BooleanMetric - Interface in org.apache.ignite.spi.metric
Interface for the metrics that holds boolean primitive.
bounded() - Method in interface org.apache.ignite.IgniteQueue
Returns true if this queue is bounded.
bounded() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
bounds() - Method in interface org.apache.ignite.spi.metric.HistogramMetric
 
brakeConnection() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST PURPOSE ONLY!
broadcast(IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given job to all nodes in the cluster group.
broadcast(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given job to all nodes in cluster group.
broadcast(IgniteClosure<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given closure job with passed in argument to all nodes in the cluster group.
broadcastAsync(IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given job asynchronously to all nodes in the cluster group.
broadcastAsync(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given job asynchronously to all nodes in cluster group.
broadcastAsync(IgniteClosure<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Broadcasts given closure job asynchronously with passed in argument to all nodes in the cluster group.
broken() - Method in class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
broken() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
bucketNumber() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
bucketSize() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
bufferSize() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
build() - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Builds binary object.
build() - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
build() - Method in class org.apache.ignite.services.ServiceCallContextBuilder
 
build() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates.Builder
Builder's build() method.
build() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters.Builder
Builder's build() method.
buildBinaryObject(String, JdbcTypeField[], Map<String, Integer>, ResultSet) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Construct binary object from query result.
buildEnum(String, int) - Method in interface org.apache.ignite.IgniteBinary
Create enum object using value.
buildEnum(String, String) - Method in interface org.apache.ignite.IgniteBinary
Create enum object using name.
builder(String) - Method in interface org.apache.ignite.IgniteBinary
Creates new binary builder.
builder(BinaryObject) - Method in interface org.apache.ignite.IgniteBinary
Creates binary builder initialized by existing binary object.
builder() - Static method in interface org.apache.ignite.services.ServiceCallContext
Create a context builder.
Builder(Scope) - Constructor for class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates.Builder
Constructor.
Builder() - Constructor for class org.apache.ignite.spi.tracing.TracingConfigurationParameters.Builder
 
buildObject(String, String, CacheAbstractJdbcStore.TypeKind, JdbcTypeField[], Map<String, Integer>, ResultSet) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Construct object from query result.
buildObject(String, String, CacheAbstractJdbcStore.TypeKind, JdbcTypeField[], Map<String, Integer>, ResultSet) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Construct object from query result.
BUILT_IN_TYPES - Static variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Built in Java types names.
BulkLoadContextCursor - Class in org.apache.ignite.cache.query
A special FieldsQueryCursor subclass that is used as a sentinel to transfer data from bulk load (COPY) command to the JDBC or other client-facing driver: the bulk load batch processor and parameters to send to the client.
BulkLoadContextCursor(BulkLoadProcessor, BulkLoadAckClientParameters) - Constructor for class org.apache.ignite.cache.query.BulkLoadContextCursor
Creates a cursor.
bulkLoadProcessor() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Returns a bulk load context.
busyTimePercentage() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 

C

cache() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
 
cache(String) - Method in interface org.apache.ignite.client.IgniteClient
Get existing cache.
cache(String) - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteCache API for the given name if one is configured or null otherwise.
cache(String) - Method in class org.apache.ignite.IgniteClientSpringBean
Get existing cache.
cache(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteCache API for the given name if one is configured or null otherwise.
CacheAbstractJdbcStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
Implementation of CacheStore backed by JDBC.
CacheAbstractJdbcStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
CacheAbstractJdbcStore.EntryMapping - Class in org.apache.ignite.cache.store.jdbc
Entry mapping description.
CacheAbstractJdbcStore.TypeKind - Enum in org.apache.ignite.cache.store.jdbc
Type kind.
cacheAffinity(String) - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
CacheAtomicityMode - Enum in org.apache.ignite.cache
Cache atomicity mode controls whether cache should maintain fully transactional semantics or more light-weight atomic behavior.
CacheCheckpointSpi - Class in org.apache.ignite.spi.checkpoint.cache
This class defines cache-based implementation for checkpoint SPI.
CacheCheckpointSpi() - Constructor for class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
 
CacheCheckpointSpiMBean - Interface in org.apache.ignite.spi.checkpoint.cache
Management bean that provides general administrative and configuration information about cache checkpoint SPI.
CacheConfiguration<K,V> - Class in org.apache.ignite.configuration
This class defines grid cache configuration.
CacheConfiguration() - Constructor for class org.apache.ignite.configuration.CacheConfiguration
Empty constructor (all values are initialized to their defaults).
CacheConfiguration(String) - Constructor for class org.apache.ignite.configuration.CacheConfiguration
 
CacheConfiguration(CompleteConfiguration<K, V>) - Constructor for class org.apache.ignite.configuration.CacheConfiguration
Copy constructor.
CacheConfiguration.IgniteAllNodesPredicate - Class in org.apache.ignite.configuration
Filter that accepts all nodes.
CacheConsistencyViolationEvent - Class in org.apache.ignite.events
This is an experimental API.
CacheConsistencyViolationEvent(String, ClusterNode, String, Map<Object, CacheConsistencyViolationEvent.EntriesInfo>, Map<Object, Object>, ReadRepairStrategy) - Constructor for class org.apache.ignite.events.CacheConsistencyViolationEvent
Creates a new instance of CacheConsistencyViolationEvent.
CacheConsistencyViolationEvent.EntriesInfo - Interface in org.apache.ignite.events
Inconsistent entries mapping.
CacheConsistencyViolationEvent.EntryInfo - Interface in org.apache.ignite.events
Inconsistent entry info.
cacheCount() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cachedPagesCount() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
CacheEntry<K,V> - Interface in org.apache.ignite.cache
Cache entry that extends Cache.Entry by providing additional entry related information.
CacheEntryEventAdapter<K,V> - Class in org.apache.ignite.cache.query
 
CacheEntryEventAdapter(Cache, EventType) - Constructor for class org.apache.ignite.cache.query.CacheEntryEventAdapter
 
CacheEntryEventSerializableFilter<K,V> - Interface in org.apache.ignite.cache
This filter adds Serializable interface to CacheEntryEventFilter object.
CacheEntryProcessor<K,V,T> - Interface in org.apache.ignite.cache
This processor adds Serializable interface to EntryProcessor object.
CacheEntryVersion - Interface in org.apache.ignite.cache
Entry event order.
CacheEvent - Class in org.apache.ignite.events
In-memory database (cache) event.
CacheEvent(String, ClusterNode, ClusterNode, String, int, int, boolean, Object, IgniteUuid, String, Object, Object, boolean, Object, boolean, UUID, String, String) - Constructor for class org.apache.ignite.events.CacheEvent
Constructs cache event.
CacheExistsException - Exception in org.apache.ignite.cache
Exception thrown when cache must be created but it already exists.
CacheExistsException(String) - Constructor for exception org.apache.ignite.cache.CacheExistsException
 
CacheExistsException(Throwable) - Constructor for exception org.apache.ignite.cache.CacheExistsException
 
CacheExistsException(String, Throwable) - Constructor for exception org.apache.ignite.cache.CacheExistsException
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupIoView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.CachePagesListView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.PartitionStateView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns cache group ID.
cacheGroupId() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns cache group ID.
CacheGroupIoView - Class in org.apache.ignite.spi.systemview.view
Cache group IO statistics representation for a SystemView.
CacheGroupIoView(CacheGroupContext, MetricRegistry) - Constructor for class org.apache.ignite.spi.systemview.view.CacheGroupIoView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupIoView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns Cache group name.
cacheGroupName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns Cache group name.
cacheGroupNames() - Method in class org.apache.ignite.dump.DumpReaderConfiguration
 
cacheGroups() - Method in class org.apache.ignite.spi.systemview.view.SnapshotView
 
CacheGroupView - Class in org.apache.ignite.spi.systemview.view
Cache group representation for the SystemView.
CacheGroupView(CacheGroupDescriptor) - Constructor for class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cacheId() - Method in interface org.apache.ignite.cdc.CdcCacheEvent
 
cacheId() - Method in interface org.apache.ignite.cdc.CdcEvent
 
cacheId() - Method in interface org.apache.ignite.dump.DumpEntry
 
cacheId() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheId() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns cache ID.
cacheId() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns cache ID.
cacheIds() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
CacheInterceptor<K,V> - Interface in org.apache.ignite.cache
Cache interceptor.
CacheInterceptorAdapter<K,V> - Class in org.apache.ignite.cache
Cache interceptor convenience adapter.
CacheInterceptorAdapter() - Constructor for class org.apache.ignite.cache.CacheInterceptorAdapter
 
CacheInterceptorEntry<K,V> - Class in org.apache.ignite.cache
A cache interceptor map entry.
CacheInterceptorEntry() - Constructor for class org.apache.ignite.cache.CacheInterceptorEntry
 
CacheJdbcBlobStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
CacheStore implementation backed by JDBC.
CacheJdbcBlobStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
 
CacheJdbcBlobStoreFactory<K,V> - Class in org.apache.ignite.cache.store.jdbc
Factory implementation for CacheJdbcBlobStore.
CacheJdbcBlobStoreFactory() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
 
CacheJdbcPojoStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
Implementation of CacheStore backed by JDBC and POJO via reflection.
CacheJdbcPojoStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
 
CacheJdbcPojoStoreFactory<K,V> - Class in org.apache.ignite.cache.store.jdbc
Factory implementation for CacheJdbcPojoStore.
CacheJdbcPojoStoreFactory() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
 
CacheJdbcStoreSessionListener - Class in org.apache.ignite.cache.store.jdbc
Cache store session listener based on JDBC connection.
CacheJdbcStoreSessionListener() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
 
CacheJndiTmFactory - Class in org.apache.ignite.cache.jta.jndi
Implementation of Factory<TransactionManager> interface that is using JNDI names to find TM.
CacheJndiTmFactory() - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Creates uninitialized jndi TM lookup.
CacheJndiTmFactory(String...) - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Creates generic TM lookup with given jndi names.
CacheJndiTmLookup - Class in org.apache.ignite.cache.jta.jndi
Implementation of CacheTmLookup interface that is using list of JNDI names to find TM.
CacheJndiTmLookup() - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
 
CacheKeyConfiguration - Class in org.apache.ignite.cache
Configuration defining various aspects of cache keys without explicit usage of annotations on user classes.
CacheKeyConfiguration() - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
Creates an empty cache key configuration that should be populated via setters.
CacheKeyConfiguration(Class) - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
 
CacheKeyConfiguration(String, String) - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
Creates cache key configuration with given type name and affinity field name.
cacheLoaderFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheLoadOnlyStoreAdapter<K,V,I> - Class in org.apache.ignite.cache.store
This adapter designed to support stores with bulk loading from stream-like source.
CacheLoadOnlyStoreAdapter() - Constructor for class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
 
CacheManager - Class in org.apache.ignite.cache
Implementation of JSR-107 CacheManager.
CacheManager(URI, CachingProvider, ClassLoader, Properties) - Constructor for class org.apache.ignite.cache.CacheManager
 
cacheMappings - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Cache with entry mapping description.
CacheMetrics - Interface in org.apache.ignite.cache
Cache metrics used to obtain statistics on cache itself.
cacheMetrics() - Method in interface org.apache.ignite.spi.discovery.DiscoveryMetricsProvider
Returns metrics data about all caches on local node.
cacheMetrics() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets collections of cache metrics for this node.
CacheMode - Enum in org.apache.ignite.cache
Enumeration of all supported caching modes.
cacheMode() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
cacheMode() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheName() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Cache name for the current store operation.
cacheName() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets cache name used for key-to-node affinity calculation.
cacheName() - Method in class org.apache.ignite.events.CacheEvent
Gets cache name.
cacheName() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets cache name on which query was executed.
cacheName() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets cache name on which query was executed.
cacheName() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets cache name.
cacheName() - Method in interface org.apache.ignite.IgniteDataStreamer
Name of cache to stream data to.
cacheName - Variable in class org.apache.ignite.services.ServiceConfiguration
Cache name.
cacheName() - Method in interface org.apache.ignite.services.ServiceContext
Gets cache name used for key-to-node affinity calculation.
cacheName() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets cache name used for key-to-node affinity calculation.
cacheName() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
cacheName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns cache name.
cacheName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns cache name.
CacheNameResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of grid cache name.
cacheNames() - Method in interface org.apache.ignite.client.IgniteClient
Gets the names of all available caches.
cacheNames() - Method in interface org.apache.ignite.Ignite
Gets the collection of names of currently available caches.
cacheNames() - Method in class org.apache.ignite.IgniteClientSpringBean
Gets the names of all available caches.
cacheNames() - Method in class org.apache.ignite.IgniteSpringBean
Gets the collection of names of currently available caches.
cacheNamesAsync() - Method in interface org.apache.ignite.client.IgniteClient
Gets the names of all available caches.
cacheNamesAsync() - Method in class org.apache.ignite.IgniteClientSpringBean
Gets the names of all available caches.
CacheObjectTransformedEvent - Class in org.apache.ignite.events
 
CacheObjectTransformedEvent(ClusterNode, String, int, byte[], byte[], boolean) - Constructor for class org.apache.ignite.events.CacheObjectTransformedEvent
 
CachePagesListView - Class in org.apache.ignite.spi.systemview.view
Pages-list representation for a SystemView.
CachePagesListView(PagesList, int, int) - Constructor for class org.apache.ignite.spi.systemview.view.CachePagesListView
 
CachePartialUpdateException - Exception in org.apache.ignite.cache
Exception thrown from non-transactional cache in case when update succeeded only partially.
CachePartialUpdateException(CachePartialUpdateCheckedException) - Constructor for exception org.apache.ignite.cache.CachePartialUpdateException
 
cachePartitionOwners(String) - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
CachePeekMode - Enum in org.apache.ignite.cache
Enumeration of all supported cache peek modes.
cachePermissions() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Map of cache names to cache permissions.
cachePermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Map of cache names to cache permissions.
CachePluginConfiguration<K,V> - Interface in org.apache.ignite.plugin
Cache plugin configuration.
CachePluginContext<C extends CachePluginConfiguration> - Interface in org.apache.ignite.plugin
Cache plugin context.
CachePluginProvider<C extends CachePluginConfiguration> - Interface in org.apache.ignite.plugin
Cache plugin provider is a point for processing of properties which provide specific CachePluginConfiguration.
cachePoolThread() - Method in class org.apache.ignite.thread.IgniteThread
 
CacheQueryEntryEvent<K,V> - Class in org.apache.ignite.cache.query
A Cache continuous query entry event.
CacheQueryEntryEvent(Cache, EventType) - Constructor for class org.apache.ignite.cache.query.CacheQueryEntryEvent
Constructs a cache entry event from a given cache as source.
CacheQueryExecutedEvent<K,V> - Class in org.apache.ignite.events
Cache query execution event.
CacheQueryExecutedEvent(ClusterNode, String, int, String, String, String, String, IgniteBiPredicate<K, V>, CacheEntryEventSerializableFilter<K, V>, Object[], UUID, String) - Constructor for class org.apache.ignite.events.CacheQueryExecutedEvent
 
CacheQueryReadEvent<K,V> - Class in org.apache.ignite.events
Cache query read event.
CacheQueryReadEvent(ClusterNode, String, int, String, String, String, String, IgniteBiPredicate<K, V>, CacheEntryEventSerializableFilter<K, V>, Object[], UUID, String, K, V, V, Object) - Constructor for class org.apache.ignite.events.CacheQueryReadEvent
 
CacheRebalanceMode - Enum in org.apache.ignite.cache
Cache rebalance mode.
CacheRebalancingEvent - Class in org.apache.ignite.events
In-memory database (cache) rebalancing event.
CacheRebalancingEvent(String, ClusterNode, String, int, int, ClusterNode, int, long) - Constructor for class org.apache.ignite.events.CacheRebalancingEvent
Constructs cache event.
CacheReflectionTmLookup - Class in org.apache.ignite.cache.jta.reflect
Implementation of CacheTmLookup interface that attempts to obtain JTA manager by calling static method on the class.
CacheReflectionTmLookup() - Constructor for class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Creates uninitialized reflection TM lookup.
CacheReflectionTmLookup(String, String) - Constructor for class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Creates generic TM lookup with given class and method name.
CacheServerNotFoundException - Exception in org.apache.ignite.cache
Exception thrown when all data nodes left the grid.
CacheServerNotFoundException(String) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
 
CacheServerNotFoundException(String, Throwable) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
 
CacheServerNotFoundException(Throwable) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
 
CacheStore<K,V> - Interface in org.apache.ignite.cache.store
API for cache persistent storage for read-through and write-through behavior.
CacheStoreAdapter<K,V> - Class in org.apache.ignite.cache.store
Cache storage convenience adapter.
CacheStoreAdapter() - Constructor for class org.apache.ignite.cache.store.CacheStoreAdapter
 
cacheStoreFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheStoreSession - Interface in org.apache.ignite.cache.store
Session for the cache store operations.
CacheStoreSessionListener - Interface in org.apache.ignite.cache.store
Cache store session listener that allows to implement callbacks for session lifecycle.
CacheStoreSessionResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of current CacheStoreSession instance.
CacheTmLookup - Interface in org.apache.ignite.cache.jta
Allows grid to use different transactional systems.
CacheTopologyValidatorProvider - Interface in org.apache.ignite.plugin
The CacheTopologyValidatorProvider is used to pass an implementation of TopologyValidators for a specific cache through Ignite plugin extensions mechanism.
cacheType() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheView - Class in org.apache.ignite.spi.systemview.view
Cache representation for a SystemView.
CacheView(DynamicCacheDescriptor, GridKernalContext) - Constructor for class org.apache.ignite.spi.systemview.view.CacheView
 
cacheWriterFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CacheWriteSynchronizationMode - Enum in org.apache.ignite.cache
Mode indicating how Ignite should wait for write replies from other nodes.
CachingProvider - Class in org.apache.ignite.cache
Implementation of JSR-107 CachingProvider.
CachingProvider() - Constructor for class org.apache.ignite.cache.CachingProvider
 
CalciteQueryEngineConfiguration - Class in org.apache.ignite.calcite
Query engine configuration for Calcite-based query engine.
CalciteQueryEngineConfiguration() - Constructor for class org.apache.ignite.calcite.CalciteQueryEngineConfiguration
 
calculateMask(int) - Static method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Helper method to calculates mask.
calculatePartition(Object, int, int) - Static method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Helper method to calculate partition.
call() - Method in class org.apache.ignite.compute.ComputeJobAdapter
call(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided job on a node within the underlying cluster group.
call(Collection<? extends IgniteCallable<R>>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs on nodes within the underlying cluster group.
call(Collection<? extends IgniteCallable<R1>>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs on nodes within the underlying cluster group.
callAsync(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
Executes provided job asynchronously on a node within the underlying cluster group.
callAsync(Collection<? extends IgniteCallable<R>>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs asynchronously on nodes within the underlying cluster group.
callAsync(Collection<? extends IgniteCallable<R1>>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs asynchronously on nodes within the underlying cluster group.
callcc() - Method in interface org.apache.ignite.compute.ComputeJobContinuation
Resumes job if it was held by ComputeJobContinuation.holdcc() method.
callcc() - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
Resumes job if it was held by ComputeJobContinuation.holdcc() method.
callLocal(Callable<R>) - Method in interface org.apache.ignite.IgniteScheduler
Executes given callable on internal system thread pool asynchronously.
cancel() - Method in interface org.apache.ignite.compute.ComputeJob
This method is called when system detects that completion of this job can no longer alter the overall outcome (for example, when parent task has already reduced the results).
cancel() - Method in class org.apache.ignite.compute.ComputeJobAdapter
This method is called when system detects that completion of this job can no longer alter the overall outcome (for example, when parent task has already reduced the results).
cancel() - Method in interface org.apache.ignite.compute.ComputeJobSibling
Sends a request to cancel this sibling.
cancel(String) - Method in interface org.apache.ignite.IgniteServices
Cancels service deployment.
cancel() - Method in interface org.apache.ignite.lang.IgniteFuture
Cancels this future.
cancel(String) - Method in interface org.apache.ignite.mxbean.ComputeMXBean
Deprecated.
Kills compute task by the session idenitifier.
cancel() - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Deprecated.
Cancel defragmentation.
cancel(String) - Method in interface org.apache.ignite.mxbean.ServiceMXBean
Deprecated.
 
cancel(String) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Deprecated.
Use managements API beans, instead.
cancel() - Method in interface org.apache.ignite.services.Service
Cancels this service.
cancel(ServiceContext) - Method in interface org.apache.ignite.services.Service
Deprecated.
Use Service.cancel() instead.
cancel() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Cancels the job.
cancelAll(Collection<String>) - Method in interface org.apache.ignite.IgniteServices
Cancels services with specified names.
cancelAll() - Method in interface org.apache.ignite.IgniteServices
Cancels all deployed services.
cancelAllAsync(Collection<String>) - Method in interface org.apache.ignite.IgniteServices
Asynchronously cancels services with specified names.
cancelAllAsync() - Method in interface org.apache.ignite.IgniteServices
Asynchronously cancels all deployed services.
cancelAsync(String) - Method in interface org.apache.ignite.IgniteServices
Asynchronously cancels service deployment.
cancelContinuous(String, String) - Method in interface org.apache.ignite.mxbean.QueryMXBean
Deprecated.
Kills continuous query by the identifier.
canceled() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
cancelScan(String, String, Long) - Method in interface org.apache.ignite.mxbean.QueryMXBean
Deprecated.
Kills scan query by the identifiers.
cancelSnapshot(String) - Method in interface org.apache.ignite.IgniteSnapshot
Cancel running snapshot operation.
cancelSnapshot(String) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
cancelSnapshotOperation(String) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
Deprecated.
Cancel previously started snapshot operation.
cancelSnapshotRestore(String) - Method in interface org.apache.ignite.IgniteSnapshot
Cancel snapshot restore operation.
cancelSnapshotRestore(String) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
cancelSQL(String) - Method in interface org.apache.ignite.mxbean.QueryMXBean
Deprecated.
Kills SQL query by the identifier.
capacity() - Method in interface org.apache.ignite.IgniteQueue
Gets maximum number of elements of the queue.
capacity() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
CdcCacheEvent - Interface in org.apache.ignite.cdc
Notification of CdcConsumer about cache creation/change events.
CdcCommandLineStartup - Class in org.apache.ignite.startup.cmdline
This class defines command-line Ignite Capture Data Change startup.
CdcCommandLineStartup() - Constructor for class org.apache.ignite.startup.cmdline.CdcCommandLineStartup
 
CdcConfiguration - Class in org.apache.ignite.cdc
This class defines CdcMain runtime configuration.
CdcConfiguration() - Constructor for class org.apache.ignite.cdc.CdcConfiguration
 
CdcConsumer - Interface in org.apache.ignite.cdc
Consumer of WAL data change events.
CdcEvent - Interface in org.apache.ignite.cdc
Event of single entry change.
CdcLoader - Class in org.apache.ignite.cdc
Utility class to load CdcMain from Spring XML configuration.
CdcLoader() - Constructor for class org.apache.ignite.cdc.CdcLoader
 
centerShow(String, String, String, LocalDate, String) - Static method in class org.apache.ignite.startup.cmdline.AboutDialog
Show about dialog.
certificates() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
 
certificates(Certificate[]) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Set client SSL certificates.
certificates() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Gets subject client certificates, or null if SSL were not used or client certificate checking not enabled.
CFG_URL_PREFIX - Static variable in class org.apache.ignite.IgniteJdbcDriver
Config URL prefix.
cfgNodeId - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
chain(IgniteClosure<? super IgniteFuture<V>, T>) - Method in interface org.apache.ignite.lang.IgniteFuture
Make a chained future to convert result of this future (when complete) into a new format.
chainAsync(IgniteClosure<? super IgniteFuture<V>, T>, Executor) - Method in interface org.apache.ignite.lang.IgniteFuture
Make a chained future to convert result of this future (when complete) into a new format.
changeCacheGroupKey(Collection<String>) - Method in interface org.apache.ignite.IgniteEncryption
Starts cache group encryption key change process.
changeCacheGroupKey(String) - Method in interface org.apache.ignite.mxbean.EncryptionMXBean
Deprecated.
Starts cache group encryption key change process.
changeMasterKey(String) - Method in interface org.apache.ignite.IgniteEncryption
Starts master key change process.
changeMasterKey(String) - Method in interface org.apache.ignite.mxbean.EncryptionMXBean
Deprecated.
Starts master key change process.
checkConfigurationConsistency0(IgniteSpiContext, ClusterNode, boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Method which is called in the end of checkConfigurationConsistency() method.
checkConfigurationConsistency0(IgniteSpiContext, ClusterNode, boolean) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Method which is called in the end of checkConfigurationConsistency() method.
checkConnection(List<ClusterNode>) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
checkFailedError(TcpDiscoveryCheckFailedMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
checkFailureTimeoutReached(Exception) - Method in class org.apache.ignite.spi.IgniteSpiOperationTimeoutHelper
Checks whether the given Exception is a timeout.
checkIgnite() - Method in class org.apache.ignite.IgniteSpringBean
Checks if this bean is valid.
checkNullParameter(Object, String) - Method in class org.apache.ignite.ssl.AbstractSslContextFactory
 
checkParameters() - Method in class org.apache.ignite.ssl.AbstractSslContextFactory
Checks that all required parameters are set.
checkParameters() - Method in class org.apache.ignite.ssl.SslContextFactory
Checks that all required parameters are set.
CHECKPOINT_PARALLEL_SORT_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Starting from this number of dirty pages in checkpoint, array will be sorted with Arrays.parallelSort(Comparable[]) in case of CheckpointWriteOrder.SEQUENTIAL.
CHECKPOINT_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
CheckpointEvent - Class in org.apache.ignite.events
Grid checkpoint event.
CheckpointEvent() - Constructor for class org.apache.ignite.events.CheckpointEvent
No-arg constructor.
CheckpointEvent(ClusterNode, String, int, String) - Constructor for class org.apache.ignite.events.CheckpointEvent
Creates new checkpoint event with given parameters.
CheckpointListener - Interface in org.apache.ignite.spi.checkpoint
Listener for notifications of checkpoints removed by CheckpointSpi.
CheckpointSpi - Interface in org.apache.ignite.spi.checkpoint
Checkpoint SPI provides an ability to save an intermediate job state.
CheckpointWriteOrder - Enum in org.apache.ignite.configuration
This enum defines order of writing pages to disk storage during checkpoint.
checkRingLatency(int) - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Diagnosis method for determining ring message latency.
checkTimeout(long) - Method in class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
Check if total timeout will be reached in now() + timeInFut.
checkTimeout(long) - Method in interface org.apache.ignite.spi.TimeoutStrategy
Check if total timeout will be reached in now() + timeInFut.
checkTimeout() - Method in interface org.apache.ignite.spi.TimeoutStrategy
Check if total timeout will be reached by now.
CIPHER_ALGO - Static variable in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Algorithm supported by implementation.
cipherSuites - Variable in class org.apache.ignite.ssl.AbstractSslContextFactory
Enabled cipher suites.
className() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets queried class name.
className() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets queried class name.
classNameFilter() - Method in interface org.apache.ignite.marshaller.MarshallerContext
Returns class name filter.
classNameFilter(ClassLoader) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Returns class name filter for marshaller.
clause() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets query clause.
clause() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets query clause.
cleanup() - Method in class org.apache.ignite.spi.IgniteSpiThread
Should be overridden by child classes if cleanup logic is required.
clear() - Method in interface org.apache.ignite.client.ClientCache
Clears the contents of the cache.
clear(K) - Method in interface org.apache.ignite.client.ClientCache
Clears entry with specified key from the cache.
clear() - Method in interface org.apache.ignite.client.ClientIgniteSet
clear() - Method in interface org.apache.ignite.IgniteCache
clear(K) - Method in interface org.apache.ignite.IgniteCache
Clears entry from the cache and swap storage, without notifying listeners or CacheWriters.
clear() - Method in interface org.apache.ignite.IgniteQueue
clear(int) - Method in interface org.apache.ignite.IgniteQueue
Removes all of the elements from this queue.
clear() - Method in interface org.apache.ignite.IgniteSet
clear() - Method in class org.apache.ignite.lang.IgniteBiTuple
clearAll(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Clears entries with specified keys from the cache.
clearAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Clears entries from the cache and swap storage, without notifying listeners or CacheWriters.
clearAll() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Removes all events from the event queue.
clearAll() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
Removes all events from the event queue.
clearAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Clears entries with specified keys from the cache asynchronously.
clearAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously clears entries from the cache and swap storage, without notifying listeners or CacheWriters.
clearAsync() - Method in interface org.apache.ignite.client.ClientCache
Clears the contents of the cache asynchronously.
clearAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Clears entry with specified key from the cache asynchronously.
clearAsync() - Method in interface org.apache.ignite.IgniteCache
Asynchronously clears the contents of the cache, without notifying listeners or CacheWriters.
clearAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously clears entry from the cache and swap storage, without notifying listeners or CacheWriters.
clearCache() - Static method in class org.apache.ignite.marshaller.MarshallerExclusions
Intended for test purposes only.
clearNodeLocalMap() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Clears node local map.
clearQueryEntities() - Method in class org.apache.ignite.configuration.CacheConfiguration
Clear query entities.
clearStatistics() - Method in interface org.apache.ignite.IgniteCache
Clear cluster statistics for this cache.
clearStatistics(Collection<String>) - Method in interface org.apache.ignite.IgniteCluster
Clear statistics for caches cluster wide.
CLIENT_THROTTLE_RECONNECT_RESET_TIMEOUT_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
Time interval that indicates that client reconnect throttle must be reset to zero. 2 minutes by default.
ClientAddressFinder - Interface in org.apache.ignite.client
This interface provides a list of addresses of Ignite server nodes within a cluster.
ClientAtomicConfiguration - Class in org.apache.ignite.client
Configuration for atomic data structures.
ClientAtomicConfiguration() - Constructor for class org.apache.ignite.client.ClientAtomicConfiguration
 
ClientAtomicLong - Interface in org.apache.ignite.client
Distributed atomic long API.
ClientAuthenticationException - Exception in org.apache.ignite.client
Indicates user name or password is invalid.
ClientAuthenticationException(String) - Constructor for exception org.apache.ignite.client.ClientAuthenticationException
Default constructor.
ClientAuthenticationException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientAuthenticationException
Constructs a new exception with the specified detail message and cause.
ClientAuthorizationException - Exception in org.apache.ignite.client
Indicates user has no permission to perform operation.
ClientAuthorizationException() - Constructor for exception org.apache.ignite.client.ClientAuthorizationException
Default constructor.
ClientAuthorizationException(Throwable) - Constructor for exception org.apache.ignite.client.ClientAuthorizationException
Constructs a new exception with the specified cause and a detail message of (cause==null ?
ClientAuthorizationException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientAuthorizationException
Constructs a new exception with the specified detail message and cause.
ClientAutoCloseableIterator<T> - Interface in org.apache.ignite.client
Auto closeable iterator.
ClientCache<K,V> - Interface in org.apache.ignite.client
Thin client cache.
ClientCacheConfiguration - Class in org.apache.ignite.client
Cache configuration.
ClientCacheConfiguration() - Constructor for class org.apache.ignite.client.ClientCacheConfiguration
Default constructor.
ClientCacheConfiguration(ClientCacheConfiguration) - Constructor for class org.apache.ignite.client.ClientCacheConfiguration
Creates client cache configuration by coping all configuration properties from the given one.
ClientCluster - Interface in org.apache.ignite.client
Thin client cluster facade.
ClientClusterGroup - Interface in org.apache.ignite.client
Thin client cluster group facade.
ClientCollectionConfiguration - Class in org.apache.ignite.client
Configuration for Ignite collections.
ClientCollectionConfiguration() - Constructor for class org.apache.ignite.client.ClientCollectionConfiguration
 
ClientCompute - Interface in org.apache.ignite.client
Thin client compute facade.
ClientConfiguration - Class in org.apache.ignite.configuration
TcpIgniteClient configuration.
ClientConfiguration() - Constructor for class org.apache.ignite.configuration.ClientConfiguration
 
ClientConnectionAttributeView - Class in org.apache.ignite.spi.systemview.view
Client connection attribute system view row.
ClientConnectionAttributeView(long, String, String) - Constructor for class org.apache.ignite.spi.systemview.view.ClientConnectionAttributeView
 
ClientConnectionException - Exception in org.apache.ignite.client
Indicates all the Ignite servers specified in the client configuration are no longer available.
ClientConnectionException(String) - Constructor for exception org.apache.ignite.client.ClientConnectionException
Constructs a new exception with the specified detail message.
ClientConnectionException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientConnectionException
Constructs a new exception with the specified cause and detail message.
ClientConnectionView - Class in org.apache.ignite.spi.systemview.view
Client connection system view row.
ClientConnectionView(GridNioSession) - Constructor for class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
ClientConnectorConfiguration - Class in org.apache.ignite.configuration
Client connector configuration.
ClientConnectorConfiguration() - Constructor for class org.apache.ignite.configuration.ClientConnectorConfiguration
Creates SQL connector configuration with all default values.
ClientConnectorConfiguration(ClientConnectorConfiguration) - Constructor for class org.apache.ignite.configuration.ClientConnectorConfiguration
Creates SQL connector configuration by copying all properties from given configuration.
ClientDisconnectListener - Interface in org.apache.ignite.client
Client disconnected event listener.
ClientException - Exception in org.apache.ignite.client
Common thin client unchecked exception.
ClientException() - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with null as its detail message.
ClientException(String) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified detail message.
ClientException(Throwable) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified cause and a detail message of (cause==null ?
ClientException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified detail message and cause.
ClientException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.ignite.client.ClientException
Constructs a new exception with the specified detail message, cause, suppression enabled or disabled, and writable stack trace enabled or disabled.
ClientExceptionsUtils - Class in org.apache.ignite.spi.communication.tcp
Utils to analyze client-related exceptions.
ClientExceptionsUtils() - Constructor for class org.apache.ignite.spi.communication.tcp.ClientExceptionsUtils
 
clientFailureDetectionTimeout() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Returns client failure detection timeout set to use for network related operations.
ClientFeatureNotSupportedByServerException - Exception in org.apache.ignite.client
Feature not supported by server exception.
ClientFeatureNotSupportedByServerException(String) - Constructor for exception org.apache.ignite.client.ClientFeatureNotSupportedByServerException
Constructs a new exception with the specified detail message.
ClientFeatureNotSupportedByServerException(ProtocolBitmaskFeature) - Constructor for exception org.apache.ignite.client.ClientFeatureNotSupportedByServerException
 
ClientFeatureNotSupportedByServerException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientFeatureNotSupportedByServerException
Constructs a new exception with the specified cause and detail message.
ClientIgniteSet<T> - Interface in org.apache.ignite.client
Distributed Set.
ClientOperationType - Enum in org.apache.ignite.client
Client operation type.
clientParams() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Returns the bulk load parameters to send to the client.
ClientPartitionAwarenessMapper - Interface in org.apache.ignite.client
This function calculates the cache key to a partition mapping for each cache key.
ClientPartitionAwarenessMapperFactory - Interface in org.apache.ignite.client
This factory is used on the client side and only when the partition awareness thin client feature is enabled.
ClientProcessorMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use managements API beans, instead.
clientReconnect() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
clientReconnect() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
clientReconnect() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
ClientReconnectedException - Exception in org.apache.ignite.client
Indicates that previous connection was lost and a new connection established, which can lead to inconsistency of non-atomic operations.
ClientReconnectedException() - Constructor for exception org.apache.ignite.client.ClientReconnectedException
Default constructor.
ClientReconnectedException(String) - Constructor for exception org.apache.ignite.client.ClientReconnectedException
Constructs a new exception with the specified message.
ClientReconnectedException(String, Throwable) - Constructor for exception org.apache.ignite.client.ClientReconnectedException
Constructs a new exception with the specified cause and detail message.
clientReconnectFuture() - Method in interface org.apache.ignite.IgniteCluster
If local client node disconnected from cluster returns future that will be completed when client reconnected.
clientReconnectSupported() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
clientReconnectSupported() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
clientReconnectSupported() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
ClientRetryAllPolicy - Class in org.apache.ignite.client
Retry policy that always returns true.
ClientRetryAllPolicy() - Constructor for class org.apache.ignite.client.ClientRetryAllPolicy
 
ClientRetryNonePolicy - Class in org.apache.ignite.client
Retry policy that always returns false.
ClientRetryNonePolicy() - Constructor for class org.apache.ignite.client.ClientRetryNonePolicy
 
ClientRetryPolicy - Interface in org.apache.ignite.client
Client retry policy determines whether client operations that have failed due to a connection issue should be retried.
ClientRetryPolicyContext - Interface in org.apache.ignite.client
Retry policy context.
ClientRetryReadPolicy - Class in org.apache.ignite.client
Retry policy that returns true for all read-only operations that do not modify data.
ClientRetryReadPolicy() - Constructor for class org.apache.ignite.client.ClientRetryReadPolicy
 
ClientServiceDescriptor - Interface in org.apache.ignite.client
Descriptor of Service.
ClientServices - Interface in org.apache.ignite.client
Thin client services facade.
ClientTransaction - Interface in org.apache.ignite.client
Thin client transaction.
ClientTransactionConfiguration - Class in org.apache.ignite.configuration
Thin client transactions configuration.
ClientTransactionConfiguration() - Constructor for class org.apache.ignite.configuration.ClientTransactionConfiguration
Empty constructor.
ClientTransactionConfiguration(ClientTransactionConfiguration) - Constructor for class org.apache.ignite.configuration.ClientTransactionConfiguration
 
ClientTransactions - Interface in org.apache.ignite.client
Thin client transactions facade.
clientWorkerCount() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
clone() - Method in interface org.apache.ignite.binary.BinaryObject
Copies this binary object.
clone() - Method in class org.apache.ignite.lang.IgniteBiTuple
clone() - Method in class org.apache.ignite.lang.IgniteUuid
close() - Method in class org.apache.ignite.cache.CacheManager
close() - Method in class org.apache.ignite.cache.CachingProvider
close(ClassLoader) - Method in class org.apache.ignite.cache.CachingProvider
close(URI, ClassLoader) - Method in class org.apache.ignite.cache.CachingProvider
close() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Closes all resources related to this cursor.
close() - Method in interface org.apache.ignite.cache.query.QueryCursor
Closes all resources related to this cursor.
close() - Method in interface org.apache.ignite.client.ClientAtomicLong
Removes this atomic long.
close() - Method in interface org.apache.ignite.client.ClientIgniteSet
Removes this set.
close() - Method in interface org.apache.ignite.client.ClientTransaction
Ends the transaction.
close() - Method in interface org.apache.ignite.client.IgniteClient
Closes this client's open connections and relinquishes all underlying resources.
close() - Method in interface org.apache.ignite.Ignite
Closes this instance of grid.
close() - Method in interface org.apache.ignite.IgniteAtomicLong
Removes this atomic long.
close() - Method in interface org.apache.ignite.IgniteAtomicReference
Removes this atomic reference.
close() - Method in interface org.apache.ignite.IgniteAtomicSequence
Removes this atomic sequence.
close() - Method in interface org.apache.ignite.IgniteAtomicStamped
Removes this atomic stamped.
close() - Method in interface org.apache.ignite.IgniteCache
Closes this cache instance.
close() - Method in class org.apache.ignite.IgniteClientSpringBean
Closes this client's open connections and relinquishes all underlying resources.
close() - Method in interface org.apache.ignite.IgniteCountDownLatch
Removes this count down latch.
close(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
Streams any remaining data and closes this streamer.
close() - Method in interface org.apache.ignite.IgniteDataStreamer
Closes data streamer.
close() - Method in interface org.apache.ignite.IgniteLock
Removes reentrant lock.
close() - Method in interface org.apache.ignite.IgniteQueue
Removes this queue.
close() - Method in interface org.apache.ignite.IgniteSemaphore
Removes this semaphore.
close() - Method in interface org.apache.ignite.IgniteSet
Removes this set.
close() - Method in class org.apache.ignite.IgniteSpringBean
Closes this instance of grid.
close() - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
close() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Closes this IP finder and releases any system resources associated with it.
close() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Closes this IP finder and releases any system resources associated with it.
close() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Closes this IP finder and releases any system resources associated with it.
close() - Method in interface org.apache.ignite.spi.IgniteSpiCloseableIterator
Closes the iterator and frees all the resources held by the iterator.
close() - Method in interface org.apache.ignite.transactions.Transaction
Ends the transaction.
closeConnection(Connection) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Closes connection.
closureClassName() - Method in class org.apache.ignite.events.CacheEvent
Gets closure class name (applicable only for TRANSFORM operations).
CLS_NAMES_FILE - Static variable in class org.apache.ignite.marshaller.MarshallerUtils
Class names file.
cluster() - Method in interface org.apache.ignite.client.IgniteClient
Gets client cluster facade.
cluster() - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteCluster interface.
cluster() - Method in class org.apache.ignite.IgniteClientSpringBean
Gets client cluster facade.
cluster() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteCluster interface.
CLUSTER_STATE_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
ClusterActivationEvent - Class in org.apache.ignite.events
Deprecated.
ClusterActivationEvent(ClusterNode, String, int, Collection<BaselineNode>) - Constructor for class org.apache.ignite.events.ClusterActivationEvent
Deprecated.
Creates activation event with given parameters.
clusterGroup() - Method in interface org.apache.ignite.client.ClientCompute
Gets cluster group to which this ClientCompute instance belongs.
clusterGroup() - Method in interface org.apache.ignite.client.ClientServices
Gets the cluster group to which this ClientServices instance belongs.
ClusterGroup - Interface in org.apache.ignite.cluster
Defines a cluster group which contains all or a subset of cluster nodes.
clusterGroup() - Method in interface org.apache.ignite.IgniteCompute
Gets cluster group to which this IgniteCompute instance belongs.
clusterGroup() - Method in interface org.apache.ignite.IgniteEvents
Gets cluster group to which this IgniteEvents instance belongs.
clusterGroup() - Method in interface org.apache.ignite.IgniteMessaging
Gets the cluster group to which this GridMessaging instance belongs.
clusterGroup() - Method in interface org.apache.ignite.IgniteServices
Gets the cluster group to which this IgniteServices instance belongs.
ClusterGroupEmptyException - Exception in org.apache.ignite.cluster
This exception defines illegal call on empty cluster group.
ClusterGroupEmptyException() - Constructor for exception org.apache.ignite.cluster.ClusterGroupEmptyException
Creates new exception with default error message.
ClusterGroupEmptyException(String) - Constructor for exception org.apache.ignite.cluster.ClusterGroupEmptyException
Creates new exception with given error message.
ClusterGroupEmptyException(String, Throwable) - Constructor for exception org.apache.ignite.cluster.ClusterGroupEmptyException
Creates a new exception with given error message and optional nested cause exception.
clusterId() - Method in interface org.apache.ignite.cache.CacheEntryVersion
Cluster id is a value to distinguish updates in case user wants to aggregate and sort updates from several Ignite clusters.
clusterId() - Method in class org.apache.ignite.events.ClusterTagUpdatedEvent
Cluster ID which tag was updated.
ClusterMetrics - Interface in org.apache.ignite.cluster
This class represents runtime information on a cluster.
ClusterMetricsMXBean - Interface in org.apache.ignite.mxbean
Cluster metrics MBean.
ClusterNode - Interface in org.apache.ignite.cluster
Interface representing a single cluster node.
ClusterNodeAttributeAffinityBackupFilter - Class in org.apache.ignite.cache.affinity.rendezvous
Attribute-based affinity backup filter that forces each partition's primary and backup nodes to different hardware which is not expected to fail simultaneously, e.g., in AWS, to different "availability zones".
ClusterNodeAttributeAffinityBackupFilter(String...) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeAffinityBackupFilter
 
ClusterNodeAttributeColocatedBackupFilter - Class in org.apache.ignite.cache.affinity.rendezvous
This class can be used as a RendezvousAffinityFunction.affinityBackupFilter to create cache templates in Spring that force each partition's primary and backup to be co-located on nodes with the same attribute value.
ClusterNodeAttributeColocatedBackupFilter(String) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeColocatedBackupFilter
 
ClusterNodeView - Class in org.apache.ignite.spi.systemview.view
Cluster node representation for a SystemView.
ClusterNodeView(ClusterNode) - Constructor for class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
ClusterStartNodeResult - Interface in org.apache.ignite.cluster
Cluster start node result information.
ClusterState - Enum in org.apache.ignite.cluster
Cluster states.
clusterState() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.clusterState" instead.
clusterState(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
clusterState(String, boolean) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Changes current cluster state.
ClusterStateChangeEvent - Class in org.apache.ignite.events
Cluster state change event.
ClusterStateChangeEvent(ClusterState, ClusterState, Collection<? extends BaselineNode>, ClusterNode, String) - Constructor for class org.apache.ignite.events.ClusterStateChangeEvent
 
ClusterStateChangeStartedEvent - Class in org.apache.ignite.events
Cluster state change started event.
ClusterStateChangeStartedEvent(ClusterState, ClusterState, ClusterNode, String, UUID) - Constructor for class org.apache.ignite.events.ClusterStateChangeStartedEvent
 
ClusterTagUpdatedEvent - Class in org.apache.ignite.events
Event type indicating that cluster tag has been updated.
ClusterTagUpdatedEvent(ClusterNode, String, UUID, String, String) - Constructor for class org.apache.ignite.events.ClusterTagUpdatedEvent
 
ClusterTopologyException - Exception in org.apache.ignite.cluster
This exception is used to indicate error with the cluster topology (e.g., crashed node, etc.).
ClusterTopologyException(String) - Constructor for exception org.apache.ignite.cluster.ClusterTopologyException
Creates new topology exception with given error message.
ClusterTopologyException(String, Throwable) - Constructor for exception org.apache.ignite.cluster.ClusterTopologyException
Creates new topology exception with given error message and optional nested exception.
code() - Method in enum org.apache.ignite.cache.CacheMode
 
collect(E) - Method in interface org.apache.ignite.lang.IgniteReducer
Collects given value.
collect(DiscoveryDataBag) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiDataExchange
Collects data from all components.
CollectionConfiguration - Class in org.apache.ignite.configuration
Configuration for Ignite collections.
CollectionConfiguration() - Constructor for class org.apache.ignite.configuration.CollectionConfiguration
 
collectionOf(Collection<DataRegionMetrics>) - Static method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Converts collection of DataRegionMetrics into collection of legacy MemoryMetrics.
collectMessagesCountByNodeId(String) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Collect messages count by nodeId
collectMessagesCountByType(String) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Collect messages count by type
COLLISION_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
CollisionContext - Interface in org.apache.ignite.spi.collision
Context for resolving collisions.
CollisionExternalListener - Interface in org.apache.ignite.spi.collision
Listener to be set on CollisionSpi for notification of external collision events (e.g. job stealing).
CollisionJobContext - Interface in org.apache.ignite.spi.collision
This interface defines set of operations that collision SPI implementation can perform on jobs that are either waiting or executing.
CollisionSpi - Interface in org.apache.ignite.spi.collision
Collision SPI allows to regulate how grid jobs get executed when they arrive on a destination node for execution.
collocated() - Method in interface org.apache.ignite.IgniteQueue
Returns true if this queue can be kept on the one node only.
collocated() - Method in interface org.apache.ignite.IgniteSet
Returns true if this set can be kept on the one node only.
collocated() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
collocated() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
colocated() - Method in interface org.apache.ignite.client.ClientIgniteSet
Gets a value indicating whether all items of this set are stored on a single node.
colocated() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
columnIndex(Map<String, Integer>, String) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Find column index by database name.
columnName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
columnName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewColumnView
 
columns() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns all columns on which index is built.
CommandLineRandomNumberGenerator - Class in org.apache.ignite.startup.cmdline
Generates a random number and prints it to the console.
CommandLineRandomNumberGenerator() - Constructor for class org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator
 
CommandLineStartup - Class in org.apache.ignite.startup.cmdline
This class defines command-line Ignite startup.
CommandLineTransformer - Class in org.apache.ignite.startup.cmdline
This class is a workaround for a versatile problems with passing arguments to the Ignite Windows batch launcher scripts.
commit() - Method in interface org.apache.ignite.client.ClientTransaction
Commits this transaction.
commit() - Method in interface org.apache.ignite.transactions.Transaction
Commits this transaction by initiating two-phase-commit process.
commitAsync() - Method in interface org.apache.ignite.transactions.Transaction
Asynchronously commits this transaction by initiating two-phase-commit process.
commitTime() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The last time, when transaction was commited.
commitTime() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets last time transaction was committed.
commonData(Map<Integer, Serializable>) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
commonData() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
commonData() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.GridDiscoveryData
 
commonDataCollectedFor(Integer) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
COMMUNICATION_METRICS_GROUP_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Communication metrics group name.
COMMUNICATION_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
CommunicationFailureContext - Interface in org.apache.ignite.configuration
Communication Failure Context.
CommunicationFailureResolver - Interface in org.apache.ignite.configuration
Communication Failure Resolver.
communicationFailureResolveSupported() - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
CommunicationListener<T extends Serializable> - Interface in org.apache.ignite.spi.communication
Listener SPI notifies IO manager with.
CommunicationSpi<T extends Serializable> - Interface in org.apache.ignite.spi.communication
Communication SPI is responsible for data exchange between nodes.
compareAndSet(long, long) - Method in interface org.apache.ignite.client.ClientAtomicLong
Atomically compares current value to the expected value, and if they are equal, sets current value to new value.
compareAndSet(long, long) - Method in interface org.apache.ignite.IgniteAtomicLong
Atomically compares current value to the expected value, and if they are equal, sets current value to new value.
compareAndSet(T, T) - Method in interface org.apache.ignite.IgniteAtomicReference
Conditionally sets the new value.
compareAndSet(T, T, S, S) - Method in interface org.apache.ignite.IgniteAtomicStamped
Conditionally sets the new value and new stamp.
compareTo(Event) - Method in class org.apache.ignite.events.EventAdapter
compareTo(IgniteProductVersion) - Method in class org.apache.ignite.lang.IgniteProductVersion
compareTo(IgniteUuid) - Method in class org.apache.ignite.lang.IgniteUuid
compareToIgnoreTimestamp(IgniteProductVersion) - Method in class org.apache.ignite.lang.IgniteProductVersion
 
completions() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets number of completed execution of query.
compositeRwLockIndex() - Method in class org.apache.ignite.thread.IgniteThread
 
compositeRwLockIndex(int) - Method in class org.apache.ignite.thread.IgniteThread
 
compute() - Method in interface org.apache.ignite.client.IgniteClient
Gets compute facade over all cluster nodes started in server mode.
compute(ClientClusterGroup) - Method in interface org.apache.ignite.client.IgniteClient
Gets compute facade over the specified cluster group.
compute() - Method in interface org.apache.ignite.Ignite
Gets compute facade over all cluster nodes started in server mode.
compute(ClusterGroup) - Method in interface org.apache.ignite.Ignite
Gets compute facade over the specified cluster group.
compute() - Method in class org.apache.ignite.IgniteClientSpringBean
Gets compute facade over all cluster nodes started in server mode.
compute(ClientClusterGroup) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets compute facade over the specified cluster group.
compute() - Method in class org.apache.ignite.IgniteSpringBean
Gets compute facade over all cluster nodes started in server mode.
compute(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Gets compute facade over the specified cluster group.
ComputeExecutionRejectedException - Exception in org.apache.ignite.compute
This exception defines execution rejection.
ComputeExecutionRejectedException(String) - Constructor for exception org.apache.ignite.compute.ComputeExecutionRejectedException
Creates new execution rejection exception with given error message.
ComputeExecutionRejectedException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeExecutionRejectedException
Creates new execution rejection given throwable as a cause and source of error message.
ComputeExecutionRejectedException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeExecutionRejectedException
Creates new execution rejection exception with given error message and optional nested exception.
ComputeJob - Interface in org.apache.ignite.compute
Defines executable unit for ComputeTask.
ComputeJobAdapter - Class in org.apache.ignite.compute
Convenience adapter for ComputeJob implementations.
ComputeJobAdapter() - Constructor for class org.apache.ignite.compute.ComputeJobAdapter
No-arg constructor.
ComputeJobAdapter(Object) - Constructor for class org.apache.ignite.compute.ComputeJobAdapter
Creates job with one arguments.
ComputeJobAdapter(Object...) - Constructor for class org.apache.ignite.compute.ComputeJobAdapter
Creates job with specified arguments.
ComputeJobAfterSend - Annotation Type in org.apache.ignite.compute
This annotation allows to call a method right after the job has been successfully sent for execution.
ComputeJobBeforeFailover - Annotation Type in org.apache.ignite.compute
This annotation allows to call a method right before job is submitted to FailoverSpi.
ComputeJobContext - Interface in org.apache.ignite.compute
Context attached to every job executed on the grid.
ComputeJobContinuation - Interface in org.apache.ignite.compute
Defines continuation support for grid job context.
ComputeJobContinuationAdapter - Class in org.apache.ignite.compute
Convenience adapter for ComputeJob implementations.
ComputeJobContinuationAdapter() - Constructor for class org.apache.ignite.compute.ComputeJobContinuationAdapter
No-arg constructor.
ComputeJobContinuationAdapter(Object) - Constructor for class org.apache.ignite.compute.ComputeJobContinuationAdapter
Creates job with one arguments.
ComputeJobContinuationAdapter(Object...) - Constructor for class org.apache.ignite.compute.ComputeJobContinuationAdapter
Creates job with specified arguments.
ComputeJobFailoverException - Exception in org.apache.ignite.compute
This runtime exception can be thrown from ComputeJob.execute() method to force job failover to another node within task topology.
ComputeJobFailoverException(String) - Constructor for exception org.apache.ignite.compute.ComputeJobFailoverException
Creates new exception with given error message.
ComputeJobFailoverException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeJobFailoverException
Creates new given throwable as a cause and source of error message.
ComputeJobFailoverException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeJobFailoverException
Creates new exception with given error message and optional nested exception.
ComputeJobMasterLeaveAware - Interface in org.apache.ignite.compute
Annotation for handling master node leave during job execution.
ComputeJobResult - Interface in org.apache.ignite.compute
Result of remote job which gets passed into ComputeTask.result(ComputeJobResult, List) method.
ComputeJobResultPolicy - Enum in org.apache.ignite.compute
This enumeration provides different types of actions following the last received job result.
ComputeJobSibling - Interface in org.apache.ignite.compute
Job sibling interface defines a job from the same split.
ComputeJobView - Class in org.apache.ignite.spi.systemview.view
Compute job representation for a SystemView.
ComputeJobView(IgniteUuid, GridJobWorker, ComputeJobView.ComputeJobState) - Constructor for class org.apache.ignite.spi.systemview.view.ComputeJobView
 
ComputeJobView.ComputeJobState - Enum in org.apache.ignite.spi.systemview.view
Compute job state.
ComputeLoadBalancer - Interface in org.apache.ignite.compute
Load balancer is used for finding the best balanced node according to load balancing policy.
ComputeMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use managements API beans, instead.
ComputeTask<T,R> - Interface in org.apache.ignite.compute
Grid task interface defines a task that can be executed on the grid.
ComputeTaskAdapter<T,R> - Class in org.apache.ignite.compute
Convenience adapter for ComputeTask interface.
ComputeTaskAdapter() - Constructor for class org.apache.ignite.compute.ComputeTaskAdapter
 
ComputeTaskCancelledException - Exception in org.apache.ignite.compute
This exception indicates that grid task was cancelled.
ComputeTaskCancelledException(String) - Constructor for exception org.apache.ignite.compute.ComputeTaskCancelledException
Creates new task cancellation exception with given error message.
ComputeTaskCancelledException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskCancelledException
Creates new task cancellation exception given throwable as a cause and source of error message.
ComputeTaskCancelledException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskCancelledException
Creates new task cancellation exception with given error message and optional nested exception.
ComputeTaskContinuousMapper - Interface in org.apache.ignite.compute
Defines a mapper that can be used for asynchronous job sending.
ComputeTaskFuture<R> - Interface in org.apache.ignite.compute
This class defines a handler for asynchronous task execution.
ComputeTaskMapAsync - Annotation Type in org.apache.ignite.compute
Annotation for asynchronous task mapping.
ComputeTaskName - Annotation Type in org.apache.ignite.compute
This annotation allows to assign optional name to grid task.
ComputeTaskNoResultCache - Annotation Type in org.apache.ignite.compute
This annotation disables caching of task results when attached to ComputeTask class being executed.
ComputeTaskSession - Interface in org.apache.ignite.compute
Defines a distributed session for particular task execution.
ComputeTaskSessionAttributeListener - Interface in org.apache.ignite.compute
This interface defines listener for task session attributes.
ComputeTaskSessionFullSupport - Annotation Type in org.apache.ignite.compute
Annotation for enabling task session attributes and checkpoints for tasks.
ComputeTaskSessionScope - Enum in org.apache.ignite.compute
Defines life-time scopes for checkpoint operations.
ComputeTaskSpis - Annotation Type in org.apache.ignite.compute
This annotation allows task to specify what SPIs it wants to use.
ComputeTaskSplitAdapter<T,R> - Class in org.apache.ignite.compute
This class defines simplified adapter for ComputeTask.
ComputeTaskSplitAdapter() - Constructor for class org.apache.ignite.compute.ComputeTaskSplitAdapter
 
ComputeTaskTimeoutException - Exception in org.apache.ignite.compute
This exception indicates that task execution timed out.
ComputeTaskTimeoutException(String) - Constructor for exception org.apache.ignite.compute.ComputeTaskTimeoutException
Creates task timeout exception with given task execution ID and error message.
ComputeTaskTimeoutException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskTimeoutException
Creates new task timeout exception given throwable as a cause and source of error message.
ComputeTaskTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskTimeoutException
Creates task timeout exception with given task execution ID, error message and optional nested exception.
ComputeTaskView - Class in org.apache.ignite.spi.systemview.view
Compute task representation for a SystemView.
ComputeTaskView(IgniteUuid, GridTaskWorker) - Constructor for class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
ComputeUserUndeclaredException - Exception in org.apache.ignite.compute
This exception is thrown when user's code throws undeclared runtime exception.
ComputeUserUndeclaredException(String) - Constructor for exception org.apache.ignite.compute.ComputeUserUndeclaredException
Creates user undeclared exception with given task execution ID and error message.
ComputeUserUndeclaredException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeUserUndeclaredException
Creates new user undeclared exception given throwable as a cause and source of error message.
ComputeUserUndeclaredException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeUserUndeclaredException
Creates user undeclared exception with given task execution ID, error message and optional nested exception.
concurrency() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
concurrency() - Method in interface org.apache.ignite.transactions.Transaction
Cache transaction concurrency mode.
configInfo(String, Object) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets uniformed string for configuration parameter.
configuration() - Method in interface org.apache.ignite.cdc.CdcCacheEvent
Note, CacheConfiguration.getQueryEntities() value not changed on table schema change.
configuration() - Method in interface org.apache.ignite.client.ClientRetryPolicyContext
Gets the client configuration.
configuration() - Method in interface org.apache.ignite.Ignite
Gets the configuration of this Ignite instance.
configuration() - Method in class org.apache.ignite.IgniteSpringBean
Gets the configuration of this Ignite instance.
ConfigurationView - Class in org.apache.ignite.spi.systemview.view
Configuration value representation for a SystemView.
ConfigurationView(String, String) - Constructor for class org.apache.ignite.spi.systemview.view.ConfigurationView
 
configureConsoleAppender(boolean) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates console appender with some reasonable default logging settings.
configureHistogramMetric(String, long[]) - Method in interface org.apache.ignite.mxbean.MetricsMxBean
Deprecated.
Change HistogramMetric configuration.
configureHitRateMetric(String, long) - Method in interface org.apache.ignite.mxbean.MetricsMxBean
Deprecated.
Change HitRateMetric configuration.
conflict(String) - Static method in class org.apache.ignite.cache.QueryEntityPatch
Builder method for patch with conflicts.
conflictResolver() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
CONN_IDX_META - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Connection index meta for session.
connect(String, Properties) - Method in class org.apache.ignite.IgniteJdbcDriver
connect(String, Properties) - Method in class org.apache.ignite.IgniteJdbcThinDriver
connectCount() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
connection() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
connectionAvailable(ClusterNode, ClusterNode) - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
ConnectionClosedEvent - Class in org.apache.ignite.client.events
 
ConnectionClosedEvent(ConnectionDescription, Throwable) - Constructor for class org.apache.ignite.client.events.ConnectionClosedEvent
 
ConnectionDescription - Class in org.apache.ignite.client.events
 
ConnectionDescription(InetSocketAddress, InetSocketAddress, String, UUID) - Constructor for class org.apache.ignite.client.events.ConnectionDescription
 
connectionDescription() - Method in class org.apache.ignite.client.events.ConnectionEvent
 
connectionDescription() - Method in class org.apache.ignite.client.events.RequestEvent
 
ConnectionEvent - Class in org.apache.ignite.client.events
 
ConnectionEvent(ConnectionDescription) - Constructor for class org.apache.ignite.client.events.ConnectionEvent
 
ConnectionEventListener - Interface in org.apache.ignite.client.events
 
connectionId() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionAttributeView
 
connectionId() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
connectionIndex() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
connectionIndex() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
ConnectorConfiguration - Class in org.apache.ignite.configuration
REST access configuration.
ConnectorConfiguration() - Constructor for class org.apache.ignite.configuration.ConnectorConfiguration
Creates client connection configuration with all default values.
ConnectorConfiguration(ConnectorConfiguration) - Constructor for class org.apache.ignite.configuration.ConnectorConfiguration
Creates client connection configuration by copying all properties from given configuration.
ConnectorMessageInterceptor - Interface in org.apache.ignite.configuration
Interface for user-defined object interceptors.
connRecoveryTimeout - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default connection recovery timeout in ms.
CONSISTENT_ID_META - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node consistent id meta for session.
CONSISTENT_ID_TAG - Static variable in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Ignite node consistent id.
consistentId() - Method in interface org.apache.ignite.cluster.BaselineNode
Gets consistent globally unique node ID.
consistentId() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets consistent globally unique node ID.
consistentId() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets consistent globally unique node ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Gets consistent ID.
consistentId() - Method in class org.apache.ignite.spi.systemview.view.BaselineNodeView
 
consistentId() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
consistentId() - Method in class org.apache.ignite.spi.systemview.view.SnapshotView
 
consumer() - Method in class org.apache.ignite.dump.DumpReaderConfiguration
 
contains(Object) - Method in interface org.apache.ignite.client.ClientIgniteSet
contains(Object) - Method in interface org.apache.ignite.IgniteQueue
contains(Object) - Method in interface org.apache.ignite.IgniteSet
containsAll(Collection<?>) - Method in interface org.apache.ignite.client.ClientIgniteSet
containsAll(Collection<?>) - Method in interface org.apache.ignite.IgniteQueue
containsAll(Collection<?>) - Method in interface org.apache.ignite.IgniteSet
containsKey(K) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains an entry for the specified key.
containsKey(K) - Method in interface org.apache.ignite.IgniteCache
containsKey(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
containsKey(String, K) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Returns true if this cache contains a mapping for the specified key.
containsKeyAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains an entry for the specified key asynchronously.
containsKeyAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously determines if the Cache contains an entry for the specified key.
containsKeys(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains entries for the specified keys.
containsKeys(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Determines if the Cache contains entries for the specified keys.
containsKeysAsync(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Determines if the ClientCache contains entries for the specified keys asynchronously.
containsKeysAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously determines if the Cache contains entries for the specified keys.
containsValue(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
contextDestroyed(ServletContextEvent) - Method in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
contextInitialized(ServletContextEvent) - Method in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
ContinuousQuery<K,V> - Class in org.apache.ignite.cache.query
API for configuring continuous cache queries.
ContinuousQuery() - Constructor for class org.apache.ignite.cache.query.ContinuousQuery
Creates new continuous query.
continuousQueryFilter() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets continuous query filter.
continuousQueryFilter() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets continuous query filter.
ContinuousQueryView - Class in org.apache.ignite.spi.systemview.view
Continuous query representation for a SystemView.
ContinuousQueryView(UUID, GridContinuousProcessor.RoutineInfo) - Constructor for class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
ContinuousQueryWithTransformer<K,V,T> - Class in org.apache.ignite.cache.query
API for configuring continuous cache queries with transformer.
ContinuousQueryWithTransformer() - Constructor for class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Creates new continuous query with transformer.
ContinuousQueryWithTransformer.EventListener<T> - Interface in org.apache.ignite.cache.query
Interface for local listener of ContinuousQueryWithTransformer to implement.
convert(PrintStream, IgniteWalConverterArguments) - Static method in class org.apache.ignite.development.utils.IgniteWalConverter
Write to out WAL log data in human-readable form.
convert(byte[]) - Method in interface org.apache.ignite.stream.socket.SocketMessageConverter
Converter message represented by array of bytes to object.
copy() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
 
copyright() - Method in interface org.apache.ignite.plugin.PluginProvider
 
COPYRIGHT_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
count() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets current count value of the latch.
count() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets total count of executions this task has already completed.
count() - Method in class org.apache.ignite.spi.systemview.view.datastructures.CountDownLatchView
 
count() - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker
 
countDown() - Method in interface org.apache.ignite.IgniteCountDownLatch
Decrements the count of the latch, releasing all waiting threads on all nodes if the count reaches zero.
countDown(int) - Method in interface org.apache.ignite.IgniteCountDownLatch
Decreases the count of the latch using passed in value, releasing all waiting threads on all nodes if the count reaches zero.
countDownAll() - Method in interface org.apache.ignite.IgniteCountDownLatch
Counts down this latch to zero, releasing all waiting threads on all nodes.
countDownLatch(String, int, boolean, boolean) - Method in interface org.apache.ignite.Ignite
Gets or creates count down latch.
countDownLatch(String, int, boolean, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Gets or creates count down latch.
CountDownLatchView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteCountDownLatch representation for a SystemView.
CountDownLatchView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.CountDownLatchView
 
COURTESY_LOGGER_NAME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Courtesy notice log category.
create(int) - Method in interface org.apache.ignite.binary.BinaryCollectionFactory
Create collection.
create(int) - Method in interface org.apache.ignite.binary.BinaryMapFactory
Create collection.
create() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyFactory
create() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicyFactory
create() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
create() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
create() - Method in class org.apache.ignite.cache.jta.websphere.WebSphereLibertyTmFactory
create() - Method in class org.apache.ignite.cache.jta.websphere.WebSphereTmFactory
create() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
create() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
create(String, int) - Method in interface org.apache.ignite.client.ClientPartitionAwarenessMapperFactory
 
create() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
create() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
create() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactoryNative
create() - Method in interface org.apache.ignite.platform.PlatformJavaObjectFactory
Constructs and returns a fully configured instance of T.
create(short) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFactory
Deprecated.
Creates new message instance of provided type.
create(short) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFactoryProvider
create() - Method in interface org.apache.ignite.plugin.platform.PlatformCachePluginConfigurationClosureFactory
Creates configuration closure instance.
create() - Method in interface org.apache.ignite.plugin.platform.PlatformPluginConfigurationClosureFactory
Creates configuration instance.
create() - Static method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Static factory method for create new permission builder.
create() - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Creates new key for an encryption/decryption of cache persistent data: pages, WAL records.
create() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Creates new key for an encryption/decryption of cache persistent data: pages, WAL records.
create() - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Creates new key for an encryption/decryption of cache persistent data: pages, WAL records.
create(String, byte[]) - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
Creates Span given name and explicit parent.
create(String, NoopSpiSpecificSpan) - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
Creates Span given name and explicit parent.
create(String, byte[]) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
Creates Span given name and explicit parent.
create(String, OpenCensusSpanAdapter) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
Creates Span given name and explicit parent.
create(String, byte[]) - Method in interface org.apache.ignite.spi.tracing.TracingSpi
Creates Span given name and explicit parent.
create(String, S) - Method in interface org.apache.ignite.spi.tracing.TracingSpi
Creates Span given name and explicit parent.
create() - Method in class org.apache.ignite.ssl.AbstractSslContextFactory
createCache(String, C) - Method in class org.apache.ignite.cache.CacheManager
createCache(String) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with a default configuration.
createCache(ClientCacheConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with the specified configuration.
createCache(CacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Dynamically starts new cache with the given cache configuration.
createCache(String) - Method in interface org.apache.ignite.Ignite
Dynamically starts new cache using template configuration.
createCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Dynamically starts new cache with the given cache configuration.
createCache(String) - Method in class org.apache.ignite.IgniteClientSpringBean
Creates a cache with a default configuration.
createCache(ClientCacheConfiguration) - Method in class org.apache.ignite.IgniteClientSpringBean
Creates a cache with the specified configuration.
createCache(CacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Dynamically starts new cache with the given cache configuration.
createCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Dynamically starts new cache with the given cache configuration.
createCache(String) - Method in class org.apache.ignite.IgniteSpringBean
Dynamically starts new cache using template configuration.
createCacheAsync(String) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with a default configuration.
createCacheAsync(ClientCacheConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Creates a cache with the specified configuration.
createCacheAsync(String) - Method in class org.apache.ignite.IgniteClientSpringBean
Creates a cache with a default configuration.
createCacheAsync(ClientCacheConfiguration) - Method in class org.apache.ignite.IgniteClientSpringBean
Creates a cache with the specified configuration.
createCacheProvider(CachePluginContext) - Method in interface org.apache.ignite.plugin.PluginProvider
Creates cache plugin provider.
createCaches(Collection<CacheConfiguration>) - Method in interface org.apache.ignite.Ignite
Dynamically starts new caches with the given cache configurations.
createCaches(Collection<CacheConfiguration>) - Method in class org.apache.ignite.IgniteSpringBean
Dynamically starts new caches with the given cache configurations.
createComponent(Class<T>) - Method in interface org.apache.ignite.plugin.CachePluginProvider
 
createComponent(PluginContext, Class<T>) - Method in interface org.apache.ignite.plugin.PluginProvider
Creates Ignite component.
createDefaultPolicyConfig() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Creates a configuration for the default memory policy that will instantiate the default memory region.
createDump(String, Collection<String>) - Method in interface org.apache.ignite.IgniteSnapshot
Creates cache groups dump.
createIncrementalSnapshot(String) - Method in interface org.apache.ignite.IgniteSnapshot
Create an incremental snapshot for an existing snapshot.
createIncrementalSnapshot(String, String) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
Deprecated.
Create the cluster-wide incremental snapshot for the given full snapshot.
createKeyManagers() - Method in class org.apache.ignite.ssl.AbstractSslContextFactory
 
createKeyManagers() - Method in class org.apache.ignite.ssl.SslContextFactory
createName(long, String, String) - Static method in class org.apache.ignite.thread.IgniteThread
Creates new thread name.
createNearCache(String, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Starts a near cache on local node if cache was previously started with one of the Ignite.createCache(CacheConfiguration) or Ignite.createCache(CacheConfiguration, NearCacheConfiguration) methods.
createNearCache(String, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Starts a near cache on local node if cache was previously started with one of the Ignite.createCache(CacheConfiguration) or Ignite.createCache(CacheConfiguration, NearCacheConfiguration) methods.
createSnapshot(String) - Method in interface org.apache.ignite.IgniteSnapshot
Create a consistent copy of all persistence cache groups from the whole cluster.
createSnapshot(String, String) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
Deprecated.
Create the cluster-wide snapshot with given name asynchronously.
createSpiAttributeName(String) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Creates new name for the given attribute.
createTcpClient(ClusterNode, int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Establish TCP connection to remote node and returns client.
createTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets time in milliseconds at which this future was created.
createTime() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
createTrustManagers() - Method in class org.apache.ignite.ssl.AbstractSslContextFactory
 
createTrustManagers() - Method in class org.apache.ignite.ssl.SslContextFactory
credentials() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets security credentials.
credentials(SecurityCredentials) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets security credentials.
credentials() - Method in class org.apache.ignite.plugin.security.SecurityCredentialsBasicProvider
Gets security credentials.
credentials() - Method in interface org.apache.ignite.plugin.security.SecurityCredentialsProvider
Gets security credentials.
ctx - Variable in class org.apache.ignite.marshaller.AbstractMarshaller
Context.
CUR_COORDINATOR_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
curActiveJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curCanceledJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curCpuLoad() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curDaemonThreadCount() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curGcCpuLoad() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curIdleTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curJobsExecuteTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curJobsWaitTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curRejectedJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
current() - Static method in class org.apache.ignite.thread.IgniteThread
 
currentBaselineTopology() - Method in interface org.apache.ignite.IgniteCluster
Gets current baseline topology.
currentCallContext() - Method in interface org.apache.ignite.services.ServiceContext
Gets context of the current service call.
currentThreadCanRequestBinaryMetadata() - Static method in class org.apache.ignite.thread.IgniteThread
 
currentTopologySnapshot() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets current topology snapshot.
currentTopologyVersion() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets current topology version number.
curThreadCount() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
curWaitingJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 

D

DataPageEvictionMode - Enum in org.apache.ignite.configuration
Defines memory page eviction algorithm.
DataRegionConfiguration - Class in org.apache.ignite.configuration
This class allows defining custom data regions' configurations with various parameters for Apache Ignite page memory (see DataStorageConfiguration.
DataRegionConfiguration() - Constructor for class org.apache.ignite.configuration.DataRegionConfiguration
 
DataRegionMetrics - Interface in org.apache.ignite
Deprecated.
Check the ReadOnlyMetricRegistry with "name=io.dataregion.{data_region_name}" instead.
dataRegionMetrics() - Method in interface org.apache.ignite.Ignite
Deprecated.
Check the ReadOnlyMetricRegistry with "name=io.dataregion.{data_region_name}" instead.
dataRegionMetrics(String) - Method in interface org.apache.ignite.Ignite
Returns the latest DataRegionMetrics snapshot for the memory region of the given name.
dataRegionMetrics() - Method in class org.apache.ignite.IgniteSpringBean
Returns a collection of DataRegionMetrics that reflects page memory usage on this Apache Ignite node instance.
dataRegionMetrics(String) - Method in class org.apache.ignite.IgniteSpringBean
Returns the latest DataRegionMetrics snapshot for the memory region of the given name.
DataRegionMetricsAdapter - Class in org.apache.ignite
Deprecated.
Check the ReadOnlyMetricRegistry with "name=io.dataregion.{data_region_name}" instead.
DataRegionMetricsProvider - Interface in org.apache.ignite
This interface provides calculated metrics for data region.
dataRegionName() - Method in class org.apache.ignite.events.PageReplacementStartedEvent
Gets data region name for which page replacement started.
dataRegionName() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
dataRegionName() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
dataRegionName() - Method in class org.apache.ignite.spi.systemview.view.PagesTimestampHistogramView
 
dataSrc - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Data source.
DataStorageConfiguration - Class in org.apache.ignite.configuration
A durable memory configuration for an Apache Ignite node.
DataStorageConfiguration() - Constructor for class org.apache.ignite.configuration.DataStorageConfiguration
Creates valid durable memory configuration with all default values.
DataStorageMXBean - Interface in org.apache.ignite.mxbean
An MX bean allowing to monitor and tune persistence.
dataStreamer(String) - Method in interface org.apache.ignite.Ignite
Gets a new instance of data streamer associated with given cache name.
dataStreamer(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets a new instance of data streamer associated with given cache name.
DB2Dialect - Class in org.apache.ignite.cache.store.jdbc.dialect
A dialect compatible with the IBM DB2 database.
DB2Dialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect
 
debug(String) - Method in interface org.apache.ignite.IgniteLogger
Logs out debug message.
debug(String, String) - Method in interface org.apache.ignite.IgniteLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out debug message.
debug(String, String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.NullLogger
Logs out debug message.
debug(String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out debug message.
debug(String, String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out debug message.
decrementAndGet() - Method in interface org.apache.ignite.client.ClientAtomicLong
Decrements and gets current value of atomic long.
decrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicLong
Decrements and gets current value of atomic long.
decrypt(byte[], Serializable) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
decrypt(byte[], Serializable) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
decrypt(byte[], Serializable) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
decryptKey(byte[]) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Decrypts key and checks it integrity.
decryptKey(byte[], String) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Decrypts key and checks its integrity using the master key specified by name.
decryptKey(byte[]) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Decrypts key and checks it integrity.
decryptKey(byte[], String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Decrypts key and checks its integrity using the master key specified by name.
decryptKey(byte[]) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Decrypts key and checks it integrity.
decryptKey(byte[], String) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Decrypts key and checks its integrity using the master key specified by name.
decryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
decryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
decryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
DEFAULT - Static variable in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Default instance.
DEFAULT() - Constructor for class org.apache.ignite.resources.SpringResource.DEFAULT
 
DEFAULT_COMMUNICATION_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default communication configuration.
DEFAULT_DISCOVERY_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default discovery configuration.
DEFAULT_EXCHANGE_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default exchange configuration.
DEFAULT_KEY_SIZE - Static variable in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Default encryption key size;
DEFAULT_MASTER_KEY_NAME - Static variable in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Default key store entry name to store Encryption master key.
DEFAULT_SQL_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default SQL tracing configuration.
DEFAULT_TX_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default transaction tracing configuration.
defaultAllowAll() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Flag indicating whether to allow or deny cache and task operations if they were not explicitly specified.
defaultAllowAll() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Flag indicating whether to allow or deny cache and task operations if they were not explicitly specified.
defaultAllowAll(boolean) - Method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
Append default all flag.
DefaultCommunicationFailureResolver - Class in org.apache.ignite.configuration
Default Communication Failure Resolver.
DefaultCommunicationFailureResolver() - Constructor for class org.apache.ignite.configuration.DefaultCommunicationFailureResolver
 
defaultLockTimeout() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
defaultValue() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
defaultValue() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewColumnView
 
DefragmentationMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use managements API beans, instead.
delayedRegister() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
delete(Object) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
delete(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
delete(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
DELIM - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Delimiter to use between address and port tokens in file names.
deploy(ServiceConfiguration) - Method in interface org.apache.ignite.IgniteServices
Deploys multiple instances of the service on the grid according to provided configuration.
DEPLOY_TMP_ROOT_NAME - Static variable in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Default temporary directory name relative to file path UriDeploymentSpi.setTemporaryDirectoryPath(String)} (value is gg.uri.deployment.tmp).
deployAll(Collection<ServiceConfiguration>) - Method in interface org.apache.ignite.IgniteServices
Deploys multiple services described by provided configurations.
deployAllAsync(Collection<ServiceConfiguration>) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys multiple services described by provided configurations.
deployAsync(ServiceConfiguration) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys multiple instances of the service on the grid according to provided configuration.
deployClass(Class<?>) - Method in interface org.apache.ignite.IgniteDataStreamer
Optional deploy class for peer deployment.
deployClusterSingleton(String, Service) - Method in interface org.apache.ignite.IgniteServices
Deploys a cluster-wide singleton service.
deployClusterSingletonAsync(String, Service) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys a cluster-wide singleton service.
deployKeyAffinitySingleton(String, Service, String, Object) - Method in interface org.apache.ignite.IgniteServices
Deploys one instance of this service on the primary node for a given affinity key.
deployKeyAffinitySingletonAsync(String, Service, String, Object) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys one instance of this service on the primary node for a given affinity key.
DEPLOYMENT_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
DeploymentEvent - Class in org.apache.ignite.events
Grid deployment event.
DeploymentEvent() - Constructor for class org.apache.ignite.events.DeploymentEvent
No-arg constructor.
DeploymentEvent(ClusterNode, String, int) - Constructor for class org.apache.ignite.events.DeploymentEvent
Creates deployment event with given parameters.
DeploymentListener - Interface in org.apache.ignite.spi.deployment
Listener for deployment events.
DeploymentMode - Enum in org.apache.ignite.configuration
Grid deployment mode.
DeploymentResource - Interface in org.apache.ignite.spi.deployment
Generic abstraction over deployed resource containing resource's name, class and corresponding class loader.
DeploymentResourceAdapter - Class in org.apache.ignite.spi.deployment
Simple adapter for DeploymentResource interface.
DeploymentResourceAdapter(String, Class<?>, ClassLoader) - Constructor for class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
Creates resource.
DeploymentSpi - Interface in org.apache.ignite.spi.deployment
Grid deployment SPI is in charge of deploying tasks and classes from different sources.
deployMultiple(String, Service, int, int) - Method in interface org.apache.ignite.IgniteServices
Deploys multiple instances of the service on the grid.
deployMultipleAsync(String, Service, int, int) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys multiple instances of the service on the grid.
deployNodeSingleton(String, Service) - Method in interface org.apache.ignite.IgniteServices
Deploys a per-node singleton service.
deployNodeSingletonAsync(String, Service) - Method in interface org.apache.ignite.IgniteServices
Asynchronously deploys a per-node singleton service.
deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in interface org.apache.ignite.client.ClientCache
Deregisters a listener, using the CacheEntryListenerConfiguration that was used to register it.
deregisterPort(int, IgnitePortProtocol, Class<?>) - Method in interface org.apache.ignite.plugin.PluginContext
Deregisters closed port.
deregisterPort(int, IgnitePortProtocol) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Deregisters closed port.
deregisterPorts(Class<?>) - Method in interface org.apache.ignite.plugin.PluginContext
Deregisters all closed ports.
deregisterPorts() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Deregisters all closed ports.
description() - Method in interface org.apache.ignite.maintenance.MaintenanceAction
 
description() - Method in class org.apache.ignite.maintenance.MaintenanceTask
 
description() - Method in interface org.apache.ignite.spi.metric.Metric
 
description() - Method in class org.apache.ignite.spi.systemview.view.MetricsView
 
description() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewView
 
description() - Method in class org.apache.ignite.spi.systemview.view.StripedExecutorTaskView
 
description() - Method in interface org.apache.ignite.spi.systemview.view.SystemView
 
deserialize() - Method in interface org.apache.ignite.binary.BinaryObject
Gets fully deserialized instance of binary object.
deserialize(ClassLoader) - Method in interface org.apache.ignite.binary.BinaryObject
Gets fully deserialized instance of binary object.
destroy() - Method in class org.apache.ignite.cache.websession.WebSessionFilter
destroy() - Method in interface org.apache.ignite.IgniteCache
Completely deletes the cache with all its data from the system on all cluster nodes.
destroy() - Method in class org.apache.ignite.IgniteSpringBean
destroy() - Method in class org.apache.ignite.startup.servlet.ServletStartup
destroyCache(String) - Method in class org.apache.ignite.cache.CacheManager
destroyCache(String) - Method in interface org.apache.ignite.client.IgniteClient
Destroys the cache with the given name.
destroyCache(String) - Method in interface org.apache.ignite.Ignite
Destroys a cache with the given name and cleans data that was written to the cache.
destroyCache(String) - Method in class org.apache.ignite.IgniteClientSpringBean
Destroys the cache with the given name.
destroyCache(String) - Method in class org.apache.ignite.IgniteSpringBean
Destroys a cache with the given name and cleans data that was written to the cache.
destroyCacheAsync(String) - Method in interface org.apache.ignite.client.IgniteClient
Destroys the cache with the given name.
destroyCacheAsync(String) - Method in class org.apache.ignite.IgniteClientSpringBean
Destroys the cache with the given name.
destroyCaches(Collection<String>) - Method in interface org.apache.ignite.Ignite
Destroys caches with the given names and cleans data that was written to the caches.
destroyCaches(Collection<String>) - Method in class org.apache.ignite.IgniteSpringBean
Destroys caches with the given names and cleans data that was written to the caches.
destroySession(String) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
 
DEV_ONLY - Static variable in interface org.apache.ignite.IgniteLogger
Marker for log messages that are useful in development environments, but not in production.
DFLT_ACK_SND_THRESHOLD - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default received messages threshold for sending ack.
DFLT_ACK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default timeout for receiving message acknowledgement in milliseconds (value is 5000ms).
DFLT_ACK_TIMEOUT_CLIENT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default timeout for receiving message acknowledgement in milliseconds (value is 5000ms).
DFLT_ACTIVE_JOBS_THRESHOLD - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Default number of parallel jobs allowed (value is 95 which is slightly less same as default value of threads in the execution thread pool to allow some extra threads for system processing).
DFLT_ACTIVE_ON_START - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
DFLT_ADDR_REQ_ATTEMPTS - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Default number of attempts to send multicast address request (value is 2).
DFLT_ALL_SEG_RESOLVERS_PASS_REQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default value for all segmentation resolvers pass required.
DFLT_ATOMIC_SEQUENCE_RESERVE_SIZE - Static variable in class org.apache.ignite.client.ClientAtomicConfiguration
Default atomic sequence reservation size.
DFLT_ATOMIC_SEQUENCE_RESERVE_SIZE - Static variable in class org.apache.ignite.configuration.AtomicConfiguration
Default atomic sequence reservation size.
DFLT_AUTO_ACTIVATION - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
DFLT_AUTO_UNSUBSCRIBE - Static variable in class org.apache.ignite.cache.query.AbstractContinuousQuery
Default value for automatic unsubscription flag.
DFLT_BACKUPS - Static variable in class org.apache.ignite.client.ClientAtomicConfiguration
Default number of backups.
DFLT_BACKUPS - Static variable in class org.apache.ignite.configuration.AtomicConfiguration
 
DFLT_BACKUPS - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default number of backups.
DFLT_BATCH_QUEUE_SIZE - Static variable in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Default batch queue size (max batches count to limit memory usage).
DFLT_BATCH_SIZE - Static variable in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Default batch size (number of records read with CacheLoadOnlyStoreAdapter.inputIterator(Object...)
DFLT_BATCH_SIZE - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Default batch size for put and remove operations.
DFLT_BINARY_METADATA_PATH - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default path (relative to working directory) of binary metadata folder
DFLT_BUFFER_SIZE - Static variable in class org.apache.ignite.marshaller.AbstractMarshaller
Default initial buffer size for the GridByteArrayOutputStream.
DFLT_BUILD_IDX_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of index create/rebuild thread pool.
DFLT_CACHE_ATOMICITY_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default atomicity mode.
DFLT_CACHE_MODE - Static variable in class org.apache.ignite.client.ClientAtomicConfiguration
Cache mode.
DFLT_CACHE_MODE - Static variable in class org.apache.ignite.configuration.AtomicConfiguration
 
DFLT_CACHE_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default caching mode.
DFLT_CACHE_NAME - Static variable in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Default cache name (value is checkpoints).
DFLT_CACHE_SANITY_CHECK_ENABLED - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default value for cache sanity check enabled flag.
DFLT_CACHE_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default cache size to use with eviction policy.
DFLT_CDC_WAL_DIRECTORY_MAX_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default change data capture directory maximum size.
DFLT_CHECKPOINT_FREQ - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
 
DFLT_CHECKPOINT_TABLE_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default checkpoint table name (value is CHECKPOINTS).
DFLT_CHECKPOINT_THREADS - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default number of checkpoint threads.
DFLT_CHECKPOINT_WRITE_ORDER - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default checkpoint write order.
DFLT_CHECKPOINT_WRITE_ORDER - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default checkpoint write order.
DFLT_CHECKPOINTING_FREQ - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
DFLT_CHECKPOINTING_THREADS - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default number of checkpointing threads.
DFLT_CLIENT_FAILURE_DETECTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default failure detection timeout for client nodes in millis.
DFLT_COMPACT_FOOTER - Static variable in class org.apache.ignite.configuration.BinaryConfiguration
Default compact footer flag setting.
DFLT_CONCURRENT_LOAD_ALL_THRESHOLD - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default threshold for concurrent loading of keys from CacheStore.
DFLT_CONFIG_PATH - Static variable in class org.apache.ignite.logger.java.JavaLogger
 
DFLT_CONN_PER_NODE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default connections per node.
DFLT_CONN_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default connection timeout (value is 5000ms).
DFLT_CONN_URL - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default connection URL (value is jdbc:h2:mem:jdbcCacheStore;DB_CLOSE_DELAY=-1).
DFLT_CONNECTION_RECOVERY_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default connection recovery timeout in ms.
DFLT_COPY_ON_READ - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'copyOnRead' flag.
DFLT_CREATE_TBL_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default create table query (value is create table if not exists ENTRIES (akey binary primary key, val binary)).
DFLT_DATA_REG_DEFAULT_NAME - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
This name is assigned to default Dataregion if no user-defined default MemPlc is specified
DFLT_DATA_REGION_INITIAL_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default data region start size (256 MB).
DFLT_DATA_REGION_MAX_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default data region's size is 20% of physical memory available on current machine.
DFLT_DATA_STREAMER_POOL_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of data streamer thread pool.
DFLT_DEFRAGMENTATION_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default defragmentation thread pool size.
DFLT_DEL_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default delete entry query (value is delete from ENTRIES where akey=?
DFLT_DEPLOY_DIR - Static variable in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Default deployment directory where SPI will pick up packages.
DFLT_DEPLOYMENT_MODE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default deployment mode (value is DeploymentMode.SHARED).
DFLT_DIR_PATH - Static variable in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Default checkpoint directory.
DFLT_DISCO_FAILED_CLIENT_RECONNECT_DELAY - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
DFLT_DISCOVERY_CLIENT_RECONNECT_HISTORY_SIZE - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
DFLT_DISCOVERY_METRICS_QNT_WARN - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
DFLT_DISCOVERY_STARTUP_DELAY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default discovery startup delay in milliseconds (value is 60,000ms).
DFLT_DISK_PAGE_COMPRESSION - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default disk page compression algorithm.
DFLT_EAGER_TTL - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for eager ttl flag.
DFLT_EVENTS_DISABLED - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for events disabled flag.
DFLT_EXPIRE_AGE_MS - Static variable in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Default event time to live value in milliseconds (value is Long.MAX_VALUE).
DFLT_EXPIRE_COUNT - Static variable in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Default expire count (value is 10000).
DFLT_EXPIRE_DATE_FIELD_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default expiration date field name (value is EXPIRE_DATE).
DFLT_EXPIRE_DATE_FIELD_TYPE - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default expiration date field type (value is DATETIME).
DFLT_FAILURE_DETECTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default failure detection timeout in millis.
DFLT_FILTER_REACHABLE_ADDRESSES - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default value for FILTER_REACHABLE_ADDRESSES socket option (value is false).
DFLT_GRID_CNT - Static variable in class org.apache.ignite.startup.BasicWarmupClosure
Default grid count to warm up.
DFLT_HANDSHAKE_TIMEOUT - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default handshake timeout.
DFLT_IDLE_CONN_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default idle connection timeout (value is 10min).
DFLT_IDLE_TIMEOUT - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default idle timeout.
DFLT_IDLE_TIMEOUT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default REST idle timeout.
DFLT_IGNITE_CLI_LIFECYCLE_PHASE - Static variable in class org.apache.ignite.IgniteClientSpringBean
Default Ignite client SmartLifecycle phase.
DFLT_INLINE_SIZE - Static variable in class org.apache.ignite.cache.QueryIndex
Default index inline size.
DFLT_INSERT_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default insert entry query (value is insert into ENTRIES (akey, val) values (?
DFLT_INVALIDATE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'invalidate' flag that indicates if this is invalidation-based cache.
DFLT_IP_FINDER_CLEAN_FREQ - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default IP finder clean frequency in milliseconds (value is 60,000ms).
DFLT_ITERATION_CNT - Static variable in class org.apache.ignite.startup.BasicWarmupClosure
Default iteration count per thread.
DFLT_JCACHE_DEFAULT_ISOLATED - Static variable in class org.apache.ignite.cache.CacheManager
 
DFLT_JOB_PRIORITY - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Default start value for job priority (value is 0).
DFLT_JOB_PRIORITY_ATTRIBUTE_KEY - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default job priority attribute key (value is grid.job.priority).
DFLT_JOIN_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default timeout for joining topology (value is 0).
DFLT_JOIN_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
DFLT_KEEP_ALIVE_TIME - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default keep alive time for REST thread pool.
DFLT_KEEP_BINARY_FLAG - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Default keep binary flag.
DFLT_KEY_ALGORITHM - Static variable in class org.apache.ignite.ssl.SslContextFactory
Default key manager / trust manager algorithm.
DFLT_KEY_FIELD_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default checkpoint key field name (value is NAME).
DFLT_KEY_FIELD_TYPE - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default checkpoint key field type (value is VARCHAR(256)).
DFLT_KEY_RANGE - Static variable in class org.apache.ignite.startup.BasicWarmupClosure
Default key range.
DFLT_LATE_AFF_ASSIGNMENT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
DFLT_LAZY - Static variable in class org.apache.ignite.cache.query.SqlFieldsQuery
Do not remove.
DFLT_LOAD_PREV_VAL - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for load previous value flag.
DFLT_LOAD_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default load entry query (value is select * from ENTRIES where akey=?
DFLT_LOCK_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
Default lock timeout configuration property has no effect.
DFLT_LOCK_WAIT_TIME - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Lock default wait time, 10 sec.
DFLT_LOCK_WAIT_TIME - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Lock default wait time, 10 sec.
DFLT_LONG_QRY_WARN_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
DFLT_LONG_QRY_WARN_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
DFLT_LONG_QRY_WARN_TIMEOUT - Static variable in class org.apache.ignite.configuration.SqlConfiguration
Default timeout after which long query warning will be printed.
DFLT_LOWER_CASE - Static variable in class org.apache.ignite.binary.BinaryBasicIdMapper
Default lower case flag setting.
DFLT_MARSHAL_LOCAL_JOBS - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default marshal local jobs flag.
DFLT_MARSHALLER_PATH - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default path (relative to working directory) of marshaller mappings folder
DFLT_MAX_ACK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Maximum ack timeout value for receiving message acknowledgement in milliseconds (value is 600,000ms).
DFLT_MAX_ACTIVE_COMPUTE_TASKS_PER_CONNECTION - Static variable in class org.apache.ignite.configuration.ThinClientConfiguration
Default limit of active compute tasks per connection.
DFLT_MAX_ACTIVE_TX_PER_CONNECTION - Static variable in class org.apache.ignite.configuration.ThinClientConfiguration
Default limit of active transactions count per connection.
DFLT_MAX_CONCURRENT_ASYNC_OPS - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'maxConcurrentAsyncOps'.
DFLT_MAX_CONN_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default Maximum connection timeout (value is 600,000ms).
DFLT_MAX_FAILOVER_ATTEMPTS - Static variable in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Maximum number of attempts to execute a failed job on another node (default is 5).
DFLT_MAX_FAILOVER_ATTEMPTS - Static variable in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
Maximum number of attempts to execute a failed job on another node (default is 5).
DFLT_MAX_OPEN_CURSORS - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default max number of open cursors per connection.
DFLT_MAX_OPEN_CURSORS_PER_CONN - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default max number of open cursors per connection.
DFLT_MAX_OPEN_CURSORS_PER_CONN - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default max number of open cursors per connection.
DFLT_MAX_PARALLEL_OPS - Static variable in interface org.apache.ignite.IgniteDataStreamer
Deprecated.
Is not used anymore.
DFLT_MAX_PARAMS_CNT - Static variable in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Default max query parameters count.
DFLT_MAX_QUERY_ITERATOR_CNT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default maximum number of query iterators that can be stored.
DFLT_MAX_RETRIES_ON_FAIL - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Default retry on fail flag value.
DFLT_MAX_STEALING_ATTEMPTS - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Maximum number of attempts to steal job by another node (default is 5).
DFLT_MCAST_GROUP - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Default multicast IP address (value is 228.1.2.4).
DFLT_MCAST_PORT - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Default multicast port number (value is 47400).
DFLT_MEM_PLC_DEFAULT_NAME - Static variable in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
This name is assigned to default DataRegion if no user-defined default MemPlc is specified
DFLT_MEMORY_POLICY_INITIAL_SIZE - Static variable in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Default memory policy start size (256 MB).
DFLT_MEMORY_POLICY_MAX_SIZE - Static variable in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Default memory policy's size is 20% of physical memory available on current machine.
DFLT_METRICS_ENABLED - Static variable in class org.apache.ignite.configuration.DataRegionConfiguration
Default metrics enabled flag.
DFLT_METRICS_ENABLED - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Deprecated.
Will be removed in upcoming releases.
DFLT_METRICS_ENABLED - Static variable in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Default metrics enabled flag.
DFLT_METRICS_ENABLED - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
DFLT_METRICS_EXPIRE_TIME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default metrics expire time.
DFLT_METRICS_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default metrics history size (value is 10000).
DFLT_METRICS_LOG_FREQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default frequency of metrics log print out.
DFLT_METRICS_UPDATE_FREQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default metrics update frequency.
DFLT_MGMT_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of management thread pool.
DFLT_MSG_EXPIRE_TIME - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Default steal message expire time in milliseconds (value is 1000).
DFLT_MSG_QUEUE_LIMIT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default message queue limit per connection (for incoming and outgoing .
DFLT_MVCC_VACUUM_FREQUENCY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default time interval between MVCC vacuum runs in milliseconds.
DFLT_MVCC_VACUUM_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default number of MVCC vacuum threads..
DFLT_NEAR_START_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Initial default near cache size.
DFLT_NETWORK_COMPRESSION - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default compression level for network messages (value is Deflater.BEST_SPEED.
DFLT_NETWORK_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default maximum timeout to wait for network responses in milliseconds (value is 5,000ms).
DFLT_NETWORK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default network timeout in milliseconds (value is 5000ms).
DFLT_NODE_IDS_HISTORY_SIZE - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
DFLT_NODE_WEIGHT - Static variable in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Default weight assigned to every node if explicit one is not provided (value is 10).
DFLT_NUMBER_OF_RETRIES - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default number of retries in case of errors (value is 2).
DFLT_P2P_ENABLED - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default flag for peer class loading.
DFLT_P2P_MISSED_RESOURCES_CACHE_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default cache size for missed resources.
DFLT_P2P_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of peer class loading thread pool.
DFLT_PAGE_REPLACEMENT_MODE - Static variable in class org.apache.ignite.configuration.DataRegionConfiguration
Default page replacement mode.
DFLT_PAGE_SIZE - Static variable in class org.apache.ignite.cache.query.AbstractContinuousQuery
Default page size.
DFLT_PAGE_SIZE - Static variable in class org.apache.ignite.cache.query.Query
Default query page size.
DFLT_PAGE_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default memory page size.
DFLT_PAGE_SIZE - Static variable in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Default memory page size.
DFLT_PARALLEL_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Default number of parallel jobs allowed (set to number of cores times 2).
DFLT_PARALLEL_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default number of parallel jobs allowed (set to number of cores times 2).
DFLT_PARALLEL_LOAD_CACHE_MINIMUM_THRESHOLD - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Default batch size for put and remove operations.
DFLT_PARALLEL_OPS_MULTIPLIER - Static variable in interface org.apache.ignite.IgniteDataStreamer
Default multiplier for data streamer pool size to get concurrent batches count for each remote node.
DFLT_PARTITION_COUNT - Static variable in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Default number of partitions.
DFLT_PARTITION_LOSS_POLICY - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default partition loss policy.
DFLT_PATH - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Default path for discovering of local nodes (testing only).
DFLT_PER_NODE_BUFFER_SIZE - Static variable in interface org.apache.ignite.IgniteDataStreamer
Default operations batch size to sent to remote node for loading.
DFLT_PER_THREAD_BUFFER_SIZE - Static variable in interface org.apache.ignite.IgniteDataStreamer
Default batch size per thread to send to buffer on node.
DFLT_PESSIMISTIC_TX_LOG_LINGER - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Deprecated.
Pessimistic tx log linger property has no effect.
DFLT_PORT - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default port.
DFLT_PORT - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default port.
DFLT_PORT - Static variable in class org.apache.ignite.IgniteJdbcDriver
Default port.
DFLT_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default port which node sets listener to (value is 47100).
DFLT_PORT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default port to listen (value is 47500).
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default port range.
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default rest port range.
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default port range.
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default local port range (value is 100).
DFLT_PORT_RANGE - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default local port range (value is 100).
DFLT_PREVENT_STARVATION_ENABLED - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default flag for preventing starvation of lower priority jobs.
DFLT_PRIORITY - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default priority that will be assigned if job does not have a priority attribute set (value is 0).
DFLT_PRIORITY_ATTRIBUTE_KEY - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default priority attribute key (value is grid.task.priority).
DFLT_PROG_NAME - Static variable in class org.apache.ignite.startup.cmdline.CommandLineStartup
 
DFLT_PROPS - Static variable in class org.apache.ignite.cache.CachingProvider
 
DFLT_PUBLIC_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default core size of public thread pool.
DFLT_QRY_DETAIL_METRICS_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default number of queries detail metrics to collect.
DFLT_QRY_TIMEOUT - Static variable in class org.apache.ignite.configuration.SqlConfiguration
Default query timeout.
DFLT_QUERY_PARALLELISM - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default query parallelism.
DFLT_QUERY_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of query thread pool.
DFLT_RATE_TIME_INTERVAL_MILLIS - Static variable in class org.apache.ignite.configuration.DataRegionConfiguration
Default length of interval over which DataRegionMetrics.getAllocationRate() metric is calculated.
DFLT_RATE_TIME_INTERVAL_MILLIS - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default length of interval over which rate-based metric is calculated.
DFLT_RATE_TIME_INTERVAL_MILLIS - Static variable in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Default length of interval over which MemoryMetrics.getAllocationRate() metric is calculated.
DFLT_RATE_TIME_INTERVAL_MILLIS - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default length of interval over which rate-based metric is calculated.
DFLT_READ_FROM_BACKUP - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'readFromBackup' flag.
DFLT_REBALANCE_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
DFLT_REBALANCE_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default rebalance batch size in bytes (value is 512Kb).
DFLT_REBALANCE_BATCHES_PREFETCH_COUNT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
DFLT_REBALANCE_BATCHES_PREFETCH_COUNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default rebalance batches prefetch count (value is 3).
DFLT_REBALANCE_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default rebalance mode for distributed cache.
DFLT_REBALANCE_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
DFLT_REBALANCE_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default limit of threads used for rebalance.
DFLT_REBALANCE_THROTTLE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
DFLT_REBALANCE_THROTTLE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Time to wait between rebalance messages in milliseconds to avoid overloading CPU (value is 0).
DFLT_REBALANCE_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
DFLT_REBALANCE_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default rebalance message timeout in milliseconds (value is 10000).
DFLT_RECONNECT_CNT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default reconnect attempts count (value is 10).
DFLT_RECONNECT_CNT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default reconnect attempts count (value is 10).
DFLT_RECONNECT_DELAY - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default delay between attempts to connect to the cluster in milliseconds (value is 2000).
DFLT_REENCRYPTION_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.EncryptionConfiguration
Default number of pages that is scanned during reencryption under checkpoint lock.
DFLT_REENCRYPTION_RATE_MBPS - Static variable in class org.apache.ignite.configuration.EncryptionConfiguration
Default re-encryption rate limit.
DFLT_RES_WAIT_TIME - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Default time IP finder waits for reply to multicast address request (value is 500).
DFLT_REST_CORE_THREAD_CNT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default size of REST thread pool.
DFLT_REST_MAX_THREAD_CNT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default max size of REST thread pool.
DFLT_RETRIES_ON_FAIL_TIMEOUT - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Default retry on fail timeout flag value.
DFLT_ROOT_PATH - Static variable in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
DFLT_SEG_CHK_FREQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default segment check frequency in discovery manager.
DFLT_SEG_PLC - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default segmentation policy.
DFLT_SEG_RESOLVE_ATTEMPTS - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default value segmentation resolve attempts count.
DFLT_SELECTOR_CNT - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default selector count.
DFLT_SELECTORS_CNT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default count of selectors for TCP server equals to "Math.max(4, Runtime.getRuntime().availableProcessors() / 2)".
DFLT_SEND_RETRY_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default message send retries count.
DFLT_SEND_RETRY_DELAY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default interval between message send retries.
DFLT_SESSIONS_MESSAGE_QUEUE_LIMIT - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default session outbound queue limit.
DFLT_SHMEM_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Deprecated.
This constant is not used and will be removed in future releases.
DFLT_SHUTDOWN_POLICY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default policy for node shutdown.
DFLT_SIMPLE_NAME - Static variable in class org.apache.ignite.binary.BinaryBasicNameMapper
Default use simple name flag setting.
DFLT_SNAPSHOT_DIRECTORY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default relative working directory path for snapshot operation result.
DFLT_SNAPSHOT_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default number of threads to perform snapshot operations.
DFLT_SO_LINGER - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default SO_LINGER to set for socket, 0 means enabled with 0 timeout.
DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default socket send and receive buffer size.
DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default socket send and receive buffer size.
DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default socket send and receive buffer size.
DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default socket send and receive buffer size.
DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default socket send and receive buffer size.
DFLT_SOCK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default socket operations timeout in milliseconds (value is 5000ms).
DFLT_SOCK_TIMEOUT_CLIENT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default socket operations timeout in milliseconds (value is 5000ms).
DFLT_SOCK_WRITE_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default socket write timeout.
DFLT_SQL_INDEX_MAX_INLINE_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default maximum inline size for sql indexes.
DFLT_SQL_ONHEAP_CACHE_MAX_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default SQL on-heap cache size.
DFLT_SQL_QUERY_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
DFLT_SQL_QUERY_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.SqlConfiguration
Default SQL query history size.
DFLT_SSL_PROTOCOL - Static variable in class org.apache.ignite.ssl.AbstractSslContextFactory
Default SSL protocol.
DFLT_SSL_PROTOCOL - Static variable in class org.apache.ignite.ssl.SslContextFactory
Default SSL protocol.
DFLT_STARVATION_INCREMENT - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default value on which job priority will be increased every time when job gets bumped down.
DFLT_STATE_ON_START - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default value for cluster state on start.
DFLT_STATS_PRINT_FREQ - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default statistics print frequency in milliseconds (value is 0ms).
DFLT_STORE_KEEP_BINARY - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for keep binary in store behavior .
DFLT_STORE_TYPE - Static variable in class org.apache.ignite.ssl.SslContextFactory
Default key / trust store type.
DFLT_SUB_INTERVALS - Static variable in class org.apache.ignite.configuration.DataRegionConfiguration
Default amount of sub intervals to calculate DataRegionMetrics.getAllocationRate() metric.
DFLT_SUB_INTERVALS - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default amount of sub intervals to calculate rate-based metric.
DFLT_SUB_INTERVALS - Static variable in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Default amount of sub intervals to calculate MemoryMetrics.getAllocationRate() metric.
DFLT_SUB_INTERVALS - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default amount of sub intervals to calculate rate-based metric.
DFLT_SYS_REG_INIT_SIZE - Static variable in class org.apache.ignite.configuration.SystemDataRegionConfiguration
Default initial size in bytes of a memory chunk for the system cache (40 MB).
DFLT_SYS_REG_MAX_SIZE - Static variable in class org.apache.ignite.configuration.SystemDataRegionConfiguration
Default max size in bytes of a memory chunk for the system cache (100 MB).
DFLT_SYSTEM_CORE_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default size of system thread pool.
DFLT_TCP_DIRECT_BUF - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default TCP direct buffer flag.
DFLT_TCP_HOST - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default TCP host.
DFLT_TCP_NO_DELAY - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default value for TCP_NODELAY socket option (value is true).
DFLT_TCP_NO_DELAY - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default value for TCP_NODELAY socket option (value is true).
DFLT_TCP_NODELAY - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default TCP_NODELAY flag.
DFLT_TCP_NODELAY - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Default value for TCP_NODELAY socket option (value is true).
DFLT_TCP_PORT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default TCP server port.
DFLT_TCP_PORT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default TCP server port.
DFLT_TCP_PORT_FROM - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default minimum TCP port range value.
DFLT_TCP_PORT_TO - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default maximum TCP port range value.
DFLT_THREAD_CNT - Static variable in class org.apache.ignite.dump.DumpReaderConfiguration
Default thread count.
DFLT_THREAD_KEEP_ALIVE_TIME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default Ignite thread keep alive time.
DFLT_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default size of thread pool.
DFLT_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Default size of thread pool.
DFLT_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Default size of thread pool.
DFLT_THREAD_PRI - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default value for thread priority (value is 10).
DFLT_THREADPOOL_QUEUE_CAP - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
Default max queue capacity of REST thread pool.
DFLT_THREADS_COUNT - Static variable in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Default number of working threads (equal to the number of available processors).
DFLT_THROTTLE_RECONNECT_RESET_TIMEOUT_INTERVAL - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
DFLT_TIME_INTERVAL - Static variable in class org.apache.ignite.cache.query.AbstractContinuousQuery
Maximum default time interval after which buffer will be flushed (if buffering is enabled).
DFLT_TIME_SERVER_PORT_BASE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default time server port base.
DFLT_TIME_SERVER_PORT_RANGE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default time server port range.
DFLT_TIMEOUT - Static variable in class org.apache.ignite.dump.DumpReaderConfiguration
Default timeout.
DFLT_TLB_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default thread local buffer size.
DFLT_TOP_HISTORY_SIZE - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Default size of topology snapshots history.
DFLT_TRANSACTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.ClientTransactionConfiguration
Default transaction timeout.
DFLT_TRANSACTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default transaction timeout.
DFLT_TX_CONCURRENCY - Static variable in class org.apache.ignite.configuration.ClientTransactionConfiguration
Default concurrency mode.
DFLT_TX_CONCURRENCY - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default concurrency mode.
DFLT_TX_ISOLATION - Static variable in class org.apache.ignite.configuration.ClientTransactionConfiguration
Default transaction isolation level.
DFLT_TX_ISOLATION - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default transaction isolation level.
DFLT_TX_SERIALIZABLE_ENABLED - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Default value for 'txSerializableEnabled' flag.
DFLT_UNLIMIT_TIMEOUT - Static variable in interface org.apache.ignite.IgniteDataStreamer
Default timeout for streamer's operations.
DFLT_UPDATE_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default update entry query (value is select * from ENTRIES where akey=?
DFLT_USE_ASYNC_FILE_IO_FACTORY - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
 
DFLT_USE_IGNITE_SSL_CTX_FACTORY - Static variable in class org.apache.ignite.configuration.ClientConnectorConfiguration
Default value of whether to use Ignite SSL context factory.
DFLT_VALUE_FIELD_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default checkpoint value field name (value is VALUE).
DFLT_VALUE_FIELD_TYPE - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Default checkpoint value field type (value is BLOB).
DFLT_WAIT_FOR_SEG_ON_START - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
Default value for wait for segment on startup flag.
DFLT_WAIT_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Default waiting jobs number.
DFLT_WAIT_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Default waiting jobs number.
DFLT_WAIT_JOBS_THRESHOLD - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Default threshold of waiting jobs.
DFLT_WAL_ALWAYS_WRITE_FULL_PAGES - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal always write full pages.
DFLT_WAL_ALWAYS_WRITE_FULL_PAGES - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal always write full pages.
DFLT_WAL_ARCHIVE_MAX_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default max size of WAL archive files, in bytes.
DFLT_WAL_ARCHIVE_PATH - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal archive directory.
DFLT_WAL_ARCHIVE_PATH - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal archive directory.
DFLT_WAL_BUFF_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default thread local buffer size.
DFLT_WAL_CDC_PATH - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default change data capture directory.
DFLT_WAL_COMPACTION_ENABLED - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal compaction enabled.
DFLT_WAL_COMPACTION_LEVEL - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal compaction level.
DFLT_WAL_FLUSH_FREQ - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default Wal flush frequency.
DFLT_WAL_FLUSH_FREQ - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default Wal flush frequency.
DFLT_WAL_FSYNC_DELAY - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal fsync delay.
DFLT_WAL_FSYNC_DELAY - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal fsync delay.
DFLT_WAL_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default number of checkpoints to be kept in WAL after checkpoint is finished
DFLT_WAL_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default number of checkpoints to be kept in WAL after checkpoint is finished
DFLT_WAL_MODE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal mode.
DFLT_WAL_MODE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal mode.
DFLT_WAL_PAGE_COMPRESSION - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default compression algorithm for WAL page snapshot records.
DFLT_WAL_PATH - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal directory.
DFLT_WAL_RECORD_ITERATOR_BUFFER_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default wal record iterator buffer size.
DFLT_WAL_RECORD_ITERATOR_BUFFER_SIZE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal record iterator buffer size.
DFLT_WAL_SEGMENT_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default WAL file segment size, 64MBytes
DFLT_WAL_SEGMENT_SIZE - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default WAL file segment size, 64MBytes
DFLT_WAL_SEGMENTS - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
 
DFLT_WAL_SEGMENTS - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
DFLT_WAL_STORE_PATH - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default wal directory.
DFLT_WRITE_ATTEMPTS - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Default value for write attempts.
DFLT_WRITE_BEHIND_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default batch size for write-behind cache store.
DFLT_WRITE_BEHIND_COALESCING - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default write coalescing for write-behind cache store.
DFLT_WRITE_BEHIND_CRITICAL_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default critical size used when flush size is not specified.
DFLT_WRITE_BEHIND_ENABLED - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default value for 'writeBehindEnabled' flag.
DFLT_WRITE_BEHIND_FLUSH_FREQUENCY - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default flush frequency for write-behind cache store in milliseconds.
DFLT_WRITE_BEHIND_FLUSH_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default flush size for write-behind cache store.
DFLT_WRITE_FROM_BEHIND_FLUSH_THREAD_CNT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Default count of flush threads for write-behind cache store.
DFLT_WRITE_THROTTLING_ENABLED - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Default write throttling enabled.
DFLT_WRITE_THROTTLING_ENABLED - Static variable in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Default write throttling enabled.
dht() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
dialect - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Database dialect.
DIRECT_TYPE_SIZE - Static variable in interface org.apache.ignite.plugin.extensions.communication.Message
Direct type size in bytes.
directType() - Method in interface org.apache.ignite.plugin.extensions.communication.Message
Gets message type.
directType() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Gets message type.
directType() - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Gets message type.
DISABLED_CLIENT_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Client nodes might have port 0 if they have no server socket opened.
disableLocal(int...) - Method in interface org.apache.ignite.IgniteEvents
Disables provided events.
disableWal(String) - Method in interface org.apache.ignite.client.ClientCluster
Disables write-ahead logging for specified cache.
disableWal(String) - Method in interface org.apache.ignite.IgniteCluster
Disables write-ahead logging for specified cache.
disconnect() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Tells discovery SPI to disconnect from topology.
disconnect() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Tells discovery SPI to disconnect from topology.
disconnect() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Tells discovery SPI to disconnect from topology.
disconnect() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Tells discovery SPI to disconnect from topology.
DISCOVERY_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
discoveryClientMode() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Deprecated.
Since 2.8. May return incorrect value if client and server nodes shares same TcpDiscoveryIpFinder instance.
DiscoveryDataBag - Class in org.apache.ignite.spi.discovery
Provides interface for GridComponent to collect and exchange discovery data both on joining node and on cluster nodes.
DiscoveryDataBag(UUID, boolean) - Constructor for class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
DiscoveryDataBag(UUID, Set<Integer>, boolean) - Constructor for class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
DiscoveryDataBag.GridDiscoveryData - Interface in org.apache.ignite.spi.discovery
Facade interface representing DiscoveryDataBag object with discovery data collected in the grid.
DiscoveryDataBag.JoiningNodeDiscoveryData - Interface in org.apache.ignite.spi.discovery
Facade interface representing DiscoveryDataBag object with discovery data from joining node.
discoveryEvent() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets discovery event caused topology change.
DiscoveryEvent - Class in org.apache.ignite.events
Grid discovery event.
DiscoveryEvent() - Constructor for class org.apache.ignite.events.DiscoveryEvent
No-arg constructor.
DiscoveryEvent(ClusterNode, String, int, ClusterNode) - Constructor for class org.apache.ignite.events.DiscoveryEvent
Creates new discovery event with given parameters.
discoveryEventName() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets name of discovery event that triggered this rebalancing event.
discoveryEventType() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets type of discovery event that triggered this rebalancing event.
DiscoveryMetricsProvider - Interface in org.apache.ignite.spi.discovery
Provides metrics to discovery SPI.
discoveryNode() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets shadow of the node that triggered this rebalancing event.
DiscoveryNotification - Class in org.apache.ignite.spi.discovery
Discovery notification object.
DiscoveryNotification(int, long, ClusterNode, Collection<ClusterNode>) - Constructor for class org.apache.ignite.spi.discovery.DiscoveryNotification
 
DiscoveryNotification(int, long, ClusterNode, Collection<ClusterNode>, NavigableMap<Long, Collection<ClusterNode>>, DiscoverySpiCustomMessage, SpanContainer) - Constructor for class org.apache.ignite.spi.discovery.DiscoveryNotification
 
DiscoverySpi - Interface in org.apache.ignite.spi.discovery
Grid discovery SPI allows to discover remote nodes in grid.
DiscoverySpiCustomMessage - Interface in org.apache.ignite.spi.discovery
Message to send across ring.
DiscoverySpiDataExchange - Interface in org.apache.ignite.spi.discovery
Handler for initial data exchange between Ignite nodes.
DiscoverySpiHistorySupport - Annotation Type in org.apache.ignite.spi.discovery
This annotation is for all implementations of DiscoverySpi that support topology snapshots history.
DiscoverySpiListener - Interface in org.apache.ignite.spi.discovery
Listener for grid node discovery events.
DiscoverySpiMBean - Interface in org.apache.ignite.spi.discovery
Generic MBean interface to monitor DiscoverySpi subsystem.
DiscoverySpiMutableCustomMessageSupport - Annotation Type in org.apache.ignite.spi.discovery
This annotation is for all implementations of DiscoverySpi that support topology mutable DiscoverySpiCustomMessages.
DiscoverySpiNodeAuthenticator - Interface in org.apache.ignite.spi.discovery
Node authenticator.
DiscoverySpiOrderSupport - Annotation Type in org.apache.ignite.spi.discovery
This annotation is for all implementations of DiscoverySpi that support proper node ordering.
discoveryTimestamp() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets timestamp of discovery event that caused this rebalancing event.
DiskPageCompression - Enum in org.apache.ignite.configuration
Disk page compression options.
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
DoubleMetric - Interface in org.apache.ignite.spi.metric
Interface for the metrics that holds double primitive.
drainPermits() - Method in interface org.apache.ignite.IgniteSemaphore
Acquires and returns all permits that are immediately available.
dropAllConnections() - Method in interface org.apache.ignite.mxbean.ClientProcessorMXBean
Deprecated.
Drop all active connections.
dropConnection(long) - Method in interface org.apache.ignite.mxbean.ClientProcessorMXBean
Deprecated.
Drops client connection by id, if exists.
DumpConsumer - Interface in org.apache.ignite.dump
Consumer of Dump.
dumpDebugInfo() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Dumps debug information for the current node.
dumpDebugInfo() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Dumps debug info using configured logger.
dumpDebugInfo() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Dumps debug info using configured logger.
DumpEntry - Interface in org.apache.ignite.dump
Single cache entry from dump.
dumpNodeStatistics(UUID) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
DumpReader - Class in org.apache.ignite.dump
Dump Reader application.
DumpReader(DumpReaderConfiguration, IgniteLogger) - Constructor for class org.apache.ignite.dump.DumpReader
 
DumpReaderConfiguration - Class in org.apache.ignite.dump
Configuration class of DumpReader.
DumpReaderConfiguration(File, DumpConsumer) - Constructor for class org.apache.ignite.dump.DumpReaderConfiguration
 
DumpReaderConfiguration(File, DumpConsumer, int, Duration, boolean, boolean, String[], boolean, EncryptionSpi) - Constructor for class org.apache.ignite.dump.DumpReaderConfiguration
 
dumpRingStructure() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Dumps ring structure to log.
dumpRoot() - Method in class org.apache.ignite.dump.DumpReaderConfiguration
 
dumpStats() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Dumps SPI per-connection stats to logs.
dumpStats() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Dumps SPI per-connection stats to logs.
duplicateIdError(TcpDiscoveryDuplicateIdMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
duration() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
duration() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
duration() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
durationMax() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
durationMin() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 

E

elapsedTime(TimeUnit) - Method in class org.apache.ignite.client.events.HandshakeFailEvent
Get the elapsed time of the handshake.
elapsedTime(TimeUnit) - Method in class org.apache.ignite.client.events.HandshakeSuccessEvent
Get the elapsed time of the handshake.
elapsedTime(TimeUnit) - Method in class org.apache.ignite.client.events.RequestFailEvent
Get the elapsed time of the request.
elapsedTime(TimeUnit) - Method in class org.apache.ignite.client.events.RequestSuccessEvent
Get the elapsed time of the request.
empty() - Static method in class org.apache.ignite.cache.QueryEntityPatch
Builder method for empty patch.
emptyDataPages() - Method in interface org.apache.ignite.DataRegionMetricsProvider
Calculates empty data pages count for region.
enabledEvents() - Method in interface org.apache.ignite.IgniteEvents
Gets types of enabled events.
enableLocal(int...) - Method in interface org.apache.ignite.IgniteEvents
Enables provided events.
enableManagement(String, boolean) - Method in class org.apache.ignite.cache.CacheManager
enableStatistics(String, boolean) - Method in class org.apache.ignite.cache.CacheManager
enableStatistics(boolean) - Method in interface org.apache.ignite.IgniteCache
Sets statistics enabled flag cluster wide for this cache.
enableStatistics(Collection<String>, boolean) - Method in interface org.apache.ignite.IgniteCluster
Enables/disables statistics for caches cluster wide.
enableWal(String) - Method in interface org.apache.ignite.client.ClientCluster
Enables write-ahead logging for specified cache.
enableWal(String) - Method in interface org.apache.ignite.IgniteCluster
Enables write-ahead logging for specified cache.
encrypt(ByteBuffer, Serializable, ByteBuffer) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Encrypts data.
encrypt(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Encrypts data.
encrypt(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Encrypts data.
encryptedSize(int) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
 
encryptedSize(int) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
encryptedSize(int) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
encryptedSizeNoPadding(int) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
 
encryptedSizeNoPadding(int) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
encryptedSizeNoPadding(int) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
encryption() - Method in interface org.apache.ignite.Ignite
Gets an instance of IgniteEncryption interface.
encryption() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of IgniteEncryption interface.
EncryptionConfiguration - Class in org.apache.ignite.configuration
Encryption configuration.
EncryptionConfiguration() - Constructor for class org.apache.ignite.configuration.EncryptionConfiguration
Creates valid encryption configuration with all default values.
EncryptionConfiguration(EncryptionConfiguration) - Constructor for class org.apache.ignite.configuration.EncryptionConfiguration
Constructs the copy of the configuration.
EncryptionMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use managements API beans, instead.
encryptionSpi() - Method in class org.apache.ignite.dump.DumpReaderConfiguration
 
EncryptionSpi - Interface in org.apache.ignite.spi.encryption
SPI provides encryption features for an Ignite.
encryptKey(Serializable) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Encrypts key.
encryptKey(Serializable, String) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Encrypts a key with the master key specified by name.
encryptKey(Serializable) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Encrypts key.
encryptKey(Serializable, String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Encrypts a key with the master key specified by name.
encryptKey(Serializable) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Encrypts key.
encryptKey(Serializable, String) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Encrypts a key with the master key specified by name.
encryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Encrypts data without padding info.
encryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Encrypts data without padding info.
encryptNoPadding(ByteBuffer, Serializable, ByteBuffer) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Encrypts data without padding info.
end(Connection, Statement) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Closes allocated resources depending on transaction status.
end() - Method in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
Ends span.
end() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
Ends span.
end() - Method in interface org.apache.ignite.spi.tracing.SpiSpecificSpan
Ends span.
endTime() - Method in interface org.apache.ignite.spi.IgniteSpiTimeoutObject
 
endTime() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
ENGINE_NAME - Static variable in class org.apache.ignite.calcite.CalciteQueryEngineConfiguration
Query engine name.
ENGINE_NAME - Static variable in class org.apache.ignite.indexing.IndexingQueryEngineConfiguration
Query engine name.
engineClass() - Method in class org.apache.ignite.calcite.CalciteQueryEngineConfiguration
Query engine class.
engineClass() - Method in class org.apache.ignite.indexing.IndexingQueryEngineConfiguration
Query engine class.
engineName() - Method in class org.apache.ignite.calcite.CalciteQueryEngineConfiguration
Query engine name.
engineName() - Method in class org.apache.ignite.indexing.IndexingQueryEngineConfiguration
Query engine name.
ensured(TcpDiscoveryAbstractMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
EntryMapping(String, JdbcDialect, JdbcType, CacheAbstractJdbcStore.TypeKind, CacheAbstractJdbcStore.TypeKind, boolean) - Constructor for class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
entrySet() - Method in class org.apache.ignite.lang.IgniteBiTuple
enumName() - Method in interface org.apache.ignite.binary.BinaryObject
Get name for this enum object.
enumOrdinal() - Method in interface org.apache.ignite.binary.BinaryObject
Get ordinal for this enum object.
enumValues() - Method in interface org.apache.ignite.binary.BinaryType
 
eq(String, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Equal To.
equals(Object) - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
equals(Object) - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
equals(Object) - Method in class org.apache.ignite.cache.affinity.AffinityKey
Equality check which delegates to the underlying key equality.
equals(Object) - Method in class org.apache.ignite.cache.CacheKeyConfiguration
equals(Object) - Method in class org.apache.ignite.cache.QueryEntity
equals(Object) - Method in class org.apache.ignite.cache.QueryIndex
equals(Object) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
equals(Object) - Method in class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
equals(Object) - Method in class org.apache.ignite.events.EventAdapter
equals(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
equals(Object) - Method in class org.apache.ignite.lang.IgniteProductVersion
equals(Object) - Method in class org.apache.ignite.lang.IgniteUuid
equals(Object) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
equals(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
equals(Object) - Method in class org.apache.ignite.services.ServiceConfiguration
equals(Object) - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
equals(Object) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionKey
equals(Object) - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates
equals(Object) - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters
equalsIgnoreNodeFilter(Object) - Method in class org.apache.ignite.services.ServiceConfiguration
Checks if configurations are equal ignoring the node filter.
ERR_MSG - Static variable in exception org.apache.ignite.cache.query.QueryCancelledException
Error message.
error() - Method in class org.apache.ignite.failure.FailureContext
 
error(String) - Method in interface org.apache.ignite.IgniteLogger
Logs out error message.
error(String, Throwable) - Method in interface org.apache.ignite.IgniteLogger
Logs error message with optional exception.
error(String, String, Throwable) - Method in interface org.apache.ignite.IgniteLogger
Logs error message with optional exception.
error(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out error message.
error(String, Throwable) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs error message with optional exception.
error(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out error message.
error(String, Throwable) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs error message with optional exception.
error(String, Throwable) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs error message with optional exception.
error(String, String, Throwable) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs error message with optional exception.
error(String) - Method in class org.apache.ignite.logger.NullLogger
Logs out error message.
error(String, Throwable) - Method in class org.apache.ignite.logger.NullLogger
Logs error message with optional exception.
error(String, Throwable) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs error message with optional exception.
error(String, String, Throwable) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs error message with optional exception.
escape(String) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
escape(String) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
 
escape(String) - Method in class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
escape(String) - Method in class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
estimateRebalancingFinishTime() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
Event - Interface in org.apache.ignite.events
Grid events are used for notification about what happens within the grid.
EventAdapter - Class in org.apache.ignite.events
Base adapter for the events.
EventAdapter() - Constructor for class org.apache.ignite.events.EventAdapter
No-arg constructor.
EventAdapter(ClusterNode, String, int) - Constructor for class org.apache.ignite.events.EventAdapter
Creates event based with given parameters.
eventNode() - Method in class org.apache.ignite.events.CacheEvent
Gets node which initiated cache operation or null if that node is not available.
eventNode(ClusterNode) - Method in class org.apache.ignite.events.DiscoveryEvent
Sets node this event is referring to.
eventNode() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets node that caused this event to be generated.
eventNode() - Method in class org.apache.ignite.events.NodeValidationFailedEvent
 
events() - Method in interface org.apache.ignite.Ignite
Gets events facade over all cluster nodes.
events(ClusterGroup) - Method in interface org.apache.ignite.Ignite
Gets events facade over nodes within the cluster group.
events() - Method in class org.apache.ignite.IgniteSpringBean
Gets events facade over all cluster nodes.
events(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Gets events facade over nodes within the cluster group.
EventStorageSpi - Interface in org.apache.ignite.spi.eventstorage
This SPI provides local node events storage.
EventType - Interface in org.apache.ignite.events
Contains event type constants.
evict() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Evicts entry associated with given key from cache.
EvictableEntry<K,V> - Interface in org.apache.ignite.cache.eviction
Evictable cache entry passed into EvictionPolicy.
evictAllowed(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.eviction.EvictionFilter
Checks if entry may be evicted from cache.
EvictionFilter<K,V> - Interface in org.apache.ignite.cache.eviction
Eviction filter to specify which entries should not be evicted.
evictionFilter() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
EvictionPolicy<K,V> - Interface in org.apache.ignite.cache.eviction
Pluggable cache eviction policy.
evictionPolicyFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
EVT_BASELINE_AUTO_ADJUST_AWAITING_TIME_CHANGED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: baseline auto-adjust timeout has been changed by user request.
EVT_BASELINE_AUTO_ADJUST_ENABLED_CHANGED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: baseline auto-adjust "enabled" flag has been changed by user request.
EVT_BASELINE_CHANGED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: baseline topology has been changed by either user request or auto-adjust timeout event.
EVT_CACHE_ENTRY_CREATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: entry created.
EVT_CACHE_ENTRY_DESTROYED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: entry destroyed.
EVT_CACHE_ENTRY_EVICTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: entry evicted.
EVT_CACHE_NODES_LEFT - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache nodes left.
EVT_CACHE_OBJECT_EXPIRED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache object was expired when reading it.
EVT_CACHE_OBJECT_LOCKED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: object locked.
EVT_CACHE_OBJECT_PUT - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: object put.
EVT_CACHE_OBJECT_READ - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: object read.
EVT_CACHE_OBJECT_REMOVED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: object removed.
EVT_CACHE_OBJECT_TRANSFORMED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache object was transformed.
EVT_CACHE_OBJECT_UNLOCKED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: object unlocked.
EVT_CACHE_QUERY_EXECUTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: query executed.
EVT_CACHE_QUERY_OBJECT_READ - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: query entry read.
EVT_CACHE_REBALANCE_OBJECT_LOADED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache entry rebalanced.
EVT_CACHE_REBALANCE_OBJECT_UNLOADED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache entry unloaded.
EVT_CACHE_REBALANCE_PART_DATA_LOST - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: all nodes that hold partition left topology.
EVT_CACHE_REBALANCE_PART_LOADED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache partition loaded.
EVT_CACHE_REBALANCE_PART_MISSED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache partition was not sent to remote node.
EVT_CACHE_REBALANCE_PART_SUPPLIED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache partition was fully sent to remote node.
EVT_CACHE_REBALANCE_PART_UNLOADED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache partition unloaded.
EVT_CACHE_REBALANCE_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache rebalance started.
EVT_CACHE_REBALANCE_STOPPED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache rebalance stopped.
EVT_CACHE_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache started.
EVT_CACHE_STOPPED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cache started.
EVT_CHECKPOINT_LOADED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: intermediate state of a job or task, so-called checkpoint, was loaded.
EVT_CHECKPOINT_REMOVED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: intermediate state of a job or task, so-called checkpoint, was removed.
EVT_CHECKPOINT_SAVED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: intermediate state of a job or task, so-called checkpoint, was saved.
EVT_CLASS_DEPLOY_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: non-task class deployment failed.
EVT_CLASS_DEPLOYED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: non-task class deployed.
EVT_CLASS_UNDEPLOYED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: non-task class undeployed.
EVT_CLIENT_NODE_DISCONNECTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: client node disconnected.
EVT_CLIENT_NODE_RECONNECTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: client node reconnected.
EVT_CLUSTER_ACTIVATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster activation state changed.
EVT_CLUSTER_DEACTIVATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster activation state changed.
EVT_CLUSTER_SNAPSHOT_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster snapshot has been failed event.
EVT_CLUSTER_SNAPSHOT_FINISHED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster snapshot has been finished event.
EVT_CLUSTER_SNAPSHOT_RESTORE_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster snapshot restore has been failed event.
EVT_CLUSTER_SNAPSHOT_RESTORE_FINISHED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster snapshot restore has been finished event.
EVT_CLUSTER_SNAPSHOT_RESTORE_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster snapshot restore has been started event.
EVT_CLUSTER_SNAPSHOT_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster snapshot has been started event.
EVT_CLUSTER_STATE_CHANGE_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster state change initiated.
EVT_CLUSTER_STATE_CHANGED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cluster state changed.
EVT_CLUSTER_TAG_UPDATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: cluster tag has been changed by user request.
EVT_CONSISTENCY_VIOLATION - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Cache consistency violation detected.
EVT_JOB_CANCELLED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: grid job cancelled.
EVT_JOB_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: grid job failed.
EVT_JOB_FAILED_OVER - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: grid job failed over.
EVT_JOB_FINISHED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: grid job finished.
EVT_JOB_MAPPED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: grid job was mapped in ComputeTask.map(List, Object) method.
EVT_JOB_QUEUED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: grid job queued.
EVT_JOB_REJECTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: grid job rejected during collision resolution.
EVT_JOB_RESULTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: grid job result was received by ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) method.
EVT_JOB_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: grid job started.
EVT_JOB_TIMEDOUT - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: grid job timed out.
EVT_MANAGEMENT_TASK_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Visor or Web Console management task started.
EVT_NODE_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: node failed.
EVT_NODE_JOINED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: node joined topology.
EVT_NODE_LEFT - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: node has normally left topology.
EVT_NODE_METRICS_UPDATED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: node metrics updated.
EVT_NODE_SEGMENTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: local node segmented.
EVT_NODE_VALIDATION_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: node validation failed.
EVT_PAGE_REPLACEMENT_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: page replacement started in one of the data regions.
EVT_SQL_QUERY_EXECUTION - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: query execution.
EVT_STORAGE_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
EVT_TASK_DEPLOY_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task deployment failed.
EVT_TASK_DEPLOYED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task deployed.
EVT_TASK_FAILED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task failed.
EVT_TASK_FINISHED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task finished.
EVT_TASK_REDUCED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task reduced.
EVT_TASK_SESSION_ATTR_SET - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task session attribute set.
EVT_TASK_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task started.
EVT_TASK_TIMEDOUT - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task timed out.
EVT_TASK_UNDEPLOYED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: task undeployed.
EVT_TX_COMMITTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Transaction has been committed.
EVT_TX_RESUMED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Transaction has been resumed.
EVT_TX_ROLLED_BACK - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Transaction has been rolled back.
EVT_TX_STARTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Transaction has been started.
EVT_TX_SUSPENDED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: Transaction has been suspended.
EVT_WAL_SEGMENT_ARCHIVED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: WAL segment movement to archive folder completed Fired for each completed WAL segment which was moved to archive NOTE: all types in range from 1 to 1000 are reserved for internal Ignite events and should not be used by user-defined events.
EVT_WAL_SEGMENT_COMPACTED - Static variable in interface org.apache.ignite.events.EventType
Built-in event type: WAL archive segment compaction is completed.
EVTS_ALL - Static variable in interface org.apache.ignite.events.EventType
All Ignite events (including metric update event).
EVTS_ALL_MINUS_METRIC_UPDATE - Static variable in interface org.apache.ignite.events.EventType
All Ignite events (excluding metric update event).
EVTS_CACHE - Static variable in interface org.apache.ignite.events.EventType
All cache events.
EVTS_CACHE_LIFECYCLE - Static variable in interface org.apache.ignite.events.EventType
All cache lifecycle events.
EVTS_CACHE_QUERY - Static variable in interface org.apache.ignite.events.EventType
All cache query events.
EVTS_CACHE_REBALANCE - Static variable in interface org.apache.ignite.events.EventType
All cache rebalance events.
EVTS_CHECKPOINT - Static variable in interface org.apache.ignite.events.EventType
All checkpoint events.
EVTS_CLUSTER_ACTIVATION - Static variable in interface org.apache.ignite.events.EventType
All cluster activation events.
EVTS_CLUSTER_SNAPSHOT - Static variable in interface org.apache.ignite.events.EventType
All cluster snapshot events.
EVTS_DEPLOYMENT - Static variable in interface org.apache.ignite.events.EventType
All deployment events.
EVTS_DISCOVERY - Static variable in interface org.apache.ignite.events.EventType
All discovery events except for EventType.EVT_NODE_METRICS_UPDATED.
EVTS_DISCOVERY_ALL - Static variable in interface org.apache.ignite.events.EventType
All discovery events.
EVTS_ERROR - Static variable in interface org.apache.ignite.events.EventType
All events indicating an error or failure condition.
EVTS_JOB_EXECUTION - Static variable in interface org.apache.ignite.events.EventType
All grid job execution events.
EVTS_TASK_EXECUTION - Static variable in interface org.apache.ignite.events.EventType
All grid task execution events.
EVTS_TX - Static variable in interface org.apache.ignite.events.EventType
All Transaction events.
exception() - Method in interface org.apache.ignite.client.ClientRetryPolicyContext
Gets the connection exception that caused current retry iteration.
exchange - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Data exchange.
excludeNode(String) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Exclude node from discovery.
execName() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
execute(String, T) - Method in interface org.apache.ignite.client.ClientCompute
Executes given task within the cluster group.
execute() - Method in interface org.apache.ignite.compute.ComputeJob
Executes this job.
execute(Class<? extends ComputeTask<T, R>>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task on within the cluster group.
execute(ComputeTask<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task within the cluster group.
execute(String, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task within the cluster group.
execute() - Method in interface org.apache.ignite.maintenance.MaintenanceAction
Executes operations of current maintenance action.
execute() - Method in interface org.apache.ignite.services.Service
Starts execution of this service.
execute(ServiceContext) - Method in interface org.apache.ignite.services.Service
Deprecated.
Use Service.execute() instead.
execute(Runnable, int) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
Executes the given command at some time in the future.
execute(Runnable) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
execute(Runnable) - Method in class org.apache.ignite.thread.SameThreadExecutor
executeAsync(String, T) - Method in interface org.apache.ignite.client.ClientCompute
Deprecated.
Use ClientCompute.executeAsync2(String, Object) instead. This method calls ClientCompute.executeAsync2(String, Object) internally, but returns a more limited Future interface.
executeAsync(Class<? extends ComputeTask<T, R>>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task asynchronously on within the cluster group.
executeAsync(ComputeTask<T, R>, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task asynchronously within the cluster group.
executeAsync(String, T) - Method in interface org.apache.ignite.IgniteCompute
Executes given task asynchronously within the cluster group.
executeAsync2(String, T) - Method in interface org.apache.ignite.client.ClientCompute
Executes given task asynchronously within the cluster group.
executeTask(String, String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
A shortcut method that executes given task assuming single java.lang.String argument and java.lang.String return type.
executionId() - Method in interface org.apache.ignite.services.ServiceContext
Gets service execution ID.
executions() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets total number execution of query.
executions() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets total number execution of query.
executions() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
executionTimeMetric(HistogramMetricImpl) - Method in class org.apache.ignite.thread.IgniteThreadPoolExecutor
 
executor() - Method in interface org.apache.ignite.plugin.extensions.communication.IoPool
Gets the Executor for this Pool.
EXECUTOR_SRVC_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
ExecutorConfiguration - Class in org.apache.ignite.configuration
Custom thread pool configuration for compute tasks.
ExecutorConfiguration() - Constructor for class org.apache.ignite.configuration.ExecutorConfiguration
Default constructor.
ExecutorConfiguration(String) - Constructor for class org.apache.ignite.configuration.ExecutorConfiguration
Constructor.
ExecutorConfiguration(ExecutorConfiguration) - Constructor for class org.apache.ignite.configuration.ExecutorConfiguration
Copying constructor.
executorName() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
executorService() - Method in interface org.apache.ignite.Ignite
Creates a new ExecutorService which will execute all submitted Callable and Runnable jobs on all cluster nodes.
executorService(ClusterGroup) - Method in interface org.apache.ignite.Ignite
Creates a new ExecutorService which will execute all submitted Callable and Runnable jobs on nodes in the specified cluster group.
executorService() - Method in class org.apache.ignite.IgniteSpringBean
Creates a new ExecutorService which will execute all submitted Callable and Runnable jobs on all cluster nodes.
executorService(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Creates a new ExecutorService which will execute all submitted Callable and Runnable jobs on nodes in the specified cluster group.
exists(BinaryObject) - Method in interface org.apache.ignite.binary.BinaryField
Check whether field exists in the object.
expireTime() - Method in interface org.apache.ignite.cdc.CdcEvent
 
expireTime() - Method in interface org.apache.ignite.dump.DumpEntry
 
expiryPolicyFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
ExponentialBackoffTimeoutStrategy - Class in org.apache.ignite.spi
Strategy which incorporates retriable network operation, handling of totalTimeout logic.
ExponentialBackoffTimeoutStrategy(long, long, long) - Constructor for class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
 
export() - Method in class org.apache.ignite.spi.metric.log.LogExporterSpi
Callback to do the export of metrics info.
export() - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Callback to do the export of metrics info.
Extension - Interface in org.apache.ignite.plugin
Marker interface for extensions.
ExtensionRegistry - Interface in org.apache.ignite.plugin
Context that allows to register extensions.
externalizableAttributes() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
extract(T) - Method in interface org.apache.ignite.stream.StreamMultipleTupleExtractor
Extracts a set of key-values from a message.
extract(T) - Method in interface org.apache.ignite.stream.StreamSingleTupleExtractor
Extracts a key-value tuple from a message.
extractParameter(String, String, CacheAbstractJdbcStore.TypeKind, String, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Get field value from object for use as query parameter.
extractParameter(String, String, CacheAbstractJdbcStore.TypeKind, String, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Get field value from object for use as query parameter.

F

FAILED_NODE_LIST_ATTR - Static variable in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Name of job context attribute containing all nodes a job failed on.
failedKeys() - Method in exception org.apache.ignite.cache.CachePartialUpdateException
Gets collection of failed keys.
failFast() - Method in class org.apache.ignite.dump.DumpReaderConfiguration
 
failNode(UUID, String) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Initiates failure of provided node.
failNode(UUID, String) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Initiates failure of provided node.
failNode(UUID, String) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Initiates failure of provided node.
failNode(UUID, String) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Initiates failure of provided node.
failNode(UUID, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
failover(FailoverContext, List<ClusterNode>) - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
This method is called when method ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns value ComputeJobResultPolicy.FAILOVER policy indicating that the result of job execution must be failed over.
failover(FailoverContext, List<ClusterNode>) - Method in interface org.apache.ignite.spi.failover.FailoverSpi
This method is called when method ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns value ComputeJobResultPolicy.FAILOVER policy indicating that the result of job execution must be failed over.
failover(FailoverContext, List<ClusterNode>) - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
This method is called when method ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns value ComputeJobResultPolicy.FAILOVER policy indicating that the result of job execution must be failed over.
failover(FailoverContext, List<ClusterNode>) - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
This method is called when method ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns value ComputeJobResultPolicy.FAILOVER policy indicating that the result of job execution must be failed over.
FAILOVER_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
FailoverContext - Interface in org.apache.ignite.spi.failover
This interface defines a set of operations available to failover SPI one a given failed job.
failoverSafe() - Method in class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
failoverSafe() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
FailoverSpi - Interface in org.apache.ignite.spi.failover
Failover SPI provides developer with ability to supply custom logic for handling failed execution of a grid job.
fails() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets total number of times a query execution failed.
FailureContext - Class in org.apache.ignite.failure
Failure context contains information about failure type and exception if applicable.
FailureContext(FailureType, Throwable) - Constructor for class org.apache.ignite.failure.FailureContext
Creates instance of FailureContext.
failureDetectionTimeout() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Returns failure detection timeout set to use for network related operations.
failureDetectionTimeoutEnabled(boolean) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Enables or disables failure detection timeout.
failureDetectionTimeoutEnabled() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Checks whether failure detection timeout is enabled for this IgniteSpi.
FailureHandler - Interface in org.apache.ignite.failure
Provides facility to handle failures by custom user implementations, which can be configured by IgniteConfiguration.setFailureHandler(FailureHandler) method.
FailureHandlingMxBean - Interface in org.apache.ignite.mxbean
MBean that controls critical failure handling.
failures() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets number of times a query execution failed.
failures() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
FailureType - Enum in org.apache.ignite.failure
Types of failures.
fair() - Method in class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
fetchSize - Variable in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Fetch size.
field(String) - Method in interface org.apache.ignite.binary.BinaryObject
Gets field value.
field(String) - Method in interface org.apache.ignite.binary.BinaryType
Get BinaryField for the given field name.
field() - Method in interface org.apache.ignite.cache.query.IndexQueryCriterion
 
fieldId(int, String) - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
Get field ID.
fieldId(int, String) - Method in interface org.apache.ignite.binary.BinaryIdMapper
Gets ID for provided field name.
fieldName(String) - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
Gets field name.
fieldName(String) - Method in interface org.apache.ignite.binary.BinaryNameMapper
Gets field name.
fieldNames() - Method in interface org.apache.ignite.binary.BinaryType
Gets collection of all field names for this binary type.
fields() - Method in class org.apache.ignite.spi.systemview.view.BinaryMetadataView
 
fieldsCount() - Method in interface org.apache.ignite.plugin.extensions.communication.Message
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Gets fields count.
fieldsCount() - Method in class org.apache.ignite.spi.systemview.view.BinaryMetadataView
 
FieldsQueryCursor<T> - Interface in org.apache.ignite.cache.query
SQL query result cursor.
fieldTypeName(String) - Method in interface org.apache.ignite.binary.BinaryType
Gets name of the field type for a given field.
FifoEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction.fifo
Eviction policy based on First In First Out (FIFO) algorithm and supports batch eviction.
FifoEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Constructs FIFO eviction policy with all defaults.
FifoEvictionPolicy(int) - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Constructs FIFO eviction policy with maximum size.
FifoEvictionPolicy(int, int) - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Constructs FIFO eviction policy with maximum size and given batch size.
FifoEvictionPolicyFactory<K,V> - Class in org.apache.ignite.cache.eviction.fifo
Factory class for FifoEvictionPolicy.
FifoEvictionPolicyFactory() - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyFactory
Constructor.
FifoEvictionPolicyFactory(int) - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyFactory
Constructor.
FifoEvictionPolicyFactory(int, int, long) - Constructor for class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyFactory
 
FifoEvictionPolicyMBean - Interface in org.apache.ignite.cache.eviction.fifo
MBean for FIFO eviction policy.
FifoQueueCollisionSpi - Class in org.apache.ignite.spi.collision.fifoqueue
This class provides implementation for Collision SPI based on FIFO queue.
FifoQueueCollisionSpi() - Constructor for class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
 
FifoQueueCollisionSpiMBean - Interface in org.apache.ignite.spi.collision.fifoqueue
Management bean that provides access to the FIFO queue collision SPI configuration.
fileName() - Method in interface org.apache.ignite.IgniteLogger
Gets name of the file being logged to if one is configured or null otherwise.
fileName() - Method in class org.apache.ignite.logger.java.JavaLogger
Gets name of the file being logged to if one is configured or null otherwise.
fileName() - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
Returns current log file.
fileName() - Method in class org.apache.ignite.logger.jcl.JclLogger
Gets name of the file being logged to if one is configured or null otherwise.
fileName() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Gets name of the file being logged to if one is configured or null otherwise.
fileName() - Method in class org.apache.ignite.logger.NullLogger
Gets name of the file being logged to if one is configured or null otherwise.
fileName() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Gets name of the file being logged to if one is configured or null otherwise.
fillKeyParameters(PreparedStatement, int, CacheAbstractJdbcStore.EntryMapping, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
fillKeyParameters(PreparedStatement, CacheAbstractJdbcStore.EntryMapping, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
fillParameter(PreparedStatement, int, JdbcTypeField, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Sets the value of the designated parameter using the given object.
fillValueParameters(PreparedStatement, int, CacheAbstractJdbcStore.EntryMapping, Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
filter() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
filtrableAttributes() - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker
 
FiltrableSystemView<R> - Interface in org.apache.ignite.spi.systemview.view
System view with filtering capabilities.
findKeyType() - Method in class org.apache.ignite.cache.QueryEntity
Attempts to get key type from fields in case it was not set directly.
findManager(Ignite) - Method in class org.apache.ignite.cache.CachingProvider
 
findMetric(String) - Method in interface org.apache.ignite.spi.metric.ReadOnlyMetricRegistry
 
findResource(String) - Method in interface org.apache.ignite.spi.deployment.DeploymentSpi
Finds class loader for the given class.
findResource(String) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Finds class loader for the given class.
findResource(String) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Finds class loader for the given class.
findValueType() - Method in class org.apache.ignite.cache.QueryEntity
Attempts to get value type from fields in case it was not set directly.
finishTime() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
flush() - Method in interface org.apache.ignite.IgniteDataStreamer
Streams any remaining data, but doesn't close the streamer.
flush() - Method in class org.apache.ignite.logger.java.JavaLogger
Flush any buffered output.
flush() - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
flush() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Flush any buffered output.
forAttribute(String, Object) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a new cluster group for nodes containing given name and value specified in user attributes.
forAttribute(String, Object) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a new cluster group for nodes containing given name and value specified in user attributes.
forCache(String) - Method in interface org.apache.ignite.spi.indexing.IndexingQueryFilter
Creates optional predicate for cache.
forCache(String) - Method in class org.apache.ignite.spi.indexing.IndexingQueryFilterImpl
Creates optional predicate for cache.
forCacheNodes(String) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for all nodes that have cache with specified name, either in client or server modes.
forClientNodes(String) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for all client nodes that access cache with the specified name.
forClients() - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group of nodes started in client mode.
forClients() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group of nodes started in client mode.
forDataNodes(String) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for all data nodes that have the cache with the specified name running.
forHost(ClusterNode) - Method in interface org.apache.ignite.client.ClientClusterGroup
Gets cluster group consisting from the nodes in this cluster group residing on the same host (with the same MAC address) as the given node.
forHost(String, String...) - Method in interface org.apache.ignite.client.ClientClusterGroup
Gets cluster group consisting from the nodes running on the hosts specified.
forHost(ClusterNode) - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets cluster group consisting from the nodes in this cluster group residing on the same host as the given node.
forHost(String, String...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets cluster group consisting from the nodes running on the hosts specified.
forLocal() - Method in interface org.apache.ignite.IgniteCluster
Gets a cluster group consisting from the local node.
format(LogRecord) - Method in class org.apache.ignite.logger.java.JavaLoggerFormatter
forNode(ClusterNode, ClusterNode...) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group for the given node.
forNode(ClusterNode, ClusterNode...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for the given node.
forNodeId(UUID, UUID...) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group for a node with the specified ID.
forNodeId(UUID, UUID...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for a node with the specified ID.
forNodeIds(Collection<UUID>) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group over nodes with specified node IDs.
forNodeIds(Collection<UUID>) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group over nodes with specified node IDs.
forNodes(Collection<? extends ClusterNode>) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group over a given set of nodes.
forNodes(Collection<? extends ClusterNode>) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group over a given set of nodes.
forOldest() - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group with one oldest node from the current cluster group.
forOldest() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group with one oldest node from the current cluster group.
forOthers(ClusterNode, ClusterNode...) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group for nodes other than the given nodes.
forOthers(ClientClusterGroup) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group for nodes not included into the given cluster group.
forOthers(ClusterNode, ClusterNode...) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for nodes other than the given nodes.
forOthers(ClusterGroup) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group for nodes not included into the given cluster group.
forPredicate(Predicate<ClusterNode>) - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a new cluster group which includes all nodes that pass the given predicate filter.
forPredicate(IgnitePredicate<ClusterNode>) - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a new cluster group which includes all nodes that pass the given predicate filter.
forRandom() - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group with one random node from the current cluster group.
forRandom() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group with one random node from the current cluster group.
forRemotes() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets cluster group consisting from the nodes in this cluster group excluding the local node.
forServers() - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group of nodes started in server mode.
forServers() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group of nodes started in server mode.
forYoungest() - Method in interface org.apache.ignite.client.ClientClusterGroup
Creates a cluster group with one youngest node in the current cluster group.
forYoungest() - Method in interface org.apache.ignite.cluster.ClusterGroup
Creates a cluster group with one youngest node in the current cluster group.
freeMemory(long) - Method in interface org.apache.ignite.mem.MemoryAllocator
Deallocates memory.
from(CacheEntryProcessor<K, V, Object>) - Static method in class org.apache.ignite.stream.StreamTransformer
Creates a new transformer based on instance of CacheEntryProcessor.
from(IgniteBiInClosure<IgniteCache<K, V>, Map.Entry<K, V>>) - Static method in class org.apache.ignite.stream.StreamVisitor
Creates a new visitor based on instance of IgniteBiInClosure.
fromBytes(byte[]) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Deserialize object from byte array using marshaller.
fromCode(int) - Static method in enum org.apache.ignite.cache.CacheMode
Efficiently gets enumerated value from its code.
fromIndex(short) - Static method in enum org.apache.ignite.spi.tracing.Scope
Created Scope from it's index.
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.CacheAtomicityMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.cache.CachePeekMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.CacheRebalanceMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.CacheWriteSynchronizationMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.cache.PartitionLossPolicy
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.cache.QueryIndexType
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.cluster.ClusterState
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.compute.ComputeJobResultPolicy
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.compute.ComputeTaskSessionScope
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.CheckpointWriteOrder
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.DataPageEvictionMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.DeploymentMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.DiskPageCompression
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.PageReplacementMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.configuration.WALMode
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.IgniteState
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.lifecycle.LifecycleEventType
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.plugin.extensions.communication.MessageCollectionItemType
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.plugin.security.SecurityPermission
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.plugin.security.SecuritySubjectType
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.plugin.segmentation.SegmentationPolicy
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.ShutdownPolicy
Efficiently gets enumerated value from its ordinal.
fromOrdinal(byte) - Static method in enum org.apache.ignite.spi.IgnitePortProtocol
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.transactions.TransactionConcurrency
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.transactions.TransactionIsolation
Efficiently gets enumerated value from its ordinal.
fromOrdinal(int) - Static method in enum org.apache.ignite.transactions.TransactionState
Efficiently gets enumerated value from its ordinal.
fromString(String) - Static method in enum org.apache.ignite.cache.ReadRepairStrategy
Provides strategy by name.
fromString(String) - Static method in class org.apache.ignite.lang.IgniteProductVersion
Tries to parse product version from it's string representation.
fromString(String) - Static method in class org.apache.ignite.lang.IgniteUuid
Converts string into IgniteUuid.
fromString(String) - Method in enum org.apache.ignite.ShutdownPolicy
Return shutdown policy matching to string.
fromUuid(UUID) - Static method in class org.apache.ignite.lang.IgniteUuid
Constructs new IgniteUuid based on global and local ID portions.
FULL_VER_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
fullTableName() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Get full table name.
future() - Method in interface org.apache.ignite.IgniteCompute
Deprecated.
future() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets future for this streaming process.
future() - Method in interface org.apache.ignite.lang.IgniteAsyncSupport
Deprecated.
since 2.0. Please use new specialized async method e.g.
     IgniteFuture f = cache.getAsync();
 
instead of old-style async API:
     IgniteCache asyncCache = cache.withAsync();
     asyncCache.get(key);
     IgniteFuture fut = asyncCache.future();
 

G

get() - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets current value of atomic long.
get(K) - Method in interface org.apache.ignite.client.ClientCache
Gets an entry from the cache.
get() - Method in interface org.apache.ignite.compute.ComputeTaskFuture
Synchronously waits for completion of the computation and returns computation result.
get(long, TimeUnit) - Method in interface org.apache.ignite.compute.ComputeTaskFuture
Synchronously waits for completion of the computation for up to the timeout specified and returns computation result.
get() - Method in interface org.apache.ignite.IgniteAtomicLong
Gets current value of atomic long.
get() - Method in interface org.apache.ignite.IgniteAtomicReference
Gets current value of an atomic reference.
get() - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets current value of atomic sequence.
get() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets both current value and current stamp of atomic stamped.
get(K) - Method in interface org.apache.ignite.IgniteCache
get(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
get() - Method in interface org.apache.ignite.lang.IgniteFuture
Synchronously waits for completion of the computation and returns computation result.
get(long) - Method in interface org.apache.ignite.lang.IgniteFuture
Synchronously waits for completion of the computation for up to the timeout specified and returns computation result.
get(long, TimeUnit) - Method in interface org.apache.ignite.lang.IgniteFuture
Synchronously waits for completion of the computation for up to the timeout specified and returns computation result.
get() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Waits for the completion of the next scheduled execution and returns its result.
get(long, TimeUnit) - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Waits for the completion of the next scheduled execution for specified amount of time and returns its result.
get(String, K) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets object from cache.
get(TracingConfigurationCoordinates) - Method in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Get the most specific tracing parameters for the specified tracing coordinates (scope, label, etc.).
get1() - Method in class org.apache.ignite.lang.IgniteBiTuple
Gets first value.
get2() - Method in class org.apache.ignite.lang.IgniteBiTuple
Gets second value.
getAbsWalSegmentIdx() - Method in class org.apache.ignite.events.WalSegmentArchivedEvent
 
getAccountToken() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
 
getAckSendThreshold() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets number of received messages per connection to node after which acknowledgment message is sent.
getAckTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets message acknowledgement timeout.
getAckTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets message acknowledgement timeout.
getActiveBaselineNodes() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get count of active baseline nodes.
getActiveJobsThreshold() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
getActiveJobsThreshold() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets number of jobs that can be executed in parallel.
getActiveTransactions(Long, Integer, String, String, String, String, Integer, String, boolean, boolean) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Deprecated.
Use managements API beans, instead.
getAddresses() - Method in interface org.apache.ignite.client.ClientAddressFinder
Get addresses of Ignite server nodes within a cluster.
getAddresses() - Method in class org.apache.ignite.client.ThinClientKubernetesAddressFinder
Get addresses of Ignite server nodes within a cluster.
getAddresses() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getAddresses() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getAddressesFinder() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getAddressRequestAttempts() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets number of attempts to send multicast address request.
getAddressResolver() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets address resolver for addresses mapping determination.
getAddressResolver() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets address resolver.
getAffinity() - Method in class org.apache.ignite.configuration.AtomicConfiguration
Gets atomic cache affinity function.
getAffinity() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets key topology resolver to provide mapping from keys to nodes.
getAffinityBackupFilter() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets optional backup filter.
getAffinityKey() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets affinity key used for key-to-node affinity calculation.
getAffinityKeyFieldName() - Method in class org.apache.ignite.cache.CacheKeyConfiguration
Gets affinity key field name.
getAffinityKeyFieldName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
getAffinityMapper() - Method in class org.apache.ignite.configuration.CacheConfiguration
Affinity key mapper used to provide custom affinity key for any given key.
getAlias() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets table alias for type.
getAliases() - Method in class org.apache.ignite.cache.QueryEntity
Gets aliases map.
getAll() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Gets all query results and stores them in the collection.
getAll() - Method in interface org.apache.ignite.cache.query.QueryCursor
Gets all query results and stores them in the collection.
getAll(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Gets a collection of entries from the ClientCache, returning them as Map of the values associated with the set of keys requested.
getAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
getAll(Scope) - Method in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
List all pairs of tracing configuration coordinates and tracing configuration parameters or list all pairs of tracing configuration and parameters for the specific scope.
getAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Gets a collection of entries from the ClientCache, returning them as Map of the values associated with the set of keys requested.
getAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets a collection of entries from the Cache, returning them as Map of the values associated with the set of keys requested.
getAllocationRate() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets pages allocation rate of a memory region.
getAllocationRate() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets pages allocation rate of a memory region.
getAllocationRate() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets pages allocation rate of a memory region.
getAllOutTx(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Gets values from cache.
getAllOutTxAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets values from cache.
getAllOwnerTransactions() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
All near transactions
getAllOwnerTransactions() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets a map of all transactions for which the local node is the originating node.
getAndAdd(long) - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets current value of atomic long and adds l.
getAndAdd(long) - Method in interface org.apache.ignite.IgniteAtomicLong
Gets current value of atomic long and adds l.
getAndAdd(long) - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets current value of atomic sequence and adds l elements.
getAndDecrement() - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets and decrements current value of atomic long.
getAndDecrement() - Method in interface org.apache.ignite.IgniteAtomicLong
Gets and decrements current value of atomic long.
getAndIncrement() - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets and increments current value of atomic long.
getAndIncrement() - Method in interface org.apache.ignite.IgniteAtomicLong
Gets and increments current value of atomic long.
getAndIncrement() - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets and increments current value of atomic sequence.
getAndPut(K, V) - Method in interface org.apache.ignite.client.ClientCache
Associates the specified value with the specified key in this cache, returning an existing value if one existed.
getAndPut(K, V) - Method in interface org.apache.ignite.IgniteCache
getAndPutAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Associates the specified value with the specified key in this cache, returning an existing value if one existed.
getAndPutAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously associates the specified value with the specified key in this cache, returning an existing value if one existed as the future result.
getAndPutIfAbsent(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically associates the specified key with the given value if it is not already associated with a value.
getAndPutIfAbsent(K, V) - Method in interface org.apache.ignite.IgniteCache
Stores given key-value pair in cache only if cache had no previous mapping for it.
getAndPutIfAbsentAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically associates the specified key with the given value if it is not already associated with a value.
getAndPutIfAbsentAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously stores given key-value pair in cache only if cache had no previous mapping for it.
getAndRemove(K) - Method in interface org.apache.ignite.client.ClientCache
Atomically removes the entry for a key only if currently mapped to some value.
getAndRemove(K) - Method in interface org.apache.ignite.IgniteCache
getAndRemoveAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Atomically removes the entry for a key only if currently mapped to some value.
getAndRemoveAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously removes the entry for a key only if currently mapped to some value.
getAndReplace(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the value for a given key if and only if there is a value currently mapped by the key.
getAndReplace(K, V) - Method in interface org.apache.ignite.IgniteCache
getAndReplaceAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the value for a given key if and only if there is a value currently mapped by the key.
getAndReplaceAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously replaces the value for a given key if and only if there is a value currently mapped by the key.
getAndSet(long) - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets current value of atomic long and sets new value l of atomic long.
getAndSet(long) - Method in interface org.apache.ignite.IgniteAtomicLong
Gets current value of atomic long and sets new value l of atomic long.
getApplicationContext() - Method in class org.apache.ignite.IgniteSpringBean
Gets the spring application context this Ignite runs in.
getArchiveFile() - Method in class org.apache.ignite.events.WalSegmentArchivedEvent
 
getArgs() - Method in class org.apache.ignite.cache.query.SpiQuery
Gets SQL arguments.
getArgs() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Gets SQL arguments.
getArgs() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Gets SQL arguments.
getAssemblies() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
 
getAsString() - Method in interface org.apache.ignite.spi.metric.BooleanMetric
getAsString() - Method in interface org.apache.ignite.spi.metric.DoubleMetric
getAsString() - Method in interface org.apache.ignite.spi.metric.IntMetric
getAsString() - Method in interface org.apache.ignite.spi.metric.LongMetric
getAsString() - Method in interface org.apache.ignite.spi.metric.Metric
 
getAsString() - Method in interface org.apache.ignite.spi.metric.ObjectMetric
getAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Gets an entry from the cache asynchronously.
getAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets an entry from the cache.
getAsyncCallbackPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing asynchronous callbacks.
getAsyncContinuationExecutor() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets the async continuation executor.
getAsyncContinuationExecutor() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets the continuation executor for cache async APIs.
getAtomicConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getAtomicityMode() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getAtomicityMode() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
getAtomicityMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache atomicity mode.
getAtomicityMode() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getAtomicSequenceReserveSize() - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Gets default number of sequence values reserved for IgniteAtomicSequence instances.
getAtomicSequenceReserveSize() - Method in class org.apache.ignite.configuration.AtomicConfiguration
Gets default number of sequence values reserved for IgniteAtomicSequence instances.
getAttribute(K) - Method in interface org.apache.ignite.compute.ComputeJobContext
Gets attribute from this job context.
getAttribute(K) - Method in interface org.apache.ignite.compute.ComputeTaskSession
getAttribute(String) - Method in class org.apache.ignite.spi.metric.jmx.MetricRegistryMBean
getAttributeNames() - Method in class org.apache.ignite.cache.affinity.rendezvous.ClusterNodeAttributeAffinityBackupFilter
Gets attribute names.
getAttributes() - Method in interface org.apache.ignite.compute.ComputeJobContext
Gets all attributes present in this job context.
getAttributes() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets all attributes.
getAttributes(String[]) - Method in class org.apache.ignite.spi.metric.jmx.ReadOnlyDynamicMBean
getAuthenticator() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getAutoAdjustmentTimeout() - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
 
getAverageActiveJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average number of active jobs concurrently executing on the node.
getAverageActiveJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average number of active jobs concurrently executing on the node.
getAverageCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average number of cancelled jobs this node ever had running concurrently.
getAverageCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average number of cancelled jobs this node ever had running concurrently.
getAverageCpuLoad() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average of CPU load values over all metrics kept in the history.
getAverageCpuLoad() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average of CPU load values over all metrics kept in the history.
getAverageGetTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute gets.
getAverageJobExecuteTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average time a job takes to execute on the node.
getAverageJobExecuteTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average time a job takes to execute on the node.
getAverageJobWaitTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average time jobs spend waiting in the queue to be executed.
getAverageJobWaitTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average time jobs spend waiting in the queue to be executed.
getAveragePutTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute puts.
getAverageRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average number of jobs this node rejects during collision resolution operations.
getAverageRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average number of jobs this node rejects during collision resolution operations.
getAverageRemoveTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute removes.
getAverageTxCommitTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute tx commit.
getAverageTxRollbackTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute tx rollbacks.
getAverageWaitingJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets average number of waiting jobs this node had queued.
getAverageWaitingJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets average number of waiting jobs this node had queued.
getAvgMessageProcessingTime() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets avg message processing time.
getAvgMessageProcessingTime() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets avg message processing time.
getBackupFilter() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets optional backup filter.
getBackups() - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Gets the number of backup nodes.
getBackups() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getBackups() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
getBackups() - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
getBackups() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets number of nodes used to back up single partition for CacheMode.PARTITIONED cache.
getBackups() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getBalancedNode(ComputeJob, Collection<ClusterNode>) - Method in interface org.apache.ignite.compute.ComputeLoadBalancer
Gets the next balanced node according to the underlying load balancing policy.
getBalancedNode(List<ClusterNode>) - Method in interface org.apache.ignite.spi.failover.FailoverContext
Gets the next balanced node for failed job.
getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Gets balanced node for specified job within given task session.
getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in interface org.apache.ignite.spi.loadbalancing.LoadBalancingSpi
Gets balanced node for specified job within given task session.
getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
Gets balanced node for specified job within given task session.
getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Gets balanced node for specified job within given task session.
getBatchQueueSize() - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Returns batch queue size.
getBatchSize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Gets batch size.
getBatchSize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Gets batch size.
getBatchSize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Gets batch size.
getBatchSize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Gets batch size.
getBatchSize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Gets batch size.
getBatchSize() - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Returns batch size.
getBatchSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Get maximum batch size for delete and delete operations.
getBatchSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Get maximum batch size for write and delete operations.
getBinaryConfiguration() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getBinaryConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets configuration for Ignite Binary objects.
getBinaryConfiguration() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
 
getBinaryMetadataFileStoreDir() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Path to binary metadata dir.
getBoolean(String) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getBoolean(String, boolean) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getBuildIndexThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool for create/rebuild index.
getBusyTimePercentage() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets percentage of time this node is busy executing jobs vs. idling.
getBusyTimePercentage() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets percentage of time this node is busy executing jobs vs. idling.
getCache(String, Class<K>, Class<V>) - Method in class org.apache.ignite.cache.CacheManager
getCache(String) - Method in class org.apache.ignite.cache.CacheManager
getCacheConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets configuration (descriptors) for all caches.
getCacheEntryListenerConfigurations() - Method in class org.apache.ignite.configuration.CacheConfiguration
getCacheEvictions() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of evictions from the cache.
getCacheGets() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of requests to the cache.
getCacheHitPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
This is a measure of cache efficiency.
getCacheHits() - Method in interface org.apache.ignite.cache.CacheMetrics
The number of get requests that were satisfied by the cache.
getCacheKeyConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets cache key configuration.
getCacheManager(URI, ClassLoader, Properties) - Method in class org.apache.ignite.cache.CachingProvider
getCacheManager(URI, ClassLoader) - Method in class org.apache.ignite.cache.CachingProvider
getCacheManager() - Method in class org.apache.ignite.cache.CachingProvider
getCacheMisses() - Method in interface org.apache.ignite.cache.CacheMetrics
A miss is a get request that is not satisfied.
getCacheMissPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
Returns the percentage of cache accesses that did not find a requested entry in the cache.
getCacheMode() - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Gets the cache mode.
getCacheMode() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getCacheMode() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
getCacheMode() - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
getCacheMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets caching mode to use.
getCacheMode() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getCacheName() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets associated cache name.
getCacheName() - Method in class org.apache.ignite.events.CacheConsistencyViolationEvent
Returns cache name.
getCacheName() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets cache name used for key-to-node affinity calculation.
getCacheName() - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Gets cache name to be used by this SPI..
getCacheName() - Method in interface org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpiMBean
Gets cache name to be used by this SPI..
getCacheNames() - Method in class org.apache.ignite.cache.CacheManager
getCachePuts() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of puts to the cache.
getCacheRemovals() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of removals from the cache.
getCacheSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Cache size.
getCacheStoreFactory() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets factory for underlying persistent storage for read-through and write-through operations.
getCacheStoreSessionListenerFactories() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache store session listener factories.
getCacheStoreSessionListenerFactories() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets cache store session listener factories.
getCacheTxCommits() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets total number of transaction commits.
getCacheTxRollbacks() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets total number of transaction rollbacks.
getCachingProvider() - Method in class org.apache.ignite.cache.CacheManager
getCause(Class<T>) - Method in exception org.apache.ignite.IgniteCheckedException
Gets first exception of given class from 'cause' hierarchy if any.
getCause(Class<T>) - Method in exception org.apache.ignite.IgniteException
Gets first exception of given class from 'cause' hierarchy if any.
getCause(Class<T>) - Method in exception org.apache.ignite.IgniteIllegalStateException
Gets first exception of given class from 'cause' hierarchy if any.
getCdcWalDirectoryMaxSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets the CDC directory maximum size in bytes.
getCdcWalPath() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a path to the CDC directory.
getCheckFrequency() - Method in class org.apache.ignite.cdc.CdcConfiguration
 
getCheckpointBufferSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets checkpoint buffer size in bytes.
getCheckpointFrequency() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets checkpoint frequency.
getCheckpointingFrequency() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets checkpointing frequency.
getCheckpointingPageBufferSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets amount of memory allocated for a checkpointing temporary buffer.
getCheckpointingThreads() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets a number of threads to use for the checkpointing purposes.
getCheckpointPageBufferSize() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets amount of memory allocated for a checkpoint temporary buffer.
getCheckpointReadLockTimeout() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Returns timeout for checkpoint read lock acquisition.
getCheckpointReadLockTimeout() - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
getCheckpointSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured checkpoint SPI implementation.
getCheckpointSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.checkpointSpiFormatted" instead.
getCheckpointTableName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets checkpoint table name.
getCheckpointTableName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets checkpoint table name.
getCheckpointThreads() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a number of threads to use for the checkpoint purposes.
getCheckpointWriteOrder() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
This property defines order of writing pages to disk storage during checkpoint.
getCheckpointWriteOrder() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
This property defines order of writing pages to disk storage during checkpoint.
getCipherSuites() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets cipher suites.
getCipherSuites() - Method in class org.apache.ignite.ssl.AbstractSslContextFactory
Gets enabled cipher suites.
getClass(int, ClassLoader) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Gets class for provided type ID.
getClassLoader() - Method in class org.apache.ignite.cache.CacheManager
getClassLoader() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets class loader responsible for loading all classes within task.
getClassLoader() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getClassLoader() - Method in interface org.apache.ignite.spi.deployment.DeploymentResource
Gets resource class loader.
getClassLoader() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
Gets resource class loader.
getClassName() - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Gets class name to use.
getClassName(byte, int) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Gets class name for provided (platformId, typeId) pair.
getClientConfiguration() - Method in class org.apache.ignite.IgniteClientSpringBean
 
getClientConnectorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets client connector configuration.
getClientFailureDetectionTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns failure detection timeout for client nodes used by TcpDiscoverySpi and TcpCommunicationSpi.
getClusterStateOnStart() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets state of cluster on start.
getCollisionSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured collision SPI implementation.
getCollisionSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.collisionSpiFormatted" instead.
getColumnsCount() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Gets number of columns in a row.
getColumnsCount() - Method in interface org.apache.ignite.cache.query.FieldsQueryCursor
Gets number of columns in a row.
getColumnValue(ResultSet, int, Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypesDefaultTransformer
Retrieves the value of the designated column in the current row of this ResultSet object and will convert to the requested Java data type.
getColumnValue(ResultSet, int, Class<?>) - Method in interface org.apache.ignite.cache.store.jdbc.JdbcTypesTransformer
Retrieves the value of the designated column in the current row of this ResultSet object and will convert to the requested Java data type.
getCommErrorProcNum() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets number of communication resolver called.
getCommunicationFailureResolver() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getCommunicationSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured SPI communication implementation.
getCommunicationSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.communicationSpiFormatted" instead.
getComp() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
Gets entries comparator.
getComponentClass() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
 
getConcurrencyLevel() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Returns the number of concurrent segments in Ignite internal page mapping tables.
getConcurrencyLevel() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Returns the number of concurrent segments in Ignite internal page mapping tables.
getConfiguration() - Method in interface org.apache.ignite.client.ClientCache
 
getConfiguration(Class<C>) - Method in interface org.apache.ignite.IgniteCache
getConfiguration() - Method in class org.apache.ignite.IgniteSpringBean
Gets the configuration of this Ignite instance.
getConfigurationAsync() - Method in interface org.apache.ignite.client.ClientCache
Gets the cache configuration asynchronously.
getConflictsMessage() - Method in class org.apache.ignite.cache.QueryEntityPatch
 
getConnection() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
getConnection(String, String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
getConnectionCheckInterval() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets connection check interval in ms.
getConnectionRecoveryTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets timeout that defines how long server node would try to recovery connection.
getConnections() - Method in interface org.apache.ignite.mxbean.ClientProcessorMXBean
Deprecated.
Returns list of active connections.
getConnectionsPerNode() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets number of connections to each remote node. if TcpCommunicationSpiMBean.isUsePairedConnections() is true then number of connections is doubled and half is used for incoming and half for outgoing messages.
getConnectorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getConnectTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets connect timeout used when establishing connection with remote nodes.
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Returns back a list of attributes that should be consistent for this SPI.
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Returns back a list of attributes that should be consistent for this SPI.
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Returns back a list of attributes that should be consistent for this SPI.
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
Returns back a list of attributes that should be consistent for this SPI.
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Returns back a list of attributes that should be consistent for this SPI.
getConsistentAttributeNames() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Returns back a list of attributes that should be consistent for this SPI.
getConsistentId() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets consistent globally unique node ID which survives node restarts.
getConsumer() - Method in class org.apache.ignite.cdc.CdcConfiguration
 
getContext() - Method in class org.apache.ignite.marshaller.AbstractMarshaller
 
getCoordinator() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
getCoordinator() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets current coordinator.
getCoordinator() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets current coordinator.
getCoordinatorNodeFormatted() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets current coordinator node formatted as a string.
getCoordinatorSinceTimestamp() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets time local node has been coordinator since.
getCoordinatorSinceTimestamp() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets time local node has been coordinator since.
getCopyright() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.copyright" instead.
getCriteria() - Method in class org.apache.ignite.cache.query.IndexQuery
Index query criteria.
getCurrentActiveJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets number of currently active jobs concurrently executing on the node.
getCurrentActiveJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets number of currently active jobs concurrently executing on the node.
getCurrentActiveJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Gets current number of jobs that are active, i.e.
getCurrentActiveJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Gets current number of jobs that are active, i.e.
getCurrentActiveJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets current number of jobs that are being executed.
getCurrentActiveJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets current number of jobs that are being executed.
getCurrentActiveJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets current number of jobs that are active, i.e.
getCurrentActiveJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets current number of jobs that are active, i.e.
getCurrentCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets number of cancelled jobs that are still running.
getCurrentCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets number of cancelled jobs that are still running.
getCurrentCoordinatorFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.currentCoordinatorFormatted" instead.
getCurrentCpuLoad() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the CPU usage in [0, 1] range.
getCurrentCpuLoad() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the CPU usage in [0, 1] range.
getCurrentDaemonThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the current number of live daemon threads.
getCurrentDaemonThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the current number of live daemon threads.
getCurrentDirectoryPath() - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Gets path to the directory where all checkpoints are saved.
getCurrentDirectoryPath() - Method in interface org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpiMBean
Gets path to the directory where all checkpoints are saved.
getCurrentGcCpuLoad() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns average time spent in CG since the last update.
getCurrentGcCpuLoad() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns average time spent in CG since the last update.
getCurrentHeldJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Gets number of currently 'held' jobs.
getCurrentHeldJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Gets number of currently 'held' jobs.
getCurrentHeldJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets number of currently 'held' jobs.
getCurrentHeldJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets number of currently 'held' jobs.
getCurrentHeldJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets number of currently 'held' jobs.
getCurrentHeldJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets number of currently 'held' jobs.
getCurrentIdleTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets time this node spend idling since executing last job.
getCurrentIdleTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets time this node spend idling since executing last job.
getCurrentJobExecuteTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets longest time a current job has been executing for.
getCurrentJobExecuteTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets longest time a current job has been executing for.
getCurrentJobsToStealNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets current number of jobs to be stolen.
getCurrentJobsToStealNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets current number of jobs to be stolen.
getCurrentJobWaitTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets current time an oldest jobs has spent waiting to be executed.
getCurrentJobWaitTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets current time an oldest jobs has spent waiting to be executed.
getCurrentMemorySize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Gets current queue size in bytes.
getCurrentMemorySize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Gets current queue size in bytes.
getCurrentMemorySize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Gets current queue size in bytes.
getCurrentMemorySize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Gets current sorted entries queue size in bytes.
getCurrentPmeDuration() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets execution duration for current partition map exchange in milliseconds.
getCurrentPmeDuration() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets execution duration for current partition map exchange in milliseconds.
getCurrentRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets number of jobs rejected after more recent collision resolution operation.
getCurrentRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets number of jobs rejected after more recent collision resolution operation.
getCurrentRunningJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Gets number of currently running (not 'held) jobs.
getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Gets number of currently running (not 'held) jobs.
getCurrentRunningJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets number of currently running (not 'held) jobs.
getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets number of currently running (not 'held) jobs.
getCurrentRunningJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets number of currently running (not 'held) jobs.
getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets number of currently running (not 'held) jobs.
getCurrentSize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
 
getCurrentSize() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Gets current queue size.
getCurrentSize() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Gets current queue size.
getCurrentSize() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Gets current size.
getCurrentThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the current number of live threads including both daemon and non-daemon threads.
getCurrentThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the current number of live threads including both daemon and non-daemon threads.
getCurrentTopologyVersion() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Current topology version.
getCurrentWaitingJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets number of queued jobs currently waiting to be executed.
getCurrentWaitingJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets number of queued jobs currently waiting to be executed.
getCurrentWaitJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Gets current number of jobs that wait for the execution.
getCurrentWaitJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Gets current number of jobs that wait for the execution.
getCurrentWaitJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets current number of jobs that wait for the execution.
getCurrentWaitJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets current number of jobs that wait for the execution.
getCurrentWaitJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets current number of jobs that wait for the execution.
getCurrentWaitJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets current number of jobs that wait for the execution.
getCustomMsgData() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getData() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets data returned by remote job if it didn't fail.
getDatabaseFieldName() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
getDatabaseFieldType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
getDatabaseSchema() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets database schema name.
getDatabaseTable() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets table name in database.
getDataRegionConfigurations() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets an array of all data regions configured.
getDataRegionName() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getDataRegionName() - Method in class org.apache.ignite.configuration.CacheConfiguration
 
getDataSource() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
getDataSource() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
Gets data source.
getDataSourceBean() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets name of the data source bean.
getDataSourceFactory() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets factory for underlying datasource.
getDataSourceInfo() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets data source description.
getDataSourceInfo() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets data source description.
getDataStorageConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets page memory configuration.
getDataStreamerThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing data stream messages.
getDefaultClassLoader() - Method in class org.apache.ignite.cache.CachingProvider
getDefaultDataRegionConfiguration() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getDefaultFieldValues() - Method in class org.apache.ignite.cache.QueryEntity
Gets fields default values.
getDefaultIdMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
getDefaultLockTimeout() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Deprecated.
Default lock timeout configuration property has no effect.
getDefaultLockTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
Default lock timeout configuration property has no effect.
getDefaultMemoryPolicyName() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Gets a name of default memory policy.
getDefaultMemoryPolicySize() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Gets a size for default memory policy overridden by user.
getDefaultNameMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
getDefaultPriority() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets default priority to use if a job does not have priority attribute set.
getDefaultPriority() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets default priority to use if a job does not have priority attribute set.
getDefaultProperties() - Method in class org.apache.ignite.cache.CachingProvider
getDefaultQueryTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getDefaultQueryTimeout() - Method in class org.apache.ignite.configuration.SqlConfiguration
Deprecated.
Since 2.9. Please use distributed default query timeout.
getDefaultSerializer() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
getDefaultTxConcurrency() - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Default transaction concurrency to use when one is not explicitly specified.
getDefaultTxConcurrency() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Default cache transaction concurrency to use when one is not explicitly specified.
getDefaultTxIsolation() - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Default transaction isolation to use when one is not explicitly specified.
getDefaultTxIsolation() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Default cache transaction isolation to use when one is not explicitly specified.
getDefaultTxTimeout() - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Gets default transaction timeout.
getDefaultTxTimeout() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Gets default transaction timeout.
getDefaultURI() - Method in class org.apache.ignite.cache.CachingProvider
getDefaultWarmUpConfiguration() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets default warm-up configuration.
getDefragmentationThreadPoolSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Maximum number of partitions which can be defragmented at the same time.
getDeploymentMode() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets deployment mode for deploying tasks and other classes on this node.
getDeploymentSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured deployment SPI implementation.
getDeploymentSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.deploymentSpiFormatted" instead.
getDhtEvictQueueCurrentSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getDialect() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Get database dialect.
getDialect() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Get database dialect.
getDirectoryPaths() - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Gets collection of all configured paths where checkpoints can be saved.
getDirectoryPaths() - Method in interface org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpiMBean
Gets collection of all configured paths where checkpoints can be saved.
getDirtyPages() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets the number of dirty pages (pages which contents is different from the current persistent storage state).
getDirtyPages() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets the number of dirty pages (pages which contents is different from the current persistent storage state).
getDirtyPages() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets the number of dirty pages (pages which contents is different from the current persistent storage state).
getDisabledTrustManager() - Static method in class org.apache.ignite.ssl.SslContextFactory
Returns an instance of trust manager that will always succeed regardless of certificate provided.
getDiscoveryPort() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
 
getDiscoveryPort() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets discovery port for warmup.
getDiscoverySpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured discovery SPI implementation.
getDiscoverySpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.discoverySpiFormatted" instead.
getDiscoveryStartupDelay() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Not used any more.
getDiskPageCompression() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets disk page compression algorithm.
getDiskPageCompressionLevel() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets algorithm specific disk page compression level.
getDouble(String, double) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getEffectiveSocketTimeout(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets effective or resulting socket timeout with considering failure detection timeout
getEmptyPagesPoolSize() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Specifies the minimal number of empty pages to be present in reuse lists for this data region.
getEmptyPagesPoolSize() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Specifies the minimal number of empty pages to be present in reuse lists for this memory policy.
getEncryptionConfiguration() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets encryyption configuration.
getEncryptionSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets fully configured encryption SPI implementations.
getEndpointAddress() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Get ODBC endpoint address.
getEndTime() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets end of computation time for the task.
getEntries() - Method in class org.apache.ignite.events.CacheConsistencyViolationEvent
Returns a mapping of keys to a collection of original entries.
getEntries(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Gets a collection of entries from the Cache.
getEntriesAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets a collection of entries from the Cache.
getEntry(K) - Method in interface org.apache.ignite.IgniteCache
Gets an entry from the cache.
getEntryAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets an entry from the cache.
getEntryProcessorAverageInvocationTime() - Method in interface org.apache.ignite.cache.CacheMetrics
The mean time to execute cache invokes.
getEntryProcessorHitPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
The percentage of invocations on keys, which exist in cache.
getEntryProcessorHits() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of invocations on keys, which exist in cache.
getEntryProcessorInvocations() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of cache invocations.
getEntryProcessorMaxInvocationTime() - Method in interface org.apache.ignite.cache.CacheMetrics
So far, the maximum time to execute cache invokes.
getEntryProcessorMinInvocationTime() - Method in interface org.apache.ignite.cache.CacheMetrics
So far, the minimum time to execute cache invokes.
getEntryProcessorMisses() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of invocations on keys, which don't exist in cache.
getEntryProcessorMissPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
The percentage of invocations on keys, which don't exist in cache.
getEntryProcessorPuts() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of cache invocations, caused update.
getEntryProcessorReadOnlyInvocations() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of cache invocations, caused no updates.
getEntryProcessorRemovals() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of cache invocations, caused removal.
getEnum(Class<E>, String) - Static method in class org.apache.ignite.IgniteSystemProperties
 
getEnum(String, E) - Static method in class org.apache.ignite.IgniteSystemProperties
 
getEnumValues() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
 
getError() - Method in interface org.apache.ignite.cluster.ClusterStartNodeResult
Gets error message if any.
getEstimatedRebalancingFinishTime() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getEstimatedRebalancingKeys() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getEventListeners() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getEventStorageSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured event SPI implementation.
getEventStorageSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.eventStorageSpiFormatted" instead.
getEvictionFilter() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets eviction filter to specify which entries should not be evicted (except explicit evict by calling IgniteCache.localEvict(Collection)).
getEvictionPolicy() - Method in class org.apache.ignite.configuration.CacheConfiguration
getEvictionPolicyFactory() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache eviction policy factory.
getEvictionRate() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets eviction rate of a given memory region.
getEvictionRate() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets eviction rate of a given memory region.
getEvictionRate() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets eviction rate of a given memory region.
getEvictionThreshold() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets a threshold for memory pages eviction initiation.
getEvictionThreshold() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Gets a threshold for memory pages eviction initiation.
getException() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets exception produced by execution of remote job, or null if remote execution finished normally and did not produce any exceptions.
getExceptionRegistry() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets Exception registry.
getExecutorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets custom executors for user compute tasks.
getExecutorServiceFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.executorServiceFormatted" instead.
getExpireAgeMs() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
getExpireAgeMs() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
Gets event time-to-live value.
getExpireCount() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
getExpireCount() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
Gets maximum event queue size.
getExpireDateFieldName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets expiration date field name for checkpoint table.
getExpireDateFieldName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets expiration date field name for checkpoint table.
getExpireDateFieldType() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets expiration date field type for checkpoint table.
getExpireDateFieldType() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets expiration date field type for checkpoint table.
getExpiryPolicy() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getExternalAddresses(InetSocketAddress) - Method in interface org.apache.ignite.configuration.AddressResolver
Maps internal address to a collection of external addresses.
getExternalAddresses(InetSocketAddress) - Method in class org.apache.ignite.configuration.BasicAddressResolver
Maps internal address to a collection of external addresses.
getFailedConfigurations() - Method in exception org.apache.ignite.services.ServiceDeploymentException
 
getFailoverSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured failover SPI implementation.
getFailoverSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.failoverSpiFormatted" instead.
getFailureDetectionTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns failure detection timeout used by TcpDiscoverySpi and TcpCommunicationSpi.
getFailureHandler() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets failure handler.
getFetchSize() - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Gives the JDBC driver a hint how many rows should be fetched from the database when more rows are needed.
getFetchSize() - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Gives the JDBC driver a hint how many rows should be fetched from the database when more rows are needed.
getField(String) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Returns value assigned to the specified field.
getFieldName(int) - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
Gets field name.
getFieldName(int) - Method in interface org.apache.ignite.cache.query.FieldsQueryCursor
Gets field name.
getFieldNames() - Method in class org.apache.ignite.cache.QueryIndex
 
getFields() - Method in class org.apache.ignite.cache.QueryEntity
Gets query fields for this query pair.
getFields() - Method in class org.apache.ignite.cache.QueryIndex
Gets fields included in the index.
getFieldsPrecision() - Method in class org.apache.ignite.cache.QueryEntity
 
getFieldsScale() - Method in class org.apache.ignite.cache.QueryEntity
 
getFileIOFactory() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Factory to provide implementation of FileIO interface which is used for data storage files read/write operations
getFileIOFactory() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Factory to provide implementation of FileIO interface which is used for any file read/write operations
getFilter() - Method in class org.apache.ignite.cache.query.IndexQuery
Gets remote cache entries filter.
getFilter() - Method in class org.apache.ignite.cache.query.ScanQuery
Gets filter.
getFilter() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Gets filter for events to be recorded.
getFloat(String, float) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getForceClientServerConnections() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
getFromTime() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
The start time interval for the record time in milliseconds.
getFullVersion() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.fullVersion" instead.
getFunc() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Gets the inner func.
getGlobalMemoryQuota() - Method in class org.apache.ignite.calcite.CalciteQueryEngineConfiguration
Gets global heap memory quota for SQL engine.
getGridCount() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets number of grids to start and run warmup.
getGridLogger() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return an instance of logger to use in grid.
getGridLoggerFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.gridLoggerFormatted" instead.
getGridName() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getGridStartTime() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets start time of the very first node in the grid.
getGridStartTime() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Gets start time of the very first node in the grid.
getGridStartTime() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets start time of the very first node in the grid.
getGridStartTime() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Gets start time of the very first node in the grid.
getGroupName() - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Sets the cache group name.
getGroupName() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets the cache group name.
getGroupName() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
getGroupName() - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
getGroupName() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets the cache group name.
getGroupName() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getHandshakeTimeout() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets handshake timeout for client connections.
getHasher() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Gets hash code calculator.
getHasher() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets hash code calculator.
getHeapEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets the number of cache entries in heap memory, including entries held by active transactions, entries in onheap cache and near entries.
getHeapMemoryCommitted() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the amount of heap memory in bytes that is committed for the JVM to use.
getHeapMemoryCommitted() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the amount of heap memory in bytes that is committed for the JVM to use.
getHeapMemoryInitialized() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the amount of heap memory in bytes that the JVM initially requests from the operating system for memory management.
getHeapMemoryInitialized() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the amount of heap memory in bytes that the JVM initially requests from the operating system for memory management.
getHeapMemoryMaximum() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the maximum amount of heap memory in bytes that can be used for memory management.
getHeapMemoryMaximum() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the maximum amount of heap memory in bytes that can be used for memory management.
getHeapMemoryTotal() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the total amount of heap memory in bytes.
getHeapMemoryTotal() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the total amount of heap memory in bytes.
getHeapMemoryUsed() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the current heap size that is used for object allocation.
getHeapMemoryUsed() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the current heap size that is used for object allocation.
getHeartbeatInterval() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets the heartbeat message interval, in milliseconds.
getHoldCount() - Method in interface org.apache.ignite.IgniteLock
Queries the number of holds on this lock by the current thread.
getHost() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Get host.
getHost() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets host for TCP binary protocol server.
getHost() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Get host.
getHostName() - Method in interface org.apache.ignite.cluster.ClusterStartNodeResult
Gets host name.
getId() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets session ID of the task being executed.
getId() - Method in interface org.apache.ignite.mxbean.IgniteClusterMXBean
Deprecated.
Gets cluster ID.
getIdleConnectionTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum idle connection time upon which idle connections will be closed.
getIdleQueryCursorCheckFrequency() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets idle query cursors check frequency.
getIdleQueryCursorTimeout() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets idle query cursors timeout in milliseconds.
getIdleTimeout() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets idle timeout for client connections.
getIdleTimeout() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets idle timeout for REST server.
getIdleTimePercentage() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets percentage of time this node is idling vs. executing jobs.
getIdleTimePercentage() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets percentage of time this node is idling vs. executing jobs.
getIdMapper() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Gets ID mapper.
getIdMapper() - Method in class org.apache.ignite.configuration.BinaryConfiguration
Gets ID mapper.
getIdMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
getIgnite() - Method in class org.apache.ignite.stream.StreamAdapter
 
getIgniteHome() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return Ignite installation home folder.
getIgniteHome() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.igniteHome" instead.
getIgniteHome() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets Ignite installation home folder (i.e.
getIgniteHome() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets Ignite installation home folder (i.e.
getIgniteInstanceName() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets optional local instance name.
getIgniteInstanceName() - Method in class org.apache.ignite.thread.IgniteThread
Gets name of the Ignite instance this thread belongs to.
getIgnoredFailureTypes() - Method in class org.apache.ignite.failure.AbstractFailureHandler
 
getIncludeEventTypes() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets array of event types, which will be recorded.
getIncludeNotReadyAddresses() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
 
getIncludeProperties() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets array of system or environment properties to include into node attributes.
getIndexBuildPartitionsLeftCount() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getIndexedTypes() - Method in class org.apache.ignite.configuration.CacheConfiguration
Array of key and value type pairs to be indexed (thus array length must be always even).
getIndexes() - Method in class org.apache.ignite.cache.QueryEntity
Gets a collection of index entities.
getIndexingSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured indexing SPI implementations.
getIndexName() - Method in class org.apache.ignite.cache.query.IndexQuery
Index name.
getIndexRebuildKeysProcessed() - Method in interface org.apache.ignite.cache.CacheMetrics
Return number of keys processed during index rebuilding.
getIndexType() - Method in class org.apache.ignite.cache.QueryIndex
Gets index type.
getInitialContextEnvironment() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Gets initial context environment map.
getInitialQuery() - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Gets initial query.
getInitialSize() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets initial memory region size defined by this data region.
getInitialSize() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Gets initial memory region size defined by this memory policy.
getInitialSize() - Method in class org.apache.ignite.configuration.SystemDataRegionConfiguration
Initial size of a data region reserved for system cache.
getInlineSize() - Method in class org.apache.ignite.cache.QueryIndex
Gets index inline size in bytes.
getInstanceName() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.InstanceName" instead.
getInteger(String, int) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getInterceptor() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache interceptor.
getInterceptors() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets service call interceptors.
getIpFinder() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets IP finder for IP addresses sharing and storing.
getIpFinderCleanFrequency() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets frequency with which coordinator cleans IP finder and keeps it in the correct state, unregistering addresses of the nodes that have left the topology.
getIpFinderCleanFrequency() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets frequency with which coordinator cleans IP finder and keeps it in the correct state, unregistering addresses of the nodes that have left the topology.
getIpFinderFormatted() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets TcpDiscoveryIpFinder (string representation).
getIpFinderFormatted() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets TcpDiscoveryIpFinder (string representation).
getIterationCount() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets iteration count for warmup.
getJavaFieldName() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
getJavaFieldType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
getJdkInformation() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.jdkInformation" instead.
getJettyPath() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets path, either absolute or relative to IGNITE_HOME, to Jetty XML configuration file.
getJndiNames() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Gets a list of JNDI names.
getJndiNames() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
Gets a list of JNDI names.
getJob() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets local instance of remote job returned by ComputeTask.map(List, Object) method.
getJob() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Job for this context.
getJobContext() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets job context.
getJobContext() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Gets job context.
getJobId() - Method in interface org.apache.ignite.compute.ComputeJobContext
Gets ID of the job this context belongs to.
getJobId() - Method in interface org.apache.ignite.compute.ComputeJobSibling
Gets ID of this grid job sibling.
getJobPriorityAttributeKey() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets key name of job priority attribute.
getJobPriorityAttributeKey() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets key name of job priority attribute.
getJobResult() - Method in interface org.apache.ignite.spi.failover.FailoverContext
Gets failed result of job execution.
getJobSibling(IgniteUuid) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets job sibling for a given ID.
getJobSiblings() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets a collection of all grid job siblings.
getJoinTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Get join timeout, in milliseconds.
getJoinTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
The join timeout, in milliseconds.
getJoinTimeout() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getKeepDeserialized() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Gets keep deserialized flag.
getKey() - Method in class org.apache.ignite.lang.IgniteBiTuple
getKeyAlgorithm() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets algorithm that will be used to create a key manager.
getKeyConfiguration() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getKeyConfiguration() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache key configuration.
getKeyFieldName() - Method in class org.apache.ignite.cache.QueryEntity
Gets key field name.
getKeyFieldName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets key field name for checkpoint table.
getKeyFieldName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets key field name for checkpoint table.
getKeyFields() - Method in class org.apache.ignite.cache.QueryEntity
Gets query fields for this query pair that belongs to the key.
getKeyFields() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets optional persistent key fields (needed only if CacheJdbcPojoStore is used).
getKeyFieldType() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets key field type for checkpoint table.
getKeyFieldType() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets key field type for checkpoint table.
getKeyRange() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets key range.
getKeySize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
Can overflow. Use CacheMetrics.getCacheSize() instead.
getKeySize() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Gets encryption key size.
getKeysToRebalanceLeft() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getKeyStoreFilePath() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets path to the key store file.
getKeyStorePassword() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets key store password.
getKeyStorePath() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Gets path to jdk keyStore that stores master key.
getKeyStorePwd() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Gets key store password.
getKeyStoreType() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets key store type used for context creation.
getKeyType() - Method in interface org.apache.ignite.cache.CacheMetrics
Determines the required type of keys for this Cache, if any.
getKeyType() - Method in class org.apache.ignite.cache.QueryEntity
Gets key type for this query pair.
getKeyType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets key type.
getKeyTypeName() - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Gets fully-qualified platform type name of the cache key used for the local map.
getLargeEntriesPagesPercentage() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
getLargeEntriesPagesPercentage() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
getLargeEntriesPagesPercentage() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
getLastDataVersion() - Method in interface org.apache.ignite.cluster.ClusterMetrics
In-Memory Data Grid assigns incremental versions to all cache operations.
getLastDataVersion() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
In-Memory Data Grid assigns incremental versions to all cache operations.
getLastUpdateTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets last update time of this node metrics.
getLastUpdateTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets last update time of this node metrics.
getLifecycleBeans() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns a collection of life-cycle beans.
getLifecycleBeansFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.lifecycleBeansFormatted" instead.
getLimit() - Method in class org.apache.ignite.cache.query.IndexQuery
Gets limit to response records count.
getLimit() - Method in class org.apache.ignite.cache.query.TextQuery
Gets limit to response records count.
getListener() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
getLivenessCheckEnabled() - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
getLoad(ClusterNode, int) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Calculates load value for a given node.
getLoad(ClusterNode, int) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
Calculates load value for a given node.
getLoad(ClusterNode, int) - Method in interface org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadProbe
Calculates load value for a given node.
getLoad(ClusterNode, int) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
Calculates load value for a given node.
getLoadBalancingSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return fully configured load balancing SPI implementation.
getLoadBalancingSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.loadBalancingSpiFormatted" instead.
getLoadProbeFormatted() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Gets text description of current load probing implementation used.
getLoadProbeFormatted() - Method in interface org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpiMBean
Gets text description of current load probing implementation used.
getLocalAddress() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets local host address for socket binding.
getLocalAddress() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets local address that multicast IP finder uses.
getLocalAddress() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets local address that was set to SPI with TcpDiscoverySpi.setLocalAddress(String) method.
getLocalEventListeners() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets map of pre-configured local event listeners.
getLocalHost() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets system-wide local address or host for all Ignite components to bind to.
getLocalListener() - Method in class org.apache.ignite.cache.query.ContinuousQuery
 
getLocalListener() - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Gets local transformed event listener
getLocalNode() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets local node.
getLocalNode() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Gets local node.
getLocalNode() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets local node.
getLocalNode() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Gets local node.
getLocalNode() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
 
getLocalNodeFormatted() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets local node formatted as a string.
getLocalNodeId() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.localNodeId" instead.
getLocalNodeId() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets ID of the local node.
getLocalNodeId() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets ID of the local node.
getLocalNodeId() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets ID of the local node.
getLocalPort() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets local port for socket binding.
getLocalPort() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets local TCP port SPI listens to.
getLocalPort() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets local TCP port SPI listens to.
getLocalPortRange() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum number of local ports tried if all previously tried ports are occupied.
getLocalPortRange() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets local TCP port range.
getLocalPortRange() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets local TCP port range.
getLockedKeysNumber() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The number of keys locked on the node.
getLockedKeysNumber() - Method in interface org.apache.ignite.transactions.TransactionMetrics
The number of keys locked on the node.
getLockTimeout() - Method in class org.apache.ignite.cdc.CdcConfiguration
 
getLockWaitTime() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Timeout in milliseconds to wait when acquiring persistence store lock file before failing the local node.
getLockWaitTime() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Time out in milliseonds to wait when acquiring persistence store lock file before failing the local node.
getLocNodeAttrs() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getLogger() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets the logger.
getLogger(Object) - Method in interface org.apache.ignite.IgniteLogger
Creates new logger with given category based off the current instance.
getLogger(Object) - Method in class org.apache.ignite.logger.java.JavaLogger
Creates new logger with given category based off the current instance.
getLogger(Object) - Method in class org.apache.ignite.logger.jcl.JclLogger
Creates new logger with given category based off the current instance.
getLogger(Object) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Gets IgniteLogger wrapper around log4j logger for the given category.
getLogger(Object) - Method in class org.apache.ignite.logger.NullLogger
Creates new logger with given category based off the current instance.
getLogger(Object) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Creates new logger with given category based off the current instance.
getLogin() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Gets login.
getLoginTimeout() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
getLogWriter() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
getLong(String, long) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getLongJVMPauseLastEvents() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.longJVMPauseLastEvents" instead.
getLongJVMPausesCount() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.longJVMPausesCount" instead.
getLongJVMPausesTotalDuration() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.longJVMPausesTotalDuration" instead.
getLongOperationsDumpTimeout() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Returns a timeout (in millis) for printing long-running transactions as well as transactions that cannot receive locks for all their keys for a long time.
getLongQueryWarningTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
getLongQueryWarningTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getLongQueryWarningTimeout() - Method in class org.apache.ignite.configuration.SqlConfiguration
Gets timeout in milliseconds after which long query warning will be printed.
getLongRunningOwnerTransactions(int) - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
Long running near transactions
getLongRunningOwnerTransactions(int) - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets a map of all transactions for which the local node is the originating node and which duration exceeds the given duration.
getLongTransactionTimeDumpThreshold() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Returns threshold timeout in milliseconds for long transactions, if transaction exceeds it, it will be dumped in log with information about how much time did it spent in system time (time while aquiring locks, preparing, commiting, etc.)
getMajorVersion() - Method in class org.apache.ignite.IgniteJdbcDriver
getMajorVersion() - Method in class org.apache.ignite.IgniteJdbcThinDriver
getManagementThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing internal and Visor GridJobs.
getMapping() - Method in interface org.apache.ignite.events.CacheConsistencyViolationEvent.EntriesInfo
 
getMarshaller() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Since 2.1. Some Ignite features will not work if non-null marshaller is set (IgniteCache.withKeepBinary(), .NET, CPP, ODBC)
getMarshallerMappingFileStoreDir() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Path to marshaller dir.
getMaster() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
 
getMasterKeyName() - Method in interface org.apache.ignite.IgniteEncryption
Gets the current master key name.
getMasterKeyName() - Method in interface org.apache.ignite.mxbean.EncryptionMXBean
Deprecated.
Gets the current master key name.
getMasterKeyName() - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Gets the current master key name.
getMasterKeyName() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Gets the current master key name.
getMasterKeyName() - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Gets the current master key name.
getMaxAckTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets maximum message acknowledgement timeout.
getMaxAckTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets maximum message acknowledgement timeout.
getMaxActiveComputeTasksPerConnection() - Method in class org.apache.ignite.configuration.ThinClientConfiguration
Gets active compute tasks per connection limit.
getMaxActiveTxPerConnection() - Method in class org.apache.ignite.configuration.ThinClientConfiguration
 
getMaxConcurrentAsyncOperations() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getMaxConcurrentAsyncOperations() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets maximum number of allowed concurrent asynchronous operations.
getMaxConnectTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum connect timeout.
getMaximumActiveJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets maximum number of jobs that ever ran concurrently on this node.
getMaximumActiveJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets maximum number of jobs that ever ran concurrently on this node.
getMaximumCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets maximum number of cancelled jobs this node ever had running concurrently.
getMaximumCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets maximum number of cancelled jobs this node ever had running concurrently.
getMaximumFailoverAttempts() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
getMaximumFailoverAttempts() - Method in interface org.apache.ignite.spi.failover.always.AlwaysFailoverSpiMBean
Gets maximum number of attempts to execute a failed job on another node.
getMaximumFailoverAttempts() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
getMaximumFailoverAttempts() - Method in interface org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpiMBean
Gets maximum number of attempts to execute a failed job on another node.
getMaximumJobExecuteTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets time it took to execute the longest job on the node.
getMaximumJobExecuteTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets time it took to execute the longest job on the node.
getMaximumJobWaitTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets maximum time a job ever spent waiting in a queue to be executed.
getMaximumJobWaitTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets maximum time a job ever spent waiting in a queue to be executed.
getMaximumPoolSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Get Max workers thread count.
getMaximumPoolSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Get maximum workers thread count.
getMaximumRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets maximum number of jobs rejected at once during a single collision resolution operation.
getMaximumRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets maximum number of jobs rejected at once during a single collision resolution operation.
getMaximumStealingAttempts() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
getMaximumStealingAttempts() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets maximum number of attempts to steal job by another node.
getMaximumThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the maximum live thread count since the JVM started or peak was reset.
getMaximumThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the maximum live thread count since the JVM started or peak was reset.
getMaximumWaitingJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets maximum number of waiting jobs this node had.
getMaximumWaitingJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets maximum number of waiting jobs this node had.
getMaximumWriteAttempts() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Gets maximum number of write attempts in case of database error.
getMaximumWriteAttempts() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets maximum number of write attempts in case of database error.
getMaxMemorySize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Gets maximum allowed cache size in bytes.
getMaxMemorySize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Gets maximum allowed cache size in bytes.
getMaxMemorySize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Gets maximum allowed cache size in bytes.
getMaxMemorySize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Gets maximum allowed cache size in bytes.
getMaxMemorySize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Gets maximum allowed cache size in bytes.
getMaxMessageProcessingTime() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets max message processing time.
getMaxMessageProcessingTime() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets max message processing time.
getMaxOpenCursors() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Gets maximum number of opened cursors per connection.
getMaxOpenCursorsPerConnection() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets maximum number of opened cursors per connection.
getMaxOpenCursorsPerConnection() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Gets maximum number of opened cursors per connection.
getMaxParameterCount() - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Get max query parameters count.
getMaxParameterCount() - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Get max query parameters count.
getMaxPerNodeCount() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets maximum number of deployed service instances on each node, 0 for unlimited.
getMaxQueryIteratorsCount() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getMaxQueryIteratorsCount() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets maximum number of query iterators that can be stored.
getMaxSize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Gets maximum allowed size of cache before entry will start getting evicted.
getMaxSize() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Gets maximum allowed size of cache before entry will start getting evicted.
getMaxSize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Gets maximum allowed cache size.
getMaxSize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Gets maximum allowed cache size.
getMaxSize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Gets maximum allowed cache size.
getMaxSize() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Maximum memory region size defined by this data region.
getMaxSize() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Maximum memory region size defined by this memory policy.
getMaxSize() - Method in class org.apache.ignite.configuration.SystemDataRegionConfiguration
Maximum data region size in bytes reserved for system cache.
getMaxWalArchiveSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a max allowed size(in bytes) of WAL archives.
getMBean() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
getMBean() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
getMBean() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
getMBean() - Method in interface org.apache.ignite.mxbean.IgniteMBeanAware
 
getMBeanInfo() - Method in class org.apache.ignite.spi.metric.jmx.MetricRegistryMBean
getMBeanServer() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return MBean server instance.
getMBeanServerFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.mBeanServerFormatted" instead.
getMemoryAllocator() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
 
getMemoryAllocator() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getMemoryConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
getMemoryPolicies() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Gets an array of all memory policies configured.
getMemoryPolicyName() - Method in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
getMessageExpireTime() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
getMessageExpireTime() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Message expire time configuration parameter.
getMessageInterceptor() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets interceptor for objects, moving to and from remote clients.
getMessageQueueLimit() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets message queue limit for incoming and outgoing messages.
getMessageSize() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
getMessageSize() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
getMessageWorkerQueueSize() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets message worker queue current size.
getMessageWorkerQueueSize() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets message worker queue current size.
getMethodName() - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Gets method name.
getMetricExporterSpi() - Method in class org.apache.ignite.cdc.CdcConfiguration
Gets fully configured metric SPI implementations.
getMetricExporterSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets fully configured metric SPI implementations.
getMetricsExpireTime() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Elapsed time in milliseconds after which node metrics are considered expired.
getMetricsHistorySize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Number of node metrics to keep in memory to calculate totals and averages.
getMetricsLogFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets frequency of metrics log print out.
getMetricsRateTimeInterval() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
getMetricsRateTimeInterval() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
getMetricsSubIntervalCount() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
getMetricsSubIntervalCount() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
getMetricsUpdateFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets Ignite metrics update frequency in milliseconds.
getMinorVersion() - Method in class org.apache.ignite.IgniteJdbcDriver
getMinorVersion() - Method in class org.apache.ignite.IgniteJdbcThinDriver
getMinWalArchiveSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a min allowed size(in bytes) of WAL archives.
getMulticastGroup() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets IP address of multicast group.
getMulticastPort() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets port number which multicast messages are sent to.
getMultipleTupleExtractor() - Method in class org.apache.ignite.stream.StreamAdapter
 
getMvccVacuumFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
This is an experimental feature.
getMvccVacuumThreadCount() - Method in class org.apache.ignite.configuration.IgniteConfiguration
This is an experimental feature.
getName() - Method in class org.apache.ignite.cache.QueryIndex
Gets index name.
getName() - Method in interface org.apache.ignite.client.ClientCache
 
getName() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getName() - Method in class org.apache.ignite.configuration.CacheConfiguration
Cache name.
getName() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets data region name.
getName() - Method in class org.apache.ignite.configuration.ExecutorConfiguration
Get thread pool name.
getName() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Gets memory policy name.
getName() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
A name of a memory region the metrics are collected for.
getName() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
A name of a memory region the metrics are collected for.
getName() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
A name of a memory region the metrics are collected for.
getName() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets service name.
getName() - Method in interface org.apache.ignite.spi.deployment.DeploymentResource
Gets resource name, either class name or alias name, such as alias specified by ComputeTaskName annotation.
getName() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
Gets resource name, either class name or alias name, such as alias specified by ComputeTaskName annotation.
getName() - Method in interface org.apache.ignite.spi.IgniteSpi
Gets SPI name.
getName() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets SPI name.
getName() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets name of the SPI.
getName() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets name of the SPI.
getName() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
Gets SPI name.
getNameMapper() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Gets name mapper.
getNameMapper() - Method in class org.apache.ignite.configuration.BinaryConfiguration
Gets name mapper.
getNameMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
getNamespace() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
 
getNativeFactory() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactoryNative
Gets the wrapped factory object.
getNearConfiguration() - Method in class org.apache.ignite.configuration.CacheConfiguration
 
getNearEvictionPolicy() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
getNearEvictionPolicyFactory() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
Gets cache eviction policy factory.
getNearStartSize() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
Gets initial cache size for near cache which will be used to pre-create internal hash table after start.
getNetworkCompressionLevel() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Compression level of internal network messages.
getNetworkSendRetryCount() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Message send retries count.
getNetworkSendRetryDelay() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Interval in milliseconds between message send retries.
getNetworkTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Maximum timeout in milliseconds for network requests.
getNetworkTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets network timeout.
getNetworkTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets network timeout.
getNewValue() - Method in class org.apache.ignite.cache.query.CacheEntryEventAdapter
 
getNode() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets node this job executed on.
getNode() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getNode(UUID) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets node by ID.
getNode(UUID) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Gets node by ID.
getNode(UUID) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets node by ID.
getNode(UUID) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Gets node by ID.
getNode0(UUID) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
getNodeAttributes() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in interface org.apache.ignite.spi.IgniteSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeAttributes() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
This method is called before SPI starts (before method IgniteSpi.spiStart(String) is called).
getNodeFilter() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets filter which determines on what nodes the cache should be started.
getNodeFilter() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
getNodeFilter() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets node filter used to filter nodes on which the service will be deployed.
getNodeId() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
getNodeOrder() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets node join order.
getNodesFailed() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets failed nodes count.
getNodesFailed() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets failed nodes count.
getNodesFailed() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets failed nodes count.
getNodesJoined() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets joined nodes count.
getNodesJoined() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets joined nodes count.
getNodesJoined() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets joined nodes count.
getNodesLeft() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets left nodes count.
getNodesLeft() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets left nodes count.
getNodesLeft() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets left nodes count.
getNodeStartTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the start time of grid node in milliseconds.
getNodeStartTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the start time of grid node in milliseconds.
getNodeWeight() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
getNodeWeight() - Method in interface org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpiMBean
Gets weight of this node.
getNonHeapMemoryCommitted() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the amount of non-heap memory in bytes that is committed for the JVM to use.
getNonHeapMemoryCommitted() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the amount of non-heap memory in bytes that is committed for the JVM to use.
getNonHeapMemoryInitialized() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the amount of non-heap memory in bytes that the JVM initially requests from the operating system for memory management.
getNonHeapMemoryInitialized() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the amount of non-heap memory in bytes that the JVM initially requests from the operating system for memory management.
getNonHeapMemoryMaximum() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the maximum amount of non-heap memory in bytes that can be used for memory management.
getNonHeapMemoryMaximum() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the maximum amount of non-heap memory in bytes that can be used for memory management.
getNonHeapMemoryTotal() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the total amount of non-heap memory in bytes that can be used for memory management.
getNonHeapMemoryTotal() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the total amount of non-heap memory in bytes that can be used for memory management.
getNonHeapMemoryUsed() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the current non-heap memory size that is used by Java VM.
getNonHeapMemoryUsed() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the current non-heap memory size that is used by Java VM.
getNotNullFields() - Method in class org.apache.ignite.cache.QueryEntity
Gets names of fields that must be checked for null.
getNumberOfRetries() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets number of retries in case of DB failure.
getNumberOfRetries() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets number of retries in case of DB failure.
getOdbcConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getOffHeapAllocatedSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets memory size allocated in off-heap.
getOffHeapBackupEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of backup entries stored in off-heap memory.
getOffHeapEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of entries stored in off-heap memory.
getOffHeapEvictions() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of evictions from the off-heap memory.
getOffHeapGets() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of get requests to the off-heap memory.
getOffHeapHitPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets the percentage of hits on off-heap memory.
getOffHeapHits() - Method in interface org.apache.ignite.cache.CacheMetrics
The number of get requests that were satisfied by the off-heap memory.
getOffHeapMaxMemory() - Method in class org.apache.ignite.configuration.CollectionConfiguration
Deprecated.
No longer used.
getOffHeapMisses() - Method in interface org.apache.ignite.cache.CacheMetrics
A miss is a get request that is not satisfied by off-heap memory.
getOffHeapMissPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets the percentage of misses on off-heap memory.
getOffHeapPrimaryEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of primary entries stored in off-heap memory.
getOffHeapPuts() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of put requests to the off-heap memory.
getOffHeapRemovals() - Method in interface org.apache.ignite.cache.CacheMetrics
The total number of removals from the off-heap memory.
getOffHeapSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Total offheap size in bytes.
getOffheapUsedSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Total used offheap size in bytes.
getOrCreateCache(String) - Method in interface org.apache.ignite.client.IgniteClient
Gets the existing cache or creates a new cache with default configuration if it does not exist.
getOrCreateCache(ClientCacheConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Gets the existing cache or creates a new cache if it does not exist.
getOrCreateCache(CacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Gets existing cache with the given name or creates new one with the given configuration.
getOrCreateCache(String) - Method in interface org.apache.ignite.Ignite
Gets existing cache with the given name or creates new one using template configuration.
getOrCreateCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Gets existing cache with the given cache configuration or creates one if it does not exist.
getOrCreateCache(String) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets the existing cache or creates a new cache with default configuration if it does not exist.
getOrCreateCache(ClientCacheConfiguration) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets the existing cache or creates a new cache if it does not exist.
getOrCreateCache(CacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Gets existing cache with the given name or creates new one with the given configuration.
getOrCreateCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Gets existing cache with the given cache configuration or creates one if it does not exist.
getOrCreateCache(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets existing cache with the given name or creates new one using template configuration.
getOrCreateCacheAsync(String) - Method in interface org.apache.ignite.client.IgniteClient
Gets the existing cache or creates a new cache with default configuration if it does not exist.
getOrCreateCacheAsync(ClientCacheConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Gets the existing cache or creates a new cache if it does not exist.
getOrCreateCacheAsync(String) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets the existing cache or creates a new cache with default configuration if it does not exist.
getOrCreateCacheAsync(ClientCacheConfiguration) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets the existing cache or creates a new cache if it does not exist.
getOrCreateCaches(Collection<CacheConfiguration>) - Method in interface org.apache.ignite.Ignite
Gets existing caches with the given name or created one with the given configuration.
getOrCreateCaches(Collection<CacheConfiguration>) - Method in class org.apache.ignite.IgniteSpringBean
Gets existing caches with the given name or created one with the given configuration.
getOrCreateCondition(String) - Method in interface org.apache.ignite.IgniteLock
Returns a Condition instance for use with this IgniteLock instance.
getOrCreateMetricRegistry(String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Returns existing or newly created instance of metric registry with given name.
getOrCreateNearCache(String, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
Gets existing near cache with the given name or creates a new one.
getOrCreateNearCache(String, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
Gets existing near cache with the given name or creates a new one.
getOriginal() - Method in class org.apache.ignite.events.CacheObjectTransformedEvent
 
getOrStart(IgniteConfiguration) - Static method in class org.apache.ignite.Ignition
Gets or starts new grid instance if it hasn't been started yet.
getOsInformation() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.osInformation" instead.
getOsUser() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.osUser" instead.
getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets outbound messages queue size.
getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets outbound messages queue size.
getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Gets outbound messages queue size.
getOutboundMessagesQueueSize() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets outbound messages queue size.
getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets outbound messages queue size.
getOwnerTransactionsNumber() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The number of active transactions for which this node is the initiator.
getOwnerTransactionsNumber() - Method in interface org.apache.ignite.transactions.TransactionMetrics
The number of active transactions for which this node is the initiator.
getPageEvictionMode() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets memory pages eviction mode.
getPageEvictionMode() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Gets memory pages eviction mode.
getPageReplacementMode() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets memory pages replacement mode.
getPages() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Return pages for searching in format grpId:pageId.
getPagesFillFactor() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Returns the ratio of space occupied by user and system data to the size of all pages that contain this data.
getPagesFillFactor() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets the percentage of space that is still free and can be filled in.
getPagesFillFactor() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets the percentage of space that is still free and can be filled in.
getPageSize() - Method in class org.apache.ignite.cache.query.Query
Gets optional page size, if 0, then default is used.
getPageSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
The page memory consists of one or more expandable data regions defined by DataRegionConfiguration.
getPageSize() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
The pages memory consists of one or more expandable memory regions defined by MemoryPolicyConfiguration.
getPageSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets memory page size.
getPageSize() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Size of pages, which was selected for file store (1024, 2048, 4096, etc).
getPagesRead() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
The number of read pages from last restart.
getPagesReplaceAge() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets average age (in milliseconds) for the pages being replaced from the disk storage.
getPagesReplaced() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
The number of replaced pages from last restart .
getPagesReplaceRate() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
getPagesReplaceRate() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
getPagesReplaceRate() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
getPagesWritten() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
The number of written pages from last restart.
getParallelJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
getParallelJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Gets number of jobs that can be executed in parallel.
getParallelJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets number of jobs that can be executed in parallel.
getParallelJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets number of jobs that can be executed in parallel.
getParallelLoadCacheMinimumThreshold() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Parallel load cache minimum row count threshold.
getParallelLoadCacheMinimumThreshold() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Parallel load cache minimum row count threshold.
getParentLogger() - Method in class org.apache.ignite.IgniteJdbcDriver
getParentLogger() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
getParentLogger() - Method in class org.apache.ignite.IgniteJdbcThinDriver
getPartition() - Method in class org.apache.ignite.cache.query.IndexQuery
Gets partition number over which this query should iterate.
getPartition() - Method in class org.apache.ignite.cache.query.ScanQuery
Gets partition number over which this query should iterate.
getPartitionAwarenessMapperFactory() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getPartitionLossPolicy() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getPartitionLossPolicy() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets partition loss policy.
getPartitions() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets total number of key partitions.
getPartitions() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
 
getPartitions() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
 
getPartitionUpdateCounter() - Method in class org.apache.ignite.cache.CacheInterceptorEntry
Each cache update increases partition counter.
getPartitionUpdateCounter() - Method in class org.apache.ignite.cache.query.CacheQueryEntryEvent
Each cache update increases partition counter.
getPassword() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getPassword() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Gets password.
getPatchOperations() - Method in class org.apache.ignite.cache.QueryEntityPatch
 
getPath() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Gets path.
getPeerClassLoadingLocalClassPathExclude() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return list of packages from the system classpath that need to be peer-to-peer loaded from task originating node. '*' is supported at the end of the package name which means that all sub-packages and their classes are included like in Java package import clause.
getPeerClassLoadingMissedResourcesCacheSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns missed resources cache size.
getPeerClassLoadingThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool which is in charge of peer class loading requests/responses.
getPendingMessagesDiscarded() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets pending messages discarded count.
getPendingMessagesDiscarded() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets pending messages discarded count.
getPendingMessagesRegistered() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets pending messages registered count.
getPendingMessagesRegistered() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets pending messages registered count.
getPersistentStoreConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Part of old API. Use DataStorageConfiguration for configuring persistence instead.
getPersistentStorePath() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
getPessimisticTxLogLinger() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Deprecated.
Pessimistic tx log linger property has no effect.
getPessimisticTxLogSize() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Deprecated.
Pessimistic tx log size property has no effect.
getPhase() - Method in class org.apache.ignite.IgniteClientSpringBean
getPhysicalMemoryPages() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets total number of pages currently loaded to the RAM.
getPhysicalMemoryPages() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets total number of pages currently loaded to the RAM.
getPhysicalMemoryPages() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets total number of pages currently loaded to the RAM.
getPhysicalMemorySize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets total size of pages loaded to the RAM.
getPlatformCacheConfiguration() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets platform cache configuration.
getPlatformConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets platform configuration.
getPluginConfigurations() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets array of cache plugin configurations.
getPluginConfigurations() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
getPluginProviders() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets plugin providers.
getPort() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Get port.
getPort() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets port for TCP binary protocol server.
getPort() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Get port.
getPortRange() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Get port range.
getPortRange() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets number of ports to try if configured port is already in use.
getPortRange() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Get port range.
getPriorityAttributeKey() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets key name of task priority attribute.
getPriorityAttributeKey() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets key name of task priority attribute.
getProcessedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets processed messages counts (grouped by type).
getProcessedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets processed messages counts (grouped by type).
getProcessorCoefficient() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Gets coefficient of every CPU processor.
getProcessSensitiveData() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Strategy for the processing of sensitive data (SHOW, HIDE, HASH, MD5).
getProperties() - Method in class org.apache.ignite.cache.CacheManager
getProperties() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
Gets a map of properties.
getProperties() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Get properties.
getProperties() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
Get properties.
getProperties() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Get properties.
getPropertyInfo(String, Properties) - Method in class org.apache.ignite.IgniteJdbcDriver
getPropertyInfo(String, Properties) - Method in class org.apache.ignite.IgniteJdbcThinDriver
getProtocol() - Method in class org.apache.ignite.ssl.AbstractSslContextFactory
Gets protocol for secure transport.
getProtocols() - Method in class org.apache.ignite.ssl.AbstractSslContextFactory
Gets enabled protocols.
getPublicThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return a thread pool size to be used in grid.
getPwd() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets checkpoint jdbc password.
getPwd() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets checkpoint jdbc password.
getQueryDetailMetricsSize() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getQueryDetailMetricsSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets size of queries detail metrics that will be stored in memory for monitoring purposes.
getQueryEnginesConfiguration() - Method in class org.apache.ignite.configuration.SqlConfiguration
Gets query engines configuration.
getQueryEntities() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getQueryEntities() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets a collection of configured query entities.
getQueryInitiatorId() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
 
getQueryMemoryQuota() - Method in class org.apache.ignite.calcite.CalciteQueryEngineConfiguration
Gets per-query heap memory quota.
getQueryParallelism() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getQueryParallelism() - Method in class org.apache.ignite.configuration.CacheConfiguration
Defines a hint to query execution engine on desired degree of parallelism within a single node.
getQueryThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing query messages.
getQueueLength() - Method in interface org.apache.ignite.IgniteSemaphore
Returns an estimate of the number of nodes waiting to acquire.
getQueueSize() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Gets current queue size of the event queue.
getQueueSize() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
Gets current queue size of the event queue.
getRateTimeInterval() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
getRateTimeInterval() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
getRebalanceBatchesPrefetchCount() - Method in class org.apache.ignite.client.ClientCacheConfiguration
getRebalanceBatchesPrefetchCount() - Method in class org.apache.ignite.configuration.CacheConfiguration
getRebalanceBatchesPrefetchCount() - Method in class org.apache.ignite.configuration.IgniteConfiguration
The number of batches generated by supply node at rebalancing procedure start.
getRebalanceBatchSize() - Method in class org.apache.ignite.client.ClientCacheConfiguration
getRebalanceBatchSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
getRebalanceBatchSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
The supply message size in bytes to be loaded within a single rebalance batch.
getRebalanceClearingPartitionsLeft() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getRebalanceDelay() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Deprecated.
Use baseline topology feature instead. Please, be aware this API will be removed in the next releases.
getRebalanceDelay() - Method in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
Use baseline topology feature instead. Please, be aware this API will be removed in the next releases.
getRebalancedKeys() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getRebalanceMode() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets rebalance mode.
getRebalanceMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets rebalance mode for distributed cache.
getRebalanceOrder() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getRebalanceOrder() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets cache rebalance order.
getRebalanceThreadPoolSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
getRebalanceThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets Max count of threads can be used at rebalancing.
getRebalanceThrottle() - Method in class org.apache.ignite.client.ClientCacheConfiguration
getRebalanceThrottle() - Method in class org.apache.ignite.configuration.CacheConfiguration
getRebalanceThrottle() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network.
getRebalanceTimeout() - Method in class org.apache.ignite.client.ClientCacheConfiguration
getRebalanceTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
getRebalanceTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Rebalance timeout for supply and demand messages in milliseconds.
getRebalancingBytesRate() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getRebalancingKeysRate() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getRebalancingPartitionsCount() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getRebalancingStartTime() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getReceiveBufferSize() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getReceiveBufferSize() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets REST TCP server receive buffer size in bytes.
getReceivedBytesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets received bytes count.
getReceivedBytesCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets received bytes count.
getReceivedBytesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Gets received bytes count.
getReceivedBytesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets received bytes count.
getReceivedBytesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets received bytes count.
getReceivedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets received messages counts (grouped by type).
getReceivedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets received messages counts (grouped by type).
getReceivedMessagesByNode() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets received messages counts (grouped by node).
getReceivedMessagesByNode() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets received messages counts (grouped by node).
getReceivedMessagesByType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets received messages counts (grouped by type).
getReceivedMessagesByType() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets received messages counts (grouped by type).
getReceivedMessagesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets received messages count.
getReceivedMessagesCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets received messages count.
getReceivedMessagesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Gets received messages count.
getReceivedMessagesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets received messages count.
getReceivedMessagesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets received messages count.
getReconnectCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum number of reconnect attempts used when establishing connection with remote nodes.
getReconnectCount() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets number of connection attempts.
getReconnectCount() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets number of connection attempts.
getReconnectDelay() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets the amount of time in milliseconds that node waits before retrying to (re)connect to the cluster.
getReconnectThrottlingPeriod() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getReconnectThrottlingRetries() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getRecordContainsText() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Filter by substring in the WAL record.
getRecordTypes() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
WAL record types (TX_RECORD, DATA_RECORD, etc).
getReencryptionBatchSize() - Method in class org.apache.ignite.configuration.EncryptionConfiguration
Gets the number of pages that is scanned during re-encryption under checkpoint lock.
getReencryptionRateLimit() - Method in class org.apache.ignite.configuration.EncryptionConfiguration
Gets re-encryption rate limit.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Gets all addresses registered in this finder.
getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Gets all addresses registered in this finder.
getRemoteFilter() - Method in class org.apache.ignite.cache.query.ContinuousQuery
Gets remote filter.
getRemoteFilterFactory() - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Gets remote filter.
getRemoteNodes() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
getRemoteNodes() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
getRemoteNodes() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
getRemoteNodes() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
getRemoteTransformerFactory() - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Gets remote transformer factory
getRepairedEntries() - Method in class org.apache.ignite.events.CacheConsistencyViolationEvent
Returns a mapping of keys to a collection of repaired entries.
getResourceClass() - Method in interface org.apache.ignite.spi.deployment.DeploymentResource
Gets resource class.
getResourceClass() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
Gets resource class.
getResponseWaitTime() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Gets time in milliseconds IP finder waits for reply to multicast address request.
getRetryLimit() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getRetryPolicy() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets the retry policy.
getScanners() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Gets scanners.
getSchema() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Get schema for the query.
getSchema() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getSecretKey() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets secret key to authenticate REST requests.
getSegmentationPolicy() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns segmentation policy.
getSegmentationResolveAttempts() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets segmentation resolve attempts.
getSegmentationResolvers() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns a collection of segmentation resolvers.
getSegmentCheckFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns frequency of network segment check by discovery manager.
getSelectorCount() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Get count of selectors to use in TCP server.
getSelectorCount() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets number of selector threads in REST TCP server.
getSelectorsCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets count of selectors used in TCP server.
getSelectorSpins() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Defines how many non-blocking selector.selectNow() should be made before falling into selector.select(long) in NIO server.
getSendBufferSize() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSendBufferSize() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets REST TCP server send buffer size.
getSendQueueLimit() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets REST TCP server send queue limit.
getSentBytesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets sent bytes count.
getSentBytesCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets sent bytes count.
getSentBytesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Gets sent bytes count.
getSentBytesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets sent bytes count.
getSentBytesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets sent bytes count.
getSentMessagesByNode() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets sent messages counts (grouped by node).
getSentMessagesByNode() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets sent messages counts (grouped by node).
getSentMessagesByType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets sent messages counts (grouped by type).
getSentMessagesByType() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets sent messages counts (grouped by type).
getSentMessagesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets sent messages count.
getSentMessagesCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets sent messages count.
getSentMessagesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Gets sent messages count.
getSentMessagesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets sent messages count.
getSentMessagesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets sent messages count.
getSerializer() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Gets serializer.
getSerializer() - Method in class org.apache.ignite.configuration.BinaryConfiguration
Gets serializer.
getSerializer() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
getService() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets service instance.
getServiceConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets configurations for services to be deployed on the grid.
getServiceName() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
 
getServiceThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return a thread pool size to be used in grid.
getSessionOutboundMessageQueueLimit() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
 
getSessionTimeout() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getSharedMemoryPort() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Deprecated.
This property will be removed in future releases.
getShutdownPolicy() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets shutdown policy.
getSingleTupleExtractor() - Method in class org.apache.ignite.stream.StreamAdapter
 
getSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
Can overflow. Use CacheMetrics.getCacheSize() instead.
getSize() - Method in class org.apache.ignite.configuration.ExecutorConfiguration
Get thread pool size.
getSlowClientQueueLimit() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets slow client queue limit.
getSnapshotPath() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getSnapshotThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
getSocketReceiveBuffer() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getSocketReceiveBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets receive buffer size for sockets created or accepted by this SPI.
getSocketReceiveBufferSize() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets socket receive buffer size.
getSocketReceiveBufferSize() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Gets socket receive buffer size.
getSocketReceiveBufferSize() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Gets socket receive buffer size.
getSocketSendBuffer() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getSocketSendBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets send buffer size for sockets created or accepted by this SPI.
getSocketSendBufferSize() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets socket send buffer size.
getSocketSendBufferSize() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Gets socket send buffer size.
getSocketSendBufferSize() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Gets socket send buffer size.
getSocketTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets socket timeout.
getSocketTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets socket timeout.
getSocketWriteTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets socket write timeout for TCP connections.
getSoLinger() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets SO_LINGER timeout for socket.
getSpanContainer() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getSpiContext() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Gets SPI context.
getSpiContext() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets SPI context.
getSpiContext() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets SPI context.
getSpiState() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiMBean
Gets current SPI state.
getSpiState() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets current SPI state.
getSpiState() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets current SPI state.
getSql() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Gets SQL clause.
getSql() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Gets SQL clause.
getSqlConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets Configuration of the SQL subsystem.
getSqlConnectorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getSqlFunctionClasses() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets classes with methods annotated by QuerySqlFunction to be used as user-defined functions from SQL queries.
getSqlIndexMaxInlineSize() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getSqlIndexMaxInlineSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets maximum inline size for sql indexes.
getSqlOnheapCacheMaxSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets maximum SQL on-heap cache.
getSqlQueryHistorySize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
getSqlQueryHistorySize() - Method in class org.apache.ignite.configuration.SqlConfiguration
Number of SQL query history elements to keep in memory.
getSqlSchema() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getSqlSchema() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets custom name of the sql schema.
getSqlSchemas() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
getSqlSchemas() - Method in class org.apache.ignite.configuration.SqlConfiguration
Gets SQL schemas to be created on node startup.
getSslClientCertificateKeyStorePassword() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslClientCertificateKeyStorePassword() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets key store password.
getSslClientCertificateKeyStorePath() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslClientCertificateKeyStoreType() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslClientCertificateKeyStoreType() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets key store type used for context creation.
getSslClientCertificateKeyStoreUrl() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets the key store URL.
getSslContextFactory() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslContextFactory() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Returns SSL context factory that will be used for creating a secure socket layer.
getSslContextFactory() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns SSL context factory that will be used for creating a secure socket layer.
getSslFactory() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets context factory that will be used for creating a secure socket layer of rest binary server.
getSslFactory() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets the class name of the custom implementation of the Factory<SSLSocketFactory>.
getSslKeyAlgorithm() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslKeyAlgorithm() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets algorithm that will be used to create a key manager.
getSslMode() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslMode() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets SSL connection mode.
getSslProtocol() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslProtocol() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets protocol for secure transport.
getSslTrustCertificateKeyStorePassword() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslTrustCertificateKeyStorePassword() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets trust store password.
getSslTrustCertificateKeyStorePath() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslTrustCertificateKeyStoreType() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getSslTrustCertificateKeyStoreType() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets trust store type.
getSslTrustCertificateKeyStoreUrl() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets the trust store URL.
getStartTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the start time of the JVM in milliseconds.
getStartTime() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets start of computation time for the task.
getStartTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the start time of the JVM in milliseconds.
getStartTimestamp() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.startTimestamp" instead.
getStartTimestamp() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Get start timestamp of this SPI.
getStartTimestamp() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Get start timestamp of this SPI.
getStartTimestampFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.startTimestampFormatted" instead.
getStartTimestampFormatted() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets string presentation of the start timestamp.
getStartTimestampFormatted() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets string presentation of the start timestamp.
getStarvationIncrement() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets value to increment job priority by every time a lower priority job gets behind a higher priority job.
getStarvationIncrement() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets value to increment job priority by every time a lower priority job gets behind a higher priority job.
getState() - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Gets state of default grid instance.
getState(String) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Gets state for a given grid instance.
getStatisticsPrintFrequency() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets statistics print frequency.
getStatisticsPrintFrequency() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets statistics print frequency.
getStealingAttributes() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
getStealingAttributes() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Configuration parameter to enable stealing to/from only nodes that have these attributes set (see ClusterNode.attribute(String) and IgniteConfiguration.getUserAttributes() methods).
getStoragePath() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getStoreConcurrentLoadAllThreshold() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets the threshold used in cases when values for multiple keys are being loaded from an underlying CacheStore in parallel.
getStrategy() - Method in class org.apache.ignite.events.CacheConsistencyViolationEvent
Returns strategy.
getStreamer() - Method in class org.apache.ignite.stream.StreamAdapter
 
getString(String) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getString(String, String) - Static method in class org.apache.ignite.IgniteSystemProperties
Gets either system property or environment variable with given name.
getStripedPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns striped pool size that should be used for cache requests processing.
getSubIntervals() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
getSubIntervals() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
getSwapFilePath() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
A path to the memory-mapped files the memory region defined by this memory policy will be mapped to.
getSwapPath() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
A path to the memory-mapped files the memory region defined by this data region will be mapped to.
getSystemCacheInitialSize() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Initial size of a memory region reserved for system cache.
getSystemCacheMaxSize() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Maximum memory region size reserved for system cache.
getSystemDataRegionConfiguration() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Configuration of system data region.
getSystemRegionInitialSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
getSystemRegionMaxSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
getSystemThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Size of thread pool that is in charge of processing internal system messages.
getSystemViewExporterSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets fully configured system view SPI implementations.
getSystemWorkerBlockedTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns maximum inactivity period for system worker.
getSystemWorkerBlockedTimeout() - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
getTableName() - Method in class org.apache.ignite.cache.QueryEntity
Gets table name for this query entity.
getTag() - Method in interface org.apache.ignite.mxbean.IgniteClusterMXBean
Deprecated.
Gets current cluster tag.
getTaskName() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets task name of the task this session belongs to.
getTaskNodeId() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets ID of the node on which task execution originated.
getTaskSession() - Method in interface org.apache.ignite.compute.ComputeTaskFuture
Gets task session of execution grid task.
getTaskSession() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
Gets current task session associated with this job.
getTaskSession() - Method in interface org.apache.ignite.spi.failover.FailoverContext
Gets current task session.
getTaskState() - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
 
getTemporaryDirectoryPath() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Gets temporary directory path.
getTemporaryDirectoryPath() - Method in interface org.apache.ignite.spi.deployment.uri.UriDeploymentSpiMBean
Gets temporary directory path.
getText() - Method in class org.apache.ignite.cache.query.TextQuery
Gets text search string.
getThinClientConfiguration() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
 
getThreadCount() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets thread count for warmup.
getThreadPoolSize() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Size of thread pool that is in charge of processing client requests.
getThreadPoolSize() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Should return a thread pool size to be used for processing of client messages (REST requests).
getThreadPoolSize() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Size of thread pool that is in charge of processing ODBC tasks.
getThreadPoolSize() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Size of thread pool that is in charge of processing SQL requests.
getThreadPriority() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets thread priority.
getThreadPriority() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets thread priority.
getThreadsCount() - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Returns number of worker threads.
getTimeInterval() - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Gets time interval.
getTimeout() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Gets the query execution timeout in milliseconds.
getTimeout() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Gets the query execution timeout in milliseconds.
getTimeout() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getTimeServerPortBase() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets base UPD port number for grid time server.
getTimeServerPortRange() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Defines port range to try for time server start.
getTimeToLive() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Set the default time-to-live for multicast packets sent out on this IP finder.
getTimeUntilAutoAdjust() - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
Deprecated.
Use managements API beans, instead.
getTlbSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
getTm() - Method in interface org.apache.ignite.cache.jta.CacheTmLookup
Gets Transaction Manager (TM).
getTm() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
Gets Transaction Manager (TM).
getTm() - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Gets Transaction Manager (TM).
getTopHist() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getTopHistorySize() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
getTopology() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets a collection of grid nodes IDs.
getTopologyValidator() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets topology validator.
getTopologyVersion() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get current topology version.
getTopSnapshot() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getTopVer() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
getTotalAllocatedPages() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets a total number of allocated pages related to the data region.
getTotalAllocatedPages() - Method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
Gets a total number of allocated pages related to the memory policy.
getTotalAllocatedPages() - Method in interface org.apache.ignite.MemoryMetrics
Deprecated.
Gets a total number of allocated pages related to the memory policy.
getTotalAllocatedSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets a total size of memory allocated in the data region.
getTotalBaselineNodes() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get count of total baseline nodes.
getTotalBusyTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total time this node spent executing jobs.
getTotalBusyTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total time this node spent executing jobs.
getTotalCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets number of cancelled jobs since node startup.
getTotalCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets number of cancelled jobs since node startup.
getTotalClientNodes() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get count of client nodes.
getTotalCount() - Method in class org.apache.ignite.services.ServiceConfiguration
Gets total number of deployed service instances in the cluster, 0 for unlimited.
getTotalCpus() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the number of CPUs available to the Java Virtual Machine.
getTotalCpus() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the number of CPUs available to the Java Virtual Machine.
getTotalExecutedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total number of jobs handled by the node since node startup.
getTotalExecutedJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total number of jobs handled by the node since node startup.
getTotalExecutedTasks() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total number of tasks handled by the node.
getTotalExecutedTasks() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total number of tasks handled by the node.
getTotalFailedOverJobsCount() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
Get total number of jobs that were failed over including stolen ones.
getTotalFailedOverJobsCount() - Method in interface org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpiMBean
Get total number of jobs that were failed over including stolen ones.
getTotalFailoverJobsCount() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Get total number of jobs that were failed over.
getTotalFailoverJobsCount() - Method in interface org.apache.ignite.spi.failover.always.AlwaysFailoverSpiMBean
Get total number of jobs that were failed over.
getTotalIdleTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total time this node spent idling (not executing any jobs).
getTotalIdleTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total time this node spent idling (not executing any jobs).
getTotalJobsExecutionTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total time all finished jobs takes to execute on the node since node startup.
getTotalJobsExecutionTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total time all finished jobs takes to execute on the node since node startup.
getTotalNodes() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total number of nodes.
getTotalNodes() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total number of nodes.
getTotalPartitionsCount() - Method in interface org.apache.ignite.cache.CacheMetrics
 
getTotalProcessedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets total processed messages count.
getTotalProcessedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets total processed messages count.
getTotalReceivedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets total received messages count.
getTotalReceivedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Gets total received messages count.
getTotalRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Gets total number of jobs this node rejects during collision resolution operations since node startup.
getTotalRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Gets total number of jobs this node rejects during collision resolution operations since node startup.
getTotalServerNodes() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Get count of server nodes.
getTotalStartedThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the total number of threads created and also started since the JVM started.
getTotalStartedThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the total number of threads created and also started since the JVM started.
getTotalStolenJobsCount() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
Get total number of jobs that were stolen.
getTotalStolenJobsCount() - Method in interface org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpiMBean
Get total number of jobs that were stolen.
getTotalStolenJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets total number of stolen jobs.
getTotalStolenJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets total number of stolen jobs.
getTotalUsedPages() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets a total number of pages used for storing the data.
getTotalUsedSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Returns the total amount of bytes occupied by the non-empty pages.
getToTime() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
The end time interval for the record time in milliseconds.
getTracingSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets fully configured tracing SPI implementation.
getTransactionConfiguration() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets transactions configuration.
getTransactionConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets transactions configuration.
getTransactionManagerLookupClassName() - Method in class org.apache.ignite.configuration.CacheConfiguration
getTransactionsCommittedNumber() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The number of transactions which were committed.
getTransactionsCommittedNumber() - Method in interface org.apache.ignite.transactions.TransactionMetrics
The number of transactions which were committed on the local node.
getTransactionsHoldingLockNumber() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The number of active transactions holding at least one key lock.
getTransactionsHoldingLockNumber() - Method in interface org.apache.ignite.transactions.TransactionMetrics
The number of active transactions on the local node holding at least one key lock.
getTransactionsRolledBackNumber() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The number of transactions which were rollback.
getTransactionsRolledBackNumber() - Method in interface org.apache.ignite.transactions.TransactionMetrics
The number of transactions which were rolled back on the local node.
getTransactionTimeDumpSamplesCoefficient() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Returns the coefficient for samples of completed transactions that will be dumped in log.
getTransactionTimeDumpSamplesPerSecondLimit() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Returns the limit of samples of completed transactions that will be dumped in log per second, if TransactionsMXBean.getTransactionTimeDumpSamplesCoefficient() is above 0.0.
getTransformed() - Method in class org.apache.ignite.events.CacheObjectTransformedEvent
 
getTransformer() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Gets types transformer.
getTransformer() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets types transformer.
getTrustManagers() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets pre-configured trust managers.
getTrustStoreFilePath() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets path to the trust store file.
getTrustStorePassword() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets trust store password.
getTrustStoreType() - Method in class org.apache.ignite.ssl.SslContextFactory
Gets trust store type used for context creation.
getTupleExtractor() - Method in class org.apache.ignite.stream.StreamAdapter
Deprecated.
getTxCommitQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxCommittedVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of cached committed transaction IDs.
getTxDhtCommitQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxDhtCommittedVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of cached committed DHT transaction IDs.
getTxDhtPrepareQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxDhtRolledbackVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of cached rolled back DHT transaction IDs.
getTxDhtStartVersionCountsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxDhtThreadMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets transaction DHT per-thread map size.
getTxDhtXidMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets transaction DHT per-Xid map size.
getTxKeyCollisions() - Method in interface org.apache.ignite.cache.CacheMetrics
Checks if there were any tx key collisions last time.
getTxKeyCollisionsInterval() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
 
getTxManagerFactory() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Gets transaction manager factory for integration with JEE app servers.
getTxManagerLookupClassName() - Method in class org.apache.ignite.configuration.TransactionConfiguration
getTxOwnerDumpRequestsAllowed() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Shows if dump requests from local node to near node are allowed, when long running transaction is found.
getTxPrepareQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxRolledbackVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets number of cached rolled back transaction IDs.
getTxStartVersionCountsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
getTxThreadMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets transaction per-thread map size.
getTxTimeoutOnPartitionMapExchange() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Some Ignite operations provoke partition map exchange process within Ignite to ensure the partitions distribution state is synchronized cluster-wide.
getTxTimeoutOnPartitionMapExchange() - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Gets transaction timeout on partition map exchange.
getTxXidMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets transaction per-Xid map size.
getType() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Gets type for query.
getType() - Method in class org.apache.ignite.cache.query.TextQuery
Gets type for query.
getTypeConfigurations() - Method in class org.apache.ignite.configuration.BinaryConfiguration
Gets types configuration.
getTypeName() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Gets type name.
getTypeName() - Method in class org.apache.ignite.cache.CacheKeyConfiguration
Sets type name for which affinity field name is being defined.
getTypeName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Gets .NET type name.
getTypeName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
getTypeName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
Gets .NET type name.
getTypeName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Get type name.
getTypes() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Gets types known by store.
getTypes() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Gets types known by store.
getTypes() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
getTypesConfiguration() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
getUnacknowledgedMessagesBufferSize() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets maximum number of stored unacknowledged messages per connection to node.
getUpdateBatchSize() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Gets update internal bach size.
getUpTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
Returns the uptime of the JVM in milliseconds.
getUpTime() - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
Returns the uptime of the JVM in milliseconds.
getUpTime() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.upTime" instead.
getUpTime() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets up-time of this SPI in ms.
getUpTime() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets up-time of this SPI in ms.
getUpTimeFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.uptimeFormatted" instead.
getUpTimeFormatted() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
Gets string presentation of up-time for this SPI.
getUpTimeFormatted() - Method in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Gets string presentation of up-time for this SPI.
getURI() - Method in class org.apache.ignite.cache.CacheManager
getUriList() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Gets list of URIs that are processed by SPI.
getUriList() - Method in interface org.apache.ignite.spi.deployment.uri.UriDeploymentSpiMBean
Gets list of URIs that are processed by SPI.
getURL() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Different application servers us different format (URL & url).
getUrl() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getUsedCheckpointBufferPages() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets used checkpoint buffer size in pages.
getUsedCheckpointBufferSize() - Method in interface org.apache.ignite.DataRegionMetrics
Deprecated.
Gets used checkpoint buffer size in bytes.
getUser() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets checkpoint jdbc user name.
getUser() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets checkpoint jdbc user name.
getUserAttributes() - Method in class org.apache.ignite.configuration.ClientConfiguration
Returns user attributes which can be used on server node.
getUserAttributes() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Should return any user-defined attributes to be added to this node.
getUserAttributesFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.userAttributesFormatted" instead.
getUserName() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getUsername() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
getUserObject() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Gets user-specific object.
getUserPassword() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
getUtilityCacheKeepAliveTime() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Keep alive time of thread pool that is in charge of processing utility cache messages.
getUtilityCacheThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Default size of thread pool that is in charge of processing utility cache messages.
getValue() - Method in class org.apache.ignite.cache.query.CacheEntryEventAdapter
getValue() - Method in interface org.apache.ignite.events.CacheConsistencyViolationEvent.EntryInfo
 
getValue() - Method in class org.apache.ignite.lang.IgniteBiTuple
getValueFieldName() - Method in class org.apache.ignite.cache.QueryEntity
Get value field name.
getValueFieldName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets value field name for checkpoint table.
getValueFieldName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets value field name for checkpoint table.
getValueFields() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets optional persistent value fields (needed only if CacheJdbcPojoStore is used).
getValueFieldType() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Gets value field type for checkpoint table.
getValueFieldType() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
Gets value field type for checkpoint table.
getValueType() - Method in interface org.apache.ignite.cache.CacheMetrics
Determines the required type of values for this Cache, if any.
getValueType() - Method in class org.apache.ignite.cache.query.IndexQuery
Cache Value type.
getValueType() - Method in class org.apache.ignite.cache.QueryEntity
Gets value type for this query pair.
getValueType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Gets value type.
getValueTypeName() - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Gets fully-qualified platform type name of the cache value used for the local map.
getVersion() - Method in interface org.apache.ignite.events.CacheConsistencyViolationEvent.EntryInfo
 
getVmName() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.VmName" instead.
getWaitingJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
getWaitingJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Maximum number of jobs that are allowed to wait in waiting queue.
getWaitingJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Maximum number of jobs that are allowed to wait in waiting queue.
getWaitingJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Maximum number of jobs that are allowed to wait in waiting queue.
getWaitJobsThreshold() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
getWaitJobsThreshold() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets job count threshold at which this node will start stealing jobs from other nodes.
getWaitQueueLength(IgniteCondition) - Method in interface org.apache.ignite.IgniteLock
Returns an estimate of the number of threads on this node that are waiting on the given condition associated with this lock.
getWalArchiveDir() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Path to dir with archive wal files.
getWalArchivePath() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a path to the WAL archive directory.
getWalArchivePath() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets a path to the WAL archive directory.
getWalAutoArchiveAfterInactivity() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getWalAutoArchiveAfterInactivity() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
getWalBufferSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Property defines size(in bytes) of WAL buffer.
getWalBufferSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
getWalCompactionLevel() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getWalCompactionLevel() - Method in interface org.apache.ignite.mxbean.DataStorageMXBean
 
getWalDir() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Path to dir with wal files.
getWalFlushFrequency() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
This property define how often WAL will be fsync-ed in BACKGROUND mode.
getWalFlushFrequency() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
This property define how often WAL will be fsync-ed in BACKGROUND mode.
getWalForceArchiveTimeout() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getWalFsyncDelayNanos() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
getWalFsyncDelayNanos() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
getWalHistorySize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Deprecated.
Instead of walHistorySize use maxWalArchiveSize for manage of archive size.
getWalHistorySize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets a total number of checkpoints to keep in the WAL history.
getWalMode() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Property that defines behavior of wal fsync.
getWalMode() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Type define behavior wal fsync.
getWalPageCompression() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets compression algorithm for WAL page snapshot records.
getWalPageCompressionLevel() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets algorithm specific WAL page compression level.
getWalPath() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a path to the directory where WAL is stored.
getWalRecordIteratorBufferSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Property define how many bytes iterator read from disk (for one reading), during go ahead wal.
getWalRecordIteratorBufferSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Property define how many bytes iterator read from disk (for one reading), during go ahead wal.
getWalSegments() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets a number of WAL segments to work with.
getWalSegments() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets a number of WAL segments to work with.
getWalSegmentSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Gets size(in bytes) of a WAL segment.
getWalSegmentSize() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets size of a WAL segment in bytes.
getWalStorePath() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets a path to the directory where WAL is stored.
getWalThreadLocalBufferSize() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Property for size of thread local buffer.
getWarmupClosure() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets grid warmup closure.
getWarmUpConfiguration() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets warm-up configuration.
getWarmupMethods() - Method in class org.apache.ignite.startup.BasicWarmupClosure
Gets warmup methods to use for cache warmup.
getWorkDirectory() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets Ignite work directory.
getWorkerNames() - Method in interface org.apache.ignite.mxbean.WorkersControlMXBean
Returns names of all registered workers.
getWriteBehindBatchSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Maximum batch size for write-behind cache store operations.
getWriteBehindBufferSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets count of entries that were processed by the write-behind store and have not been flushed to the underlying store yet.
getWriteBehindCoalescing() - Method in class org.apache.ignite.configuration.CacheConfiguration
Write coalescing flag for write-behind cache store operations.
getWriteBehindCriticalOverflowCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets count of write buffer overflow events in progress at the moment.
getWriteBehindErrorRetryCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets count of cache entries that are in a store-retry state.
getWriteBehindFlushFrequency() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets the cache flush frequency.
getWriteBehindFlushFrequency() - Method in class org.apache.ignite.configuration.CacheConfiguration
Frequency with which write-behind cache is flushed to the cache store in milliseconds.
getWriteBehindFlushSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets the maximum size of the write-behind buffer.
getWriteBehindFlushSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
Maximum size of the write-behind cache.
getWriteBehindFlushThreadCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets the number of flush threads that will perform store update operations.
getWriteBehindFlushThreadCount() - Method in class org.apache.ignite.configuration.CacheConfiguration
Number of threads that will perform cache flushing.
getWriteBehindStoreBatchSize() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets the maximum count of similar (put or remove) operations that can be grouped to a single batch.
getWriteBehindTotalCriticalOverflowCount() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets count of write buffer overflow events since initialization.
getWriteSynchronizationMode() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
getWriteSynchronizationMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets write synchronization mode.
getZkConnectionString() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getZkConnectionString() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets connection string used to connect to ZooKeeper cluster.
getZkRootPath() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
getZkRootPath() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets root path in ZooKeeper cluster Zk client uses to put data to.
getZkSessionId() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets session id of Zk client established with ZooKeeper cluster.
getZkSessionTimeout() - Method in interface org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpiMBean
Gets session timeout used by Zk client of local Ignite node.
globalId() - Method in class org.apache.ignite.lang.IgniteUuid
Gets global ID portion of this IgniteUuid.
greaterThanEqual(int, int, int) - Method in class org.apache.ignite.lang.IgniteProductVersion
 
grid() - Method in interface org.apache.ignite.plugin.CachePluginContext
 
grid() - Method in interface org.apache.ignite.plugin.PluginContext
 
GRID_LOG_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
gridDiscoveryData(int) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
gridStartTime - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Start time of the very first grid node.
groupId() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
groupId() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
groupName() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
groupName() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
GRP_IDX_UNASSIGNED - Static variable in class org.apache.ignite.thread.IgniteThread
Index for unassigned thread.
gt(String, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Greater Then.
gte(String, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Greater Then or Equal To.

H

H2Dialect - Class in org.apache.ignite.cache.store.jdbc.dialect
A dialect compatible with the H2 database.
H2Dialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.H2Dialect
 
HALF_MAX_WAL_ARCHIVE_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Value used to indicate the use of half of the DataStorageConfiguration.getMaxWalArchiveSize().
handle(Ignite, FailureContext) - Method in class org.apache.ignite.failure.AbstractFailureHandler
Actual failure handling.
handle(Ignite, FailureContext) - Method in class org.apache.ignite.failure.NoOpFailureHandler
Actual failure handling.
handle(Ignite, FailureContext) - Method in class org.apache.ignite.failure.RestartProcessFailureHandler
Actual failure handling.
handle(Ignite, FailureContext) - Method in class org.apache.ignite.failure.StopNodeFailureHandler
Actual failure handling.
handle(Ignite, FailureContext) - Method in class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
Actual failure handling.
HANDSHAKE2_MESSAGE_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
Message size in bytes including HandshakeMessage fields.
HANDSHAKE_MSG_TYPE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Handshake message type.
HANDSHAKE_WAIT_MSG_TYPE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Handshake wait message type.
HandshakeFailEvent - Class in org.apache.ignite.client.events
 
HandshakeFailEvent(ConnectionDescription, long, Throwable) - Constructor for class org.apache.ignite.client.events.HandshakeFailEvent
 
HandshakeMessage - Class in org.apache.ignite.spi.communication.tcp.messages
Handshake message.
HandshakeMessage() - Constructor for class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Default constructor required by Message.
HandshakeMessage(UUID, long, long) - Constructor for class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
HandshakeMessage2 - Class in org.apache.ignite.spi.communication.tcp.messages
Updated handshake message.
HandshakeMessage2() - Constructor for class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
 
HandshakeMessage2(UUID, long, long, int) - Constructor for class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
 
HandshakeStartEvent - Class in org.apache.ignite.client.events
 
HandshakeStartEvent(ConnectionDescription) - Constructor for class org.apache.ignite.client.events.HandshakeStartEvent
 
HandshakeSuccessEvent - Class in org.apache.ignite.client.events
 
HandshakeSuccessEvent(ConnectionDescription, long) - Constructor for class org.apache.ignite.client.events.HandshakeSuccessEvent
 
HandshakeWaitMessage - Class in org.apache.ignite.spi.communication.tcp.messages
Message requesting to wait until node's SPI context initialize.
HandshakeWaitMessage() - Constructor for class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Default constructor required by Message.
hasCause(Class<? extends Throwable>...) - Method in exception org.apache.ignite.IgniteCheckedException
Checks if this exception has given class in 'cause' hierarchy.
hasCause(Class<? extends Throwable>...) - Method in exception org.apache.ignite.IgniteException
Checks if this exception has given class in 'cause' hierarchy.
hasCause(Class<? extends Throwable>...) - Method in exception org.apache.ignite.IgniteIllegalStateException
Checks if this exception has given class in 'cause' hierarchy.
hasConflict() - Method in class org.apache.ignite.cache.QueryEntityPatch
Check for conflict in this patch.
hasField(String) - Method in interface org.apache.ignite.binary.BinaryObject
Checks whether field exists in the object.
hashCode() - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
hashCode() - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
hashCode() - Method in class org.apache.ignite.cache.affinity.AffinityKey
Hash code implementation which delegates to the underlying AffinityKey.key().
hashCode() - Method in class org.apache.ignite.cache.CacheKeyConfiguration
hashCode() - Method in class org.apache.ignite.cache.QueryEntity
hashCode() - Method in class org.apache.ignite.cache.QueryIndex
hashCode(Collection<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeDefaultHasher
Calculate hash code for specified object and fields.
hashCode() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
hashCode(Collection<?>) - Method in interface org.apache.ignite.cache.store.jdbc.JdbcTypeHasher
Calculate hash code for specified object and fields.
hashCode() - Method in class org.apache.ignite.events.EventAdapter
hashCode() - Method in class org.apache.ignite.lang.IgniteBiTuple
hashCode() - Method in class org.apache.ignite.lang.IgniteProductVersion
hashCode() - Method in class org.apache.ignite.lang.IgniteUuid
hashCode() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
hashCode() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
hashCode() - Method in class org.apache.ignite.services.ServiceConfiguration
hashCode() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
hashCode() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionKey
hashCode() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates
hasher - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Hash calculator.
hasJoiningNodeData() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.JoiningNodeDiscoveryData
 
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.H2Dialect
hasMerge() - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
 
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.OracleDialect
hasMerge() - Method in class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
hasNewValue() - Method in class org.apache.ignite.events.CacheEvent
Gets flag indicating whether cache entry has new value in case if we only have new value in serialized form in which case CacheEvent.newValue() will return null.
hasOldValue() - Method in class org.apache.ignite.events.CacheEvent
Gets flag indicating whether cache entry has old value in case if we only have old value in serialized form in which case CacheEvent.oldValue() will return null.
hasQueuedThread(Thread) - Method in interface org.apache.ignite.IgniteLock
Queries whether the given thread is waiting to acquire this lock.
hasQueuedThreads() - Method in interface org.apache.ignite.IgniteLock
Queries whether any threads on this node are waiting to acquire this lock.
hasQueuedThreads() - Method in interface org.apache.ignite.IgniteSemaphore
Queries whether any threads are waiting to acquire.
hasQueuedThreads() - Method in class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
hasQueuedThreads() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
hasWaiters(IgniteCondition) - Method in interface org.apache.ignite.IgniteLock
Queries whether any threads on this node are waiting on the given condition associated with this lock.
heapMemoryCommited() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
heapMemoryInit() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
heapMemoryMax() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
heapMemoryTotal() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
heapMemoryUsed() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
heldcc() - Method in interface org.apache.ignite.compute.ComputeJobContinuation
Checks if job execution has been temporarily held (suspended).
heldcc() - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
Checks if job execution has been temporarily held (suspended).
heldJobs() - Method in interface org.apache.ignite.spi.collision.CollisionContext
Gets collection of jobs that are currently in held state.
HistogramMetric - Interface in org.apache.ignite.spi.metric
Histogram metric calculates counts of measurements that gets into each bounds interval.
holdcc() - Method in interface org.apache.ignite.compute.ComputeJobContinuation
Holds (suspends) a given job indefinitely until ComputeJobContinuation.callcc() is called.
holdcc(long) - Method in interface org.apache.ignite.compute.ComputeJobContinuation
Holds (suspends) a given job for specified timeout or until ComputeJobContinuation.callcc() is called.
holdcc() - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
Holds (suspends) a given job indefinitely until ComputeJobContinuation.callcc() is called.
holdcc(long) - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
Holds (suspends) a given job for specified timeout or until ComputeJobContinuation.callcc() is called.
hostNames() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets the read-only collection of hostnames in this cluster group.
hostNames() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets collection of host names this node is known by.
hostNames() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
hostNames() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets collection of host names this node is known by.
hostnames() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 

I

id() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets globally unique node ID.
id() - Method in interface org.apache.ignite.events.Event
Gets globally unique ID of this event.
id() - Method in class org.apache.ignite.events.EventAdapter
Gets globally unique ID of this event.
id() - Method in interface org.apache.ignite.IgniteCluster
Cluster ID is a unique identifier automatically generated when cluster starts up for the very first time.
id() - Method in interface org.apache.ignite.plugin.extensions.communication.IoPool
Gets the numeric identifier of the pool.
id() - Method in interface org.apache.ignite.plugin.platform.PlatformCachePluginConfigurationClosureFactory
Gets the factory id.
id() - Method in interface org.apache.ignite.plugin.platform.PlatformPluginConfigurationClosureFactory
Gets the factory id.
id() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Gets subject ID.
id() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets scheduled task ID.
id() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets globally unique node ID.
id() - Method in interface org.apache.ignite.spi.IgniteSpiTimeoutObject
 
id() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
id() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
id() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
id() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
idleTimePercentage() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
idx() - Method in enum org.apache.ignite.spi.tracing.Scope
 
ignite - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Auto injected ignite instance.
ignite() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
ignite() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets instance of grid.
Ignite - Interface in org.apache.ignite
Main entry-point for all Ignite APIs.
ignite() - Static method in class org.apache.ignite.Ignition
Gets an instance of default no-name grid.
ignite(UUID) - Static method in class org.apache.ignite.Ignition
Gets a grid instance for given local node ID.
ignite(String) - Static method in class org.apache.ignite.Ignition
Gets a named Ignite instance.
ignite() - Method in class org.apache.ignite.messaging.MessagingListenActor
Gets grid instance associated with this actor.
ignite - Variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Deprecated.
Since 2.8. May contain an invalid Ignite instance when multiple nodes shares same TcpDiscoveryIpFinder instance.
ignite - Variable in class org.apache.ignite.spi.IgniteSpiAdapter
Ignite instance.
ignite() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets ignite instance.
ignite - Variable in class org.apache.ignite.stream.StreamAdapter
Ignite.
IGNITE_AFFINITY_BACKUPS_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Size threshold to allocate and retain additional HashMap to improve contains() which leads to extra memory consumption.
IGNITE_AFFINITY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size for affinity assignment history.
IGNITE_ALLOW_DML_INSIDE_TRANSACTION - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, Ignite will allow execute DML operation (MERGE|INSERT|UPDATE|DELETE) within transaction for non MVCC mode.
IGNITE_ALLOW_MIXED_CACHE_GROUPS - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag indicating whether atomic and transactional caches are allowed inside the same cache group.
IGNITE_ALLOW_START_CACHES_IN_PARALLEL - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables start caches in parallel.
IGNITE_ATOMIC_CACHE_DELETE_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size for atomic cache queue delete history (default is 200 000 entries per partition).
IGNITE_ATOMIC_CACHE_QUEUE_RETRY_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Atomic cache deferred update timeout.
IGNITE_ATOMIC_DEFERRED_ACK_BUFFER_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Atomic cache deferred update response buffer size.
IGNITE_ATOMIC_DEFERRED_ACK_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Atomic cache deferred update timeout.
IGNITE_BASELINE_AUTO_ADJUST_LOG_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
Interval between logging of time of next auto-adjust.
IGNITE_BINARY_DONT_WRAP_TREE_STRUCTURES - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Should be removed in Apache Ignite 2.0.
IGNITE_BINARY_MARSHALLER_USE_STRING_SERIALIZATION_VER_2 - Static variable in class org.apache.ignite.IgniteSystemProperties
Manages type of serialization mechanism for String that is marshalled/unmarshalled by BinaryMarshaller.
IGNITE_BINARY_SORT_OBJECT_FIELDS - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true fields are written by BinaryMarshaller in sorted order.
IGNITE_BPLUS_TREE_DISABLE_METRICS - Static variable in class org.apache.ignite.IgniteSystemProperties
Disables secondary indexes B+Tree metrics.
IGNITE_BPLUS_TREE_LOCK_RETRIES - Static variable in class org.apache.ignite.IgniteSystemProperties
Number of repetitions to capture a lock in the B+Tree.
IGNITE_CACHE_CLIENT - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling default behavior of cache client flag.
IGNITE_CACHE_KEY_VALIDATION_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Since 2.10 Obsolete because of common use of binary marshaller.
IGNITE_CACHE_REMOVED_ENTRIES_TTL - Static variable in class org.apache.ignite.IgniteSystemProperties
Ttl of removed cache entries (ms).
IGNITE_CACHE_RETRIES_COUNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Number of cache operation retries in case of topology exceptions.
IGNITE_CACHE_START_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Cache start size for on-heap maps.
IGNITE_CALCITE_EXEC_IN_BUFFER_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Calcite-based SQL engine.
IGNITE_CALCITE_EXEC_IO_BATCH_CNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Calcite-based SQL engine.
IGNITE_CALCITE_EXEC_IO_BATCH_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Calcite-based SQL engine.
IGNITE_CALCITE_EXEC_MODIFY_BATCH_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Calcite-based SQL engine.
IGNITE_CALCITE_REL_JSON_PRETTY_PRINT - Static variable in class org.apache.ignite.IgniteSystemProperties
Calcite-based SQL engine.
IGNITE_CFG_FILE_PATH_PARAM - Static variable in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
Configuration file path parameter name.
IGNITE_CHECKPOINT_MAP_SNAPSHOT_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Threshold of the checkpoint quantity since the last earliest checkpoint map snapshot.
IGNITE_CHECKPOINT_READ_LOCK_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Timeout for checkpoint read lock acquisition in milliseconds.
IGNITE_CHECKPOINT_TRIGGER_ARCHIVE_SIZE_PERCENTAGE - Static variable in class org.apache.ignite.IgniteSystemProperties
Property for setup percentage of archive size for checkpoint trigger.
IGNITE_CLIENT_CACHE_CHANGE_MESSAGE_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
When client cache is started or closed special discovery message is sent to notify cluster (for example this is needed for ClusterGroup.forCacheNodes(String) API.
IGNITE_CLUSTER_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite cluster name.
IGNITE_CONFIG_URL - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to hold optional configuration URL.
IGNITE_CONFIGURATION_VIEW_PACKAGES - Static variable in class org.apache.ignite.IgniteSystemProperties
Comma separated packages list to expose in configuration view.
IGNITE_CONSISTENT_ID_BY_HOST_WITHOUT_PORT - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, for consistent id will calculate by host name, without port, and you can use only one node for host in cluster.
IGNITE_CONSOLE_APPENDER - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set to true (default) and Ignite is launched in verbose mode (see IgniteSystemProperties.IGNITE_QUIET) and no console appenders can be found in configuration, then default console appender will be added.
IGNITE_DATA_STORAGE_FOLDER_BY_CONSISTENT_ID - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, Data store folders are generated only by consistent id, and no consistent ID will be set based on existing data store folders.
IGNITE_DATA_STREAMING_EXECUTOR_SERVICE_TASKS_STEALING_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Tasks stealing will be started if tasks queue size per data-streamer thread exceeds this threshold.
IGNITE_DEFAULT_DATA_STORAGE_PAGE_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Sets default storage page size.
IGNITE_DEFAULT_DISK_PAGE_COMPRESSION - Static variable in class org.apache.ignite.IgniteSystemProperties
Sets default disk page compression.
IGNITE_DEFERRED_ONE_PHASE_COMMIT_ACK_REQUEST_BUFFER_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
One phase commit deferred ack request buffer size.
IGNITE_DEFERRED_ONE_PHASE_COMMIT_ACK_REQUEST_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
One phase commit deferred ack request timeout.
IGNITE_DEFRAGMENTATION_REGION_SIZE_PERCENTAGE - Static variable in class org.apache.ignite.IgniteSystemProperties
Defragmentation region size percentage of configured region size.
IGNITE_DELAYED_REPLACED_PAGE_WRITE - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true (default), pages are written to page store without holding segment lock (with delay).
IGNITE_DEP_MODE_OVERRIDE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override deployment mode configuration parameter.
IGNITE_DEPLOYMENT_ADDITIONAL_CHECK - Static variable in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Enables additional check for resource name on resources removal.
IGNITE_DEV_ONLY_LOGGING_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, warnings that are intended for development environments and not for production (such as coding mistakes in code using Ignite) will not be logged.
IGNITE_DIAGNOSTIC_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_DIAGNOSTIC_WARN_LIMIT - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum number of diagnostic warning messages per category, when waiting for PME.
IGNITE_DIRECT_IO_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, direct IO may be enabled.
IGNITE_DISABLE_AFFINITY_MEMORY_OPTIMIZATION - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag to disable memory optimization: BitSets instead of HashSets to store partitions.
IGNITE_DISABLE_GRP_STATE_LAZY_STORE - Static variable in class org.apache.ignite.IgniteSystemProperties
Disable group state lazy store.
IGNITE_DISABLE_HOSTNAME_VERIFIER - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to disable HostnameVerifier for SSL connections.
IGNITE_DISABLE_ONHEAP_CACHE - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, on-heap cache cannot be enabled - see CacheConfiguration.setOnheapCacheEnabled(boolean).
IGNITE_DISABLE_REBALANCING_CANCELLATION_OPTIMIZATION - Static variable in class org.apache.ignite.IgniteSystemProperties
When property is set false each next exchange will try to compare with previous.
IGNITE_DISABLE_TRIGGERING_CACHE_INTERCEPTOR_ON_CONFLICT - Static variable in class org.apache.ignite.IgniteSystemProperties
Disables cache interceptor triggering in case of conflicts.
IGNITE_DISABLE_WAL_DURING_REBALANCING - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to false, WAL will not be automatically disabled during rebalancing if there is no partition in OWNING state.
IGNITE_DISCO_FAILED_CLIENT_RECONNECT_DELAY - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines reconnect delay in milliseconds for client node that was failed forcible.
IGNITE_DISCOVERY_CLIENT_RECONNECT_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum number of discovery message history used to support client reconnect.
IGNITE_DISCOVERY_DISABLE_CACHE_METRICS_UPDATE - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, cache metrics are not included into the discovery metrics update message (in this case message contains only cluster metrics).
IGNITE_DISCOVERY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size for discovery messages history.
IGNITE_DISCOVERY_METRICS_QNT_WARN - Static variable in class org.apache.ignite.IgniteSystemProperties
Logging a warning message when metrics quantity exceeded a specified number.
IGNITE_DUMP_PAGE_LOCK_ON_FAILURE - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables threads locks dumping on critical node failure.
IGNITE_DUMP_THREADS_ON_FAILURE - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables threads dumping on critical node failure.
IGNITE_DUMP_THREADS_ON_FAILURE_THROTTLING_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Throttling time out for thread dump generation during failure handling.
IGNITE_DUMP_TX_COLLISIONS_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
When above zero, prints tx key collisions once per interval.
IGNITE_ENABLE_EXPERIMENTAL_COMMAND - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Use "--enable-experimental" parameter instead.
IGNITE_ENABLE_EXTRA_INDEX_REBUILD_LOGGING - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables extended logging of indexes create/rebuild process.
IGNITE_ENABLE_FORCIBLE_NODE_KILL - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set, a node will forcible fail a remote node when it fails to establish a communication connection.
IGNITE_ENABLE_SUBQUERY_REWRITE_OPTIMIZATION - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables subquery rewriting optimization.
IGNITE_EVICTION_PERMITS - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Since version 2.10. Use IgniteConfiguration.setRebalanceThreadPoolSize(int) to manage eviction parallelism.
IGNITE_EXCEPTION_REGISTRY_MAX_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling size of buffer holding last exception.
IGNITE_EXCHANGE_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size for exchange history.
IGNITE_EXCHANGE_MERGE_DELAY - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_FAIL_NODE_ON_UNRECOVERABLE_PARTITION_INCONSISTENCY - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag to enable triggering failure handler for node if unrecoverable partition inconsistency is discovered during partition update counters exchange.
IGNITE_FAILURE_HANDLER_RESERVE_BUFFER_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Amount of memory reserved in the heap at node start, which can be dropped to increase the chances of success when handling OutOfMemoryError.
IGNITE_GLOBAL_METASTORAGE_HISTORY_MAX_BYTES - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum amount of bytes that can be stored in history of DistributedMetaStorage updates.
IGNITE_GRID_CLIENT_LOG_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set to true enable logging in GridClient.
IGNITE_H2_DEBUG_CONSOLE - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Since 2.8. H2 console is no longer supported.
IGNITE_H2_DEBUG_CONSOLE_PORT - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Since 2.8. H2 console is no longer supported.
IGNITE_H2_INDEXING_CACHE_CLEANUP_PERIOD - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify period in milliseconds between calls of the SQL statements cache cleanup task.
IGNITE_H2_INDEXING_CACHE_THREAD_USAGE_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify timeout in milliseconds after which thread's SQL statements cache is cleared by cleanup task if the thread does not perform any query.
IGNITE_HOME - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines Ignite installation folder.
IGNITE_HOME_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
IGNITE_IGNORE_LOCAL_HOST_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to ignore reading hostname of the local address.
IGNITE_INDEX_REBUILD_BATCH_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Count of rows, being processed within a single checkpoint lock when indexes are rebuilt.
IGNITE_INDEXING_DISCOVERY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Indexing discovery history size.
IGNITE_IO_BALANCE_PERIOD - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_IO_DUMP_ON_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_IPC_SHMEM_SPACE_DEBUG - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
This property is ignored and will be deleted in future releases.
IGNITE_JCACHE_DEFAULT_ISOLATED - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling whether CacheManager will start grid with isolated IP finder when default URL is passed in.
IGNITE_JDBC_DRIVER_CURSOR_REMOVE_DELAY - Static variable in class org.apache.ignite.IgniteSystemProperties
JDBC driver cursor remove delay.
IGNITE_JETTY_HOST - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allows to override Jetty host for REST processor.
IGNITE_JETTY_LOG_NO_OVERRIDE - Static variable in class org.apache.ignite.IgniteSystemProperties
This property does not allow Ignite to override Jetty log configuration for REST processor.
IGNITE_JETTY_PORT - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allows to override Jetty local port for REST processor.
IGNITE_JOBS_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override default job processor maps sizes for finished jobs and cancellation requests.
IGNITE_JOBS_METRICS_CONCURRENCY_LEVEL - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Check the ReadOnlyMetricRegistry with "name=compute.jobs" instead.
IGNITE_JVM_PAUSE_DETECTOR_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite JVM pause detector disabled.
IGNITE_JVM_PAUSE_DETECTOR_LAST_EVENTS_COUNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite JVM pause detector last events count.
IGNITE_JVM_PAUSE_DETECTOR_PRECISION - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite JVM pause detector precision.
IGNITE_JVM_PAUSE_DETECTOR_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite JVM pause detector threshold.
IGNITE_KEEP_STATIC_CACHE_CONFIGURATION - Static variable in class org.apache.ignite.IgniteSystemProperties
Keep static cache configuration even if stored cache data differs from the static config.
IGNITE_LOADED_PAGES_BACKWARD_SHIFT_MAP - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to false, loaded pages implementation is switched to previous version of implementation, FullPageIdTable.
IGNITE_LOCAL_HOST - Static variable in class org.apache.ignite.IgniteSystemProperties
The system property sets a system-wide local IP address or hostname to be used by Ignite networking components.
IGNITE_LOCAL_STORE_KEEPS_PRIMARY_ONLY - Static variable in class org.apache.ignite.IgniteSystemProperties
Indicating whether local store keeps primary only.
IGNITE_LOG_CLASSPATH_CONTENT_ON_STARTUP - Static variable in class org.apache.ignite.IgniteSystemProperties
Scan the classpath on startup and log all the files containing in it.
IGNITE_LOG_DIR - Static variable in class org.apache.ignite.IgniteSystemProperties
Environment variable to override logging directory that has been set in logger configuration.
IGNITE_LOG_GRID_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
IGNITE_LOG_INSTANCE_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
If this system property is present the Ignite will include instance name into verbose log.
IGNITE_LOG_THROTTLE_CAPACITY - Static variable in class org.apache.ignite.IgniteSystemProperties
Max amount of remembered errors for GridLogThrottle.
IGNITE_LONG_LONG_HASH_MAP_LOAD_FACTOR - Static variable in class org.apache.ignite.IgniteSystemProperties
Long-long offheap map load factor.
IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Cache operations that take more time than value of this property will be output to log.
IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT_LIMIT - Static variable in class org.apache.ignite.IgniteSystemProperties
Upper time limit between long running/hanging operations debug dumps.
IGNITE_LONG_TRANSACTION_TIME_DUMP_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Threshold timeout for long transactions, if transaction exceeds it, it will be dumped in log with information about how much time did it spent in system time (time while aquiring locks, preparing, commiting, etc) and user time (time when client node runs some code while holding transaction and not waiting it).
IGNITE_MARSHAL_BUFFERS_PER_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify per thread binary allocator chunk pool size.
IGNITE_MARSHAL_BUFFERS_RECHECK - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify how often in milliseconds marshal buffers should be rechecked and potentially trimmed.
IGNITE_MARSHALLER_BLACKLIST - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines path to the file that contains list of classes disallowed to safe deserialization.
IGNITE_MARSHALLER_WHITELIST - Static variable in class org.apache.ignite.IgniteSystemProperties
Defines path to the file that contains list of classes allowed to safe deserialization.
IGNITE_MASTER_KEY_NAME_TO_CHANGE_BEFORE_STARTUP - Static variable in class org.apache.ignite.IgniteSystemProperties
The master key name that the node will use during the recovery.
IGNITE_MAX_COMPLETED_TX_COUNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling size of buffer holding completed transaction versions.
IGNITE_MAX_INDEX_PAYLOAD_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify maximum payload size in bytes for H2TreeIndex.
IGNITE_MAX_NESTED_LISTENER_CALLS - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum number of nested listener calls before listener notification becomes asynchronous.
IGNITE_MBEAN_APPEND_CLASS_LOADER_ID - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set to true then Ignite will append hash code of class loader to MXBean name.
IGNITE_MBEAN_APPEND_JVM_ID - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set to true then Ignite will append hash code of Ignite class as hex string and append JVM name returned by RuntimeMXBean.getName().
IGNITE_MBEANS_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
If property is set to true, then Ignite will disable MBeans registration.
IGNITE_MEMORY_PER_BYTE_COPY_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
When unsafe memory copy if performed below this threshold, Ignite will do it on per-byte basis instead of calling to Unsafe.copyMemory().
IGNITE_MEMORY_UNALIGNED_ACCESS - Static variable in class org.apache.ignite.IgniteSystemProperties
Whether Ignite can access unaligned memory addresses.
IGNITE_MIN_BUFFERED_COMMUNICATION_MSG_CNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Not used anymore.
IGNITE_MVCC_TX_SIZE_CACHING_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum number for cached MVCC transaction updates.
IGNITE_NEAR_GET_MAX_REMAPS - Static variable in class org.apache.ignite.IgniteSystemProperties
This property defines the maximum number of attempts to remap near get to the same primary node.
IGNITE_NIO_RECOVERY_DESCRIPTOR_RESERVATION_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Sets timeout for TCP client recovery descriptor reservation.
IGNITE_NO_ASCII - Static variable in class org.apache.ignite.IgniteSystemProperties
If this system property is present (any value) - no ASCII logo will be printed.
IGNITE_NO_DISCO_ORDER - Static variable in class org.apache.ignite.IgniteSystemProperties
Name of the system property to disable requirement for proper node ordering by discovery SPI.
IGNITE_NO_SELECTOR_OPTS - Static variable in class org.apache.ignite.IgniteSystemProperties
If set to true, then default selected keys set is used inside GridNioServer which lead to some extra garbage generation when processing selected keys.
IGNITE_NO_SHUTDOWN_HOOK - Static variable in class org.apache.ignite.IgniteSystemProperties
If this system property is set to true - no shutdown hook will be set.
IGNITE_NODE_IDS_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum size of history of server nodes (server node IDs) that ever joined to current topology.
IGNITE_OFFHEAP_LOCK_CONCURRENCY_LEVEL - Static variable in class org.apache.ignite.IgniteSystemProperties
Ignite page memory concurrency level.
IGNITE_OFFHEAP_SAFE_RELEASE - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag that will force Ignite to fill memory block with some recognisable pattern right before this memory block is released.
IGNITE_OPTIMIZED_MARSHALLER_USE_DEFAULT_SUID - Static variable in class org.apache.ignite.IgniteSystemProperties
Manages OptimizedMarshaller behavior of serialVersionUID computation for Serializable classes.
IGNITE_OVERRIDE_CONSISTENT_ID - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to specify consistent id of Ignite node.
IGNITE_OVERRIDE_MCAST_GRP - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override multicast group taken from configuration.
IGNITE_OVERRIDE_WRITE_THROTTLING_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set, DataStorageConfiguration.setWriteThrottlingEnabled(boolean) will be overridden to true regardless the initial value in the configuration.
IGNITE_PAGE_LOCK_TRACKER_CAPACITY - Static variable in class org.apache.ignite.IgniteSystemProperties
Capacity in pages for storing in page lock tracker strucuture.
IGNITE_PAGE_LOCK_TRACKER_CHECK_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
Page lock tracker thread for checking hangs threads interval.
IGNITE_PAGE_LOCK_TRACKER_TYPE - Static variable in class org.apache.ignite.IgniteSystemProperties
Page lock tracker type
IGNITE_PAGES_LIST_DISABLE_ONHEAP_CACHING - Static variable in class org.apache.ignite.IgniteSystemProperties
Disable onheap caching of pages lists (free lists and reuse lists).
IGNITE_PART_DISTRIBUTION_WARN_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
The threshold of uneven distribution above which partition distribution will be logged.
IGNITE_PARTITION_RELEASE_FUTURE_DUMP_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
If a partition release future completion time during an exchange exceeds this threshold, the contents of the future will be dumped to the log on exchange.
IGNITE_PARTITION_RELEASE_FUTURE_WARN_LIMIT - Static variable in class org.apache.ignite.IgniteSystemProperties
This property specifies the maximum number of futures that are included into diagnostic message.
IGNITE_PDS_MAX_CHECKPOINT_MEMORY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Number of checkpoint history entries held in memory.
IGNITE_PDS_PARTITION_DESTROY_CHECKPOINT_DELAY - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
IGNITE_PDS_SKIP_CRC - Static variable in class org.apache.ignite.IgniteSystemProperties
Skip CRC calculation flag.
IGNITE_PDS_WAL_REBALANCE_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
use Distributed MetaStorage property historical.rebalance.threshold.
IGNITE_PENDING_TX_TRACKER_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to enable pending transaction tracker.
IGNITE_PERF_STAT_BUFFER_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Performance statistics off heap buffer size in bytes.
IGNITE_PERF_STAT_CACHED_STRINGS_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum performance statistics cached strings threshold.
IGNITE_PERF_STAT_FILE_MAX_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum performance statistics file size in bytes.
IGNITE_PERF_STAT_FLUSH_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Minimal performance statistics batch size to be flushed in bytes.
IGNITE_PERFORMANCE_SUGGESTIONS_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag indicating whether performance suggestions output on start should be disabled.
IGNITE_PME_FREE_SWITCH_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
PME-free switch explicitly disabled.
IGNITE_PREFER_WAL_REBALANCE - Static variable in class org.apache.ignite.IgniteSystemProperties
Prefer historical rebalance if there's enough history regardless off all heuristics.
IGNITE_PRELOAD_RESEND_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to hold preload resend timeout for evicted partitions.
IGNITE_PROG_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
Name of the system property defining name of command line program.
IGNITE_QUIET - Static variable in class org.apache.ignite.IgniteSystemProperties
Set to either true or false to enable or disable quiet mode of Ignite.
IGNITE_READ_LOAD_BALANCING - Static variable in class org.apache.ignite.IgniteSystemProperties
Whenever read load balancing is enabled, that means 'get' requests will be distributed between primary and backup nodes if it is possible and CacheConfiguration.isReadFromBackup() is true.
IGNITE_REBALANCE_STATISTICS_TIME_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
IGNITE_REBALANCE_THROTTLE_OVERRIDE - Static variable in class org.apache.ignite.IgniteSystemProperties
IGNITE_RECOVERY_SEMAPHORE_PERMITS - Static variable in class org.apache.ignite.IgniteSystemProperties
Limit the maximum number of objects in memory during the recovery procedure.
IGNITE_RECOVERY_VERBOSE_LOGGING - Static variable in class org.apache.ignite.IgniteSystemProperties
Allows to log additional information about all restored partitions after binary and logical recovery phases.
IGNITE_REFLECTION_CACHE_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to override default reflection cache size.
IGNITE_REST_GETALL_AS_ARRAY - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Should be made default in Apache Ignite 3.0.
IGNITE_REST_MAX_TASK_RESULTS - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allows to override maximum count of task results stored on one node in REST processor.
IGNITE_REST_SECURITY_TOKEN_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allow rewriting default (300) REST session security token expire time (in seconds).
IGNITE_REST_SESSION_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allow rewriting default (30) REST session expire time (in seconds).
IGNITE_REST_START_ON_CLIENT - Static variable in class org.apache.ignite.IgniteSystemProperties
This property allows to override default behavior that rest processor doesn't start on client node.
IGNITE_RESTART_CODE - Static variable in class org.apache.ignite.IgniteSystemProperties
This property is used internally to pass an exit code to loader when Ignite instance is being restarted.
IGNITE_REUSE_MEMORY_ON_DEACTIVATE - Static variable in class org.apache.ignite.IgniteSystemProperties
Try reuse memory on deactivation.
IGNITE_SECURITY_COMPATIBILITY_MODE - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, Ignite switches to compatibility mode with versions that don't support service security permissions.
IGNITE_SKIP_CONFIGURATION_CONSISTENCY_CHECK - Static variable in class org.apache.ignite.IgniteSystemProperties
Property allowing to skip configuration consistency checks.
IGNITE_SKIP_PARTITION_SIZE_VALIDATION - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, Ignite will skip partitions sizes check on partition validation after rebalance has finished.
IGNITE_SLOW_TX_WARN_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Transactions that take more time, than value of this property, will be output to log with warning level.
IGNITE_SNAPSHOT_SEQUENTIAL_WRITE - Static variable in class org.apache.ignite.IgniteSystemProperties
Flag to indicate that disk writes during snapshot process should be in a sequential manner when possible.
IGNITE_SQL_ALLOW_KEY_VAL_UPDATES - Static variable in class org.apache.ignite.IgniteSystemProperties
Allow use composite _key, _val columns at the INSERT/UPDATE/MERGE statements.
IGNITE_SQL_DISABLE_SYSTEM_VIEWS - Static variable in class org.apache.ignite.IgniteSystemProperties
Disable SQL system views.
IGNITE_SQL_FILL_ABSENT_PK_WITH_DEFAULTS - Static variable in class org.apache.ignite.IgniteSystemProperties
Forcibly fills missing columns belonging to the primary key with nulls or default values if those have been specified.
IGNITE_SQL_FORCE_LAZY_RESULT_SET - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Since version 2.8.
IGNITE_SQL_MAX_EXTRACTED_PARTS_FROM_BETWEEN - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum number of different partitions to be extracted from between expression within sql query.
IGNITE_SQL_MERGE_TABLE_MAX_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling maximum number of SQL result rows which can be fetched into a merge table.
IGNITE_SQL_MERGE_TABLE_PREFETCH_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
Property controlling number of SQL result rows that will be fetched into a merge table at once before applying binary search for the bounds.
IGNITE_SQL_PARSER_DISABLE_H2_FALLBACK - Static variable in class org.apache.ignite.IgniteSystemProperties
Disable fallback to H2 SQL parser if the internal SQL parser fails to parse the statement.
IGNITE_SQL_RETRY_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
SQL retry timeout.
IGNITE_SQL_SYSTEM_SCHEMA_NAME_IGNITE - Static variable in class org.apache.ignite.IgniteSystemProperties
Enable backward compatible to use 'IGNITE' as SQL system schema.
IGNITE_SQL_UUID_DDL_BYTE_FORMAT - Static variable in class org.apache.ignite.IgniteSystemProperties
Enable backward compatible handling of UUID through DDL.
IGNITE_SSH_HOST - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to hold SSH host for visor-started nodes.
IGNITE_SSH_USER_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
System property to hold SSH user name for visor-started nodes.
IGNITE_START_CACHES_ON_JOIN - Static variable in class org.apache.ignite.IgniteSystemProperties
 
IGNITE_STARVATION_CHECK_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
This system property defines interval in milliseconds in which Ignite will check thread pool state for starvation.
IGNITE_STREAM_TRANSFORMER_COMPATIBILITY_MODE - Static variable in class org.apache.ignite.IgniteSystemProperties
Manages backward compatibility of StreamTransformer.from(CacheEntryProcessor) method.
IGNITE_SUCCESS_FILE - Static variable in class org.apache.ignite.IgniteSystemProperties
Name of the system property defining success file name.
IGNITE_SYSTEM_WORKER_BLOCKED_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum inactivity period for system worker in milliseconds.
IGNITE_TCP_COMM_SET_ATTR_HOST_NAMES - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables setting attribute value of ATTR_HOST_NAMES when value getLocalHost is ip, for backward compatibility.
IGNITE_TCP_DISCOVERY_ADDRESSES - Static variable in class org.apache.ignite.IgniteSystemProperties
Comma separated list of addresses in format "10.100.22.100:45000,10.100.22.101:45000".
IGNITE_TEST_ENV - Static variable in class org.apache.ignite.IgniteSystemProperties
Set to true only during the junit tests.
IGNITE_TEST_FEATURES_ENABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
If property is set to true, then test features will be enabled.
IGNITE_THREAD_DUMP_ON_EXCHANGE_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set to true then Ignite will log thread dump in case of partition exchange timeout.
IGNITE_THRESHOLD_WAIT_TIME_NEXT_WAL_SEGMENT - Static variable in class org.apache.ignite.IgniteSystemProperties
Threshold time (in millis) to print warning to log if waiting for next wal segment took longer than the threshold.
IGNITE_THRESHOLD_WAL_ARCHIVE_SIZE_PERCENTAGE - Static variable in class org.apache.ignite.IgniteSystemProperties
IGNITE_THROTTLE_INLINE_SIZE_CALCULATION - Static variable in class org.apache.ignite.IgniteSystemProperties
Throttle frequency for an index row inline size calculation and logging index inline size recommendation.
IGNITE_THROTTLE_LOG_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
Threshold for throttling operations logging.
IGNITE_TO_STRING_COLLECTION_LIMIT - Static variable in class org.apache.ignite.IgniteSystemProperties
Limit collection (map, array) elements number to output.
IGNITE_TO_STRING_INCLUDE_SENSITIVE - Static variable in class org.apache.ignite.IgniteSystemProperties
Setting to true enables writing sensitive information in toString() output.
IGNITE_TO_STRING_MAX_LENGTH - Static variable in class org.apache.ignite.IgniteSystemProperties
Maximum length for toString() result.
IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT - Static variable in class org.apache.ignite.IgniteSystemProperties
The coefficient for samples of completed transactions that will be dumped in log.
IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_PER_SECOND_LIMIT - Static variable in class org.apache.ignite.IgniteSystemProperties
The limit of samples of completed transactions that will be dumped in log per second, if IgniteSystemProperties.IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT is above 0.0.
IGNITE_TROUBLESHOOTING_LOGGER - Static variable in class org.apache.ignite.IgniteSystemProperties
Setting this option to true will enable troubleshooting logger.
IGNITE_TTL_EXPIRE_BATCH_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
When cache has entries with expired TTL, each user operation will also remove this amount of expired entries.
IGNITE_TX_DEADLOCK_DETECTION_MAX_ITERS - Static variable in class org.apache.ignite.IgniteSystemProperties
Specifies maximum number of iterations for deadlock detection procedure.
IGNITE_TX_DEADLOCK_DETECTION_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Specifies timeout for deadlock detection procedure.
IGNITE_TX_OWNER_DUMP_REQUESTS_ALLOWED - Static variable in class org.apache.ignite.IgniteSystemProperties
Shows if dump requests from local node to near node are allowed, when long running transaction is found.
IGNITE_UNWIND_THROTTLING_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Throttling timeout in millis which avoid excessive PendingTree access on unwind if there is nothing to clean yet.
IGNITE_UNWRAP_BINARY_FOR_INDEXING_SPI - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Should be removed in Apache Ignite 2.0.
IGNITE_UPDATE_NOTIFIER - Static variable in class org.apache.ignite.IgniteSystemProperties
If this system property is set to false - no checks for new versions will be performed by Ignite.
IGNITE_USE_ASYNC_FILE_IO_FACTORY - Static variable in class org.apache.ignite.IgniteSystemProperties
If this property is set, then Ignite will use Async File IO factory by default.
IGNITE_USE_BINARY_ARRAYS - Static variable in class org.apache.ignite.IgniteSystemProperties
Enables storage of typed arrays.
IGNITE_USE_LEGACY_NODE_COMPARATOR - Static variable in class org.apache.ignite.IgniteSystemProperties
If the property is set Ignite will use legacy node comparator (based on node order) inste Default value is false.
IGNITE_WAIT_FOR_BACKUPS_ON_SHUTDOWN - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Use ShutdownPolicy instead.
IGNITE_WAIT_SCHEMA_UPDATE - Static variable in class org.apache.ignite.IgniteSystemProperties
Timeout for waiting schema update if schema was not found for last accepted version.
IGNITE_WAL_COMPRESSOR_WORKER_THREAD_CNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Count of WAL compressor worker threads.
IGNITE_WAL_DEBUG_LOG_ON_RECOVERY - Static variable in class org.apache.ignite.IgniteSystemProperties
Deprecated.
Not used.
IGNITE_WAL_FSYNC_WITH_DEDICATED_WORKER - Static variable in class org.apache.ignite.IgniteSystemProperties
When set to true, WAL implementation with dedicated worker will be used even in FSYNC mode.
IGNITE_WAL_MMAP - Static variable in class org.apache.ignite.IgniteSystemProperties
Property that indicates should be mapped byte buffer used or not.
IGNITE_WAL_SEGMENT_SYNC_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Property for setup Ignite WAL segment sync timeout.
IGNITE_WAL_SERIALIZER_VERSION - Static variable in class org.apache.ignite.IgniteSystemProperties
Property for setup WAL serializer version.
IGNITE_WORK_DIR - Static variable in class org.apache.ignite.IgniteSystemProperties
Environment variable to set work directory.
IGNITE_ZOOKEEPER_DISCOVERY_MAX_RETRY_COUNT - Static variable in class org.apache.ignite.IgniteSystemProperties
Number of attempts to reconnect to ZooKeeper.
IGNITE_ZOOKEEPER_DISCOVERY_RETRY_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
Timeout between ZooKeeper client retries, default 2s.
IgniteAllNodesPredicate() - Constructor for class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
 
IgniteAsyncCallback - Annotation Type in org.apache.ignite.lang
If callback has this annotation then it will be executing in another thread.
IgniteAsyncSupport - Interface in org.apache.ignite.lang
Deprecated.
since 2.0. Please use specialized asynchronous methods.
IgniteAsyncSupported - Annotation Type in org.apache.ignite.lang
Deprecated.
since 2.0. Please use specialized asynchronous methods.
IgniteAtomicLong - Interface in org.apache.ignite
This interface provides a rich API for working with distributedly cached atomic long value.
IgniteAtomicReference<T> - Interface in org.apache.ignite
This interface provides a rich API for working with distributed atomic reference.
IgniteAtomicSequence - Interface in org.apache.ignite
This interface provides a rich API for working with distributed atomic sequence.
IgniteAtomicStamped<T,S> - Interface in org.apache.ignite
This interface provides a rich API for working with distributed atomic stamped value.
IgniteAuthenticationException - Exception in org.apache.ignite
Exception that represents authentication failure.
IgniteAuthenticationException(String) - Constructor for exception org.apache.ignite.IgniteAuthenticationException
Creates authentication exception with given error message.
IgniteBiClosure<E1,E2,R> - Interface in org.apache.ignite.lang
Defines generic closure with two parameters.
IgniteBiInClosure<E1,E2> - Interface in org.apache.ignite.lang
Closure with two in-parameters and void return type.
IgniteBinary - Interface in org.apache.ignite
Defines binary objects functionality.
IgniteBiPredicate<E1,E2> - Interface in org.apache.ignite.lang
Defines a predicate which accepts two parameters and returns true or false.
IgniteBiTuple<V1,V2> - Class in org.apache.ignite.lang
Convenience class representing mutable tuple of two values.
IgniteBiTuple() - Constructor for class org.apache.ignite.lang.IgniteBiTuple
Empty constructor required by Externalizable.
IgniteBiTuple(V1, V2) - Constructor for class org.apache.ignite.lang.IgniteBiTuple
Fully initializes this tuple.
IgniteCache<K,V> - Interface in org.apache.ignite
Main entry point for all Data Grid APIs.
igniteCacheConfiguration() - Method in interface org.apache.ignite.plugin.CachePluginContext
 
IgniteCacheRestartingException - Exception in org.apache.ignite
Exception thrown from ignite cache API if cache is restarting.
IgniteCacheRestartingException(String) - Constructor for exception org.apache.ignite.IgniteCacheRestartingException
 
IgniteCacheRestartingException(IgniteFuture<?>, String) - Constructor for exception org.apache.ignite.IgniteCacheRestartingException
 
IgniteCacheRestartingException(IgniteFuture<?>, String, Throwable) - Constructor for exception org.apache.ignite.IgniteCacheRestartingException
 
IgniteCallable<V> - Interface in org.apache.ignite.lang
Grid-aware adapter for Callable implementations.
IgniteCheckedException - Exception in org.apache.ignite
General grid exception.
IgniteCheckedException() - Constructor for exception org.apache.ignite.IgniteCheckedException
Create empty exception.
IgniteCheckedException(String) - Constructor for exception org.apache.ignite.IgniteCheckedException
Creates new exception with given error message.
IgniteCheckedException(Throwable) - Constructor for exception org.apache.ignite.IgniteCheckedException
Creates new grid exception with given throwable as a cause and source of error message.
IgniteCheckedException(String, Throwable, boolean) - Constructor for exception org.apache.ignite.IgniteCheckedException
Creates new exception with given error message and optional nested exception.
IgniteCheckedException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteCheckedException
Creates new exception with given error message and optional nested exception.
IgniteClient - Interface in org.apache.ignite.client
Ignite thin client.
IgniteClientDisconnectedException - Exception in org.apache.ignite
Exception thrown from Ignite API when client node disconnected from cluster.
IgniteClientDisconnectedException(IgniteFuture<?>, String) - Constructor for exception org.apache.ignite.IgniteClientDisconnectedException
 
IgniteClientDisconnectedException(IgniteFuture<?>, String, Throwable) - Constructor for exception org.apache.ignite.IgniteClientDisconnectedException
 
IgniteClientFuture<T> - Interface in org.apache.ignite.client
Thin client async operations future.
IgniteClientSpringBean - Class in org.apache.ignite
Represents Ignite client Spring bean that provides the ability to automatically start Ignite client during Spring Context initialization.
IgniteClientSpringBean() - Constructor for class org.apache.ignite.IgniteClientSpringBean
 
IgniteClosure<E,R> - Interface in org.apache.ignite.lang
Defines generic closure with one parameter.
IgniteCluster - Interface in org.apache.ignite
Represents whole cluster (all available nodes) and also provides a handle on IgniteCluster.nodeLocalMap() which provides map-like functionality linked to current grid node.
IgniteClusterMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use managements API beans, instead.
IgniteCompute - Interface in org.apache.ignite
Defines compute grid functionality for executing tasks and closures over nodes in the ClusterGroup.
IgniteCondition - Interface in org.apache.ignite
This interface provides a rich API for working with condition objects associated with distributed reentrant locks.
IgniteConfiguration - Class in org.apache.ignite.configuration
This class defines grid runtime configuration.
IgniteConfiguration() - Constructor for class org.apache.ignite.configuration.IgniteConfiguration
Creates valid grid configuration with all default values.
IgniteConfiguration(IgniteConfiguration) - Constructor for class org.apache.ignite.configuration.IgniteConfiguration
Creates grid configuration by coping all configuration properties from given configuration.
igniteConfiguration() - Method in interface org.apache.ignite.plugin.CachePluginContext
 
igniteConfiguration() - Method in interface org.apache.ignite.plugin.PluginContext
 
IgniteCountDownLatch - Interface in org.apache.ignite
This interface provides a rich API for working with distributed count down latch.
IgniteDataStreamer<K,V> - Interface in org.apache.ignite
Data streamer is responsible for streaming external data into cache.
IgniteDataStreamerTimeoutException - Exception in org.apache.ignite
Exception is thrown when timeout of some IgniteDataStreamer operations occurs.
IgniteDataStreamerTimeoutException(String) - Constructor for exception org.apache.ignite.IgniteDataStreamerTimeoutException
Creates new timeout exception with given error message.
IgniteDataStreamerTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteDataStreamerTimeoutException
Creates new timeout exception with given error message and optional nested exception.
IgniteDeploymentException - Exception in org.apache.ignite
Deployment or re-deployment failed.
IgniteDeploymentException(String) - Constructor for exception org.apache.ignite.IgniteDeploymentException
Creates new exception with given error message.
IgniteDeploymentException(Throwable) - Constructor for exception org.apache.ignite.IgniteDeploymentException
Creates new exception with given throwable as a nested cause and source of error message.
IgniteDeploymentException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteDeploymentException
Creates a new exception with given error message and optional nested cause exception.
IgniteDiscoveryThread - Interface in org.apache.ignite.spi.discovery
Marker interface for discovery thread on cluster server node.
IgniteEncryption - Interface in org.apache.ignite
Defines encryption features.
IgniteEvents - Interface in org.apache.ignite
Provides functionality for local and remote event notifications on nodes defined by IgniteEvents.clusterGroup().
IgniteException - Exception in org.apache.ignite
General grid exception.
IgniteException() - Constructor for exception org.apache.ignite.IgniteException
Create empty exception.
IgniteException(String) - Constructor for exception org.apache.ignite.IgniteException
Creates new exception with given error message.
IgniteException(Throwable) - Constructor for exception org.apache.ignite.IgniteException
Creates new grid exception with given throwable as a cause and source of error message.
IgniteException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteException
Creates new exception with given error message and optional nested exception.
IgniteExperimental - Annotation Type 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.
IgniteFuture<V> - Interface in org.apache.ignite.lang
Future with simplified exception handling, functional programming support and ability to listen for future completion via functional callback.
IgniteFutureCancelledException - Exception in org.apache.ignite.lang
Future computation cannot be retrieved because it was cancelled.
IgniteFutureCancelledException(String) - Constructor for exception org.apache.ignite.lang.IgniteFutureCancelledException
Creates new exception with given error message.
IgniteFutureCancelledException(Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureCancelledException
Creates new exception with given throwable as a nested cause and source of error message.
IgniteFutureCancelledException(String, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureCancelledException
Creates a new exception with given error message and optional nested cause exception.
IgniteFutureTimeoutException - Exception in org.apache.ignite.lang
Future computation completion is timed out.
IgniteFutureTimeoutException(String) - Constructor for exception org.apache.ignite.lang.IgniteFutureTimeoutException
Creates new exception with given error message.
IgniteFutureTimeoutException(Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureTimeoutException
Creates new exception with given throwable as a nested cause and source of error message.
IgniteFutureTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureTimeoutException
Creates a new exception with given error message and optional nested cause exception.
IgniteIllegalStateException - Exception in org.apache.ignite
This exception indicates the ignite access in invalid state.
IgniteIllegalStateException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteIllegalStateException
Constructs exception with given message and cause.
IgniteIllegalStateException(Throwable) - Constructor for exception org.apache.ignite.IgniteIllegalStateException
Creates exception given throwable as a cause and source of error message.
IgniteIllegalStateException(String) - Constructor for exception org.apache.ignite.IgniteIllegalStateException
Constructs exception with given message.
IgniteInClosure<E> - Interface in org.apache.ignite.lang
Closure with one in-parameter and void return type.
igniteInstanceName - Variable in class org.apache.ignite.spi.IgniteSpiAdapter
Ignite instance name.
igniteInstanceName - Variable in class org.apache.ignite.thread.IgniteThread
The name of the Ignite instance this thread belongs to.
IgniteInstanceResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of current Ignite instance.
IgniteInterruptedException - Exception in org.apache.ignite
This exception is used to wrap standard InterruptedException into IgniteException.
IgniteInterruptedException(InterruptedException) - Constructor for exception org.apache.ignite.IgniteInterruptedException
Creates new exception with given throwable as a nested cause and source of error message.
IgniteInterruptedException(String) - Constructor for exception org.apache.ignite.IgniteInterruptedException
Creates a new exception with given error message and optional nested cause exception.
IgniteInterruptedException(String, InterruptedException) - Constructor for exception org.apache.ignite.IgniteInterruptedException
Creates a new exception with given error message and optional nested cause exception.
IgniteJdbcDriver - Class in org.apache.ignite
JDBC driver implementation for In-Memory Data Grid.
IgniteJdbcDriver() - Constructor for class org.apache.ignite.IgniteJdbcDriver
 
IgniteJdbcThinDataSource - Class in org.apache.ignite
JDBC thin DataSource implementation.
IgniteJdbcThinDataSource() - Constructor for class org.apache.ignite.IgniteJdbcThinDataSource
 
IgniteJdbcThinDriver - Class in org.apache.ignite
JDBC driver thin implementation for In-Memory Data Grid.
IgniteJdbcThinDriver() - Constructor for class org.apache.ignite.IgniteJdbcThinDriver
 
IgniteLock - Interface in org.apache.ignite
This interface provides a rich API for working with distributed reentrant locks.
IgniteLogger - Interface in org.apache.ignite
This interface defines basic logging functionality used throughout the system.
IgniteMBeanAware - Interface in org.apache.ignite.mxbean
MBean-aware interface.
IgniteMessageFactory - Interface in org.apache.ignite.plugin.extensions.communication
Message factory for all communication messages registered using IgniteMessageFactory.register(short, Supplier) method call.
IgniteMessaging - Interface in org.apache.ignite
Provides functionality for topic-based message exchange among nodes defined by IgniteMessaging.clusterGroup().
IgniteMXBean - Interface in org.apache.ignite.mxbean
This interface defines JMX view on kernal.
IgniteNodeValidationResult - Class in org.apache.ignite.spi
Result of joining node validation.
IgniteNodeValidationResult(UUID, String) - Constructor for class org.apache.ignite.spi.IgniteNodeValidationResult
 
IgniteNodeValidationResult(UUID, String, String) - Constructor for class org.apache.ignite.spi.IgniteNodeValidationResult
 
IgniteNotPeerDeployable - Annotation Type in org.apache.ignite.lang
This annotations should be used to mark any type that should not be peer deployable.
IgniteOutClosure<T> - Interface in org.apache.ignite.lang
Closure that does not take any parameters and returns a value.
IgnitePlugin - Interface in org.apache.ignite.plugin
Marker interface for all Ignite plugins.
IgnitePortProtocol - Enum in org.apache.ignite.spi
Protocols supported by port processor.
IgnitePredicate<E> - Interface in org.apache.ignite.lang
Defines a predicate which accepts a parameter and returns true or false.
IgniteProducer<T> - Interface in org.apache.ignite.lang
Defines a producer which can throw IgniteCheckedException.
IgniteProductVersion - Class in org.apache.ignite.lang
Represents node version.
IgniteProductVersion() - Constructor for class org.apache.ignite.lang.IgniteProductVersion
Empty constructor required by Externalizable.
IgniteProductVersion(byte, byte, byte, long, byte[]) - Constructor for class org.apache.ignite.lang.IgniteProductVersion
 
IgniteProductVersion(byte, byte, byte, String, long, byte[]) - Constructor for class org.apache.ignite.lang.IgniteProductVersion
 
IgniteQueue<T> - Interface in org.apache.ignite
This interface provides a rich API for working with distributed queues based on In-Memory Data Grid.
IgniteReducer<E,R> - Interface in org.apache.ignite.lang
Defines generic reducer that collects multiple values and reduces them into one.
IgniteReflectionFactory<T> - Class in org.apache.ignite.configuration
Factory implementation that use reflection to create instance of given class.
IgniteReflectionFactory() - Constructor for class org.apache.ignite.configuration.IgniteReflectionFactory
Default constructor.
IgniteReflectionFactory(Class<? extends T>, boolean) - Constructor for class org.apache.ignite.configuration.IgniteReflectionFactory
 
IgniteReflectionFactory(Class<? extends T>) - Constructor for class org.apache.ignite.configuration.IgniteReflectionFactory
Creates non-singleton component factory.
IgniteRunnable - Interface in org.apache.ignite.lang
Grid-aware adapter for Runnable implementations.
IgniteScheduler - Interface in org.apache.ignite
Provides functionality for scheduling jobs locally using UNIX cron-based syntax.
IgniteSemaphore - Interface in org.apache.ignite
This interface provides a rich API for working with distributed semaphore.
IgniteServices - Interface in org.apache.ignite
Defines functionality necessary to deploy distributed services on the grid.
IgniteSet<T> - Interface in org.apache.ignite
Set implementation based on on In-Memory Data Grid.
IgniteSnapshot - Interface in org.apache.ignite
This interface provides functionality for creating cluster-wide cache data snapshots.
IgniteSpi - Interface in org.apache.ignite.spi
This interface defines life-cycle of SPI implementation.
IgniteSpiAdapter - Class in org.apache.ignite.spi
This class provides convenient adapter for SPI implementations.
IgniteSpiAdapter() - Constructor for class org.apache.ignite.spi.IgniteSpiAdapter
Creates new adapter and initializes it from the current (this) class.
IgniteSpiCloseableIterator<T> - Interface in org.apache.ignite.spi
Closeable iterator.
IgniteSpiConfiguration - Annotation Type in org.apache.ignite.spi
Annotates SPI configuration setters on whether or not it is optional.
IgniteSpiConsistencyChecked - Annotation Type in org.apache.ignite.spi
SPIs that have this annotation present will be checked for consistency within grid.
IgniteSpiContext - Interface in org.apache.ignite.spi
SPI context provides common functionality for all SPI implementations.
IgniteSpiException - Exception in org.apache.ignite.spi
Exception thrown by SPI implementations.
IgniteSpiException(String) - Constructor for exception org.apache.ignite.spi.IgniteSpiException
Creates new SPI exception with given error message.
IgniteSpiException(Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiException
Creates new SPI exception given throwable as a cause and source of error message.
IgniteSpiException(String, Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiException
Creates new SPI exception with given error message and optional nested exception.
IgniteSpiManagementMBean - Interface in org.apache.ignite.spi
This interface defines basic MBean for all SPI implementations.
IgniteSpiMBeanAdapter - Class in org.apache.ignite.spi
This class provides convenient adapter for MBean implementations.
IgniteSpiMBeanAdapter(IgniteSpiAdapter) - Constructor for class org.apache.ignite.spi.IgniteSpiMBeanAdapter
Constructor
IgniteSpiMultiException - Exception in org.apache.ignite.spi
Grid SPI exception which may contain more than one failure.
IgniteSpiMultiException(String) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
Creates new exception with given error message.
IgniteSpiMultiException(Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
Creates new grid exception with given throwable as a cause and source of error message.
IgniteSpiMultiException(String, Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
Creates new exception with given error message and optional nested exception.
IgniteSpiMultiException(String, Throwable, Collection<Throwable>) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
Creates new exception with given error message and optional nested exception.
IgniteSpiMultipleInstancesSupport - Annotation Type in org.apache.ignite.spi
Annotates whether or not multiple instances of this SPI can be started in the same VM.
IgniteSpiNoop - Annotation Type in org.apache.ignite.spi
Annotates NO-OP SPI implementations.
IgniteSpiOperationTimeoutException - Exception in org.apache.ignite.spi
Kind of exception that is used when failure detection timeout is enabled for TcpDiscoverySpi or TcpCommunicationSpi.
IgniteSpiOperationTimeoutException(String) - Constructor for exception org.apache.ignite.spi.IgniteSpiOperationTimeoutException
Constructor.
IgniteSpiOperationTimeoutHelper - Class in org.apache.ignite.spi
Object that incorporates logic that determines a timeout value for the next network related operation and checks whether a failure detection timeout is reached or not.
IgniteSpiOperationTimeoutHelper(IgniteSpiAdapter, boolean) - Constructor for class org.apache.ignite.spi.IgniteSpiOperationTimeoutHelper
Constructor.
IgniteSpiOperationTimeoutHelper(IgniteSpiAdapter, boolean, long, long) - Constructor for class org.apache.ignite.spi.IgniteSpiOperationTimeoutHelper
Creates timeout helper based on time of last related operation.
IgniteSpiThread - Class in org.apache.ignite.spi
This class provides convenient adapter for threads used by SPIs.
IgniteSpiThread(String, String, IgniteLogger) - Constructor for class org.apache.ignite.spi.IgniteSpiThread
Creates thread with given name.
IgniteSpiThreadFactory - Class in org.apache.ignite.spi
This class provides implementation of ThreadFactory factory for creating grid SPI threads.
IgniteSpiThreadFactory(String, String, IgniteLogger) - Constructor for class org.apache.ignite.spi.IgniteSpiThreadFactory
 
IgniteSpiTimeoutObject - Interface in org.apache.ignite.spi
Provides possibility to schedule delayed execution, see IgniteSpiContext.addTimeoutObject(IgniteSpiTimeoutObject).
IgniteSpiVersionCheckException - Exception in org.apache.ignite.spi
Grid SPI exception for version check failure.
IgniteSpiVersionCheckException(String) - Constructor for exception org.apache.ignite.spi.IgniteSpiVersionCheckException
Creates new SPI exception with given error message.
IgniteSpiVersionCheckException(Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiVersionCheckException
Creates new SPI exception given throwable as a cause and source of error message.
IgniteSpiVersionCheckException(String, Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiVersionCheckException
Creates new SPI exception with given error message and optional nested exception.
IgniteSpring - Class in org.apache.ignite
Factory methods to start Ignite with optional Spring application context, this context can be injected into grid tasks and grid jobs using @SpringApplicationContextResource annotation.
IgniteSpring() - Constructor for class org.apache.ignite.IgniteSpring
 
IgniteSpringBean - Class in org.apache.ignite
Ignite Spring bean allows to bypass Ignition methods.
IgniteSpringBean() - Constructor for class org.apache.ignite.IgniteSpringBean
 
IgniteState - Enum in org.apache.ignite
Possible states of Ignition.
IgniteStripedThreadPoolExecutor - Class in org.apache.ignite.thread
An ExecutorService that executes submitted tasks using pooled grid threads.
IgniteStripedThreadPoolExecutor(int, String, String, Thread.UncaughtExceptionHandler, boolean, long) - Constructor for class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
Create striped thread pool.
IgniteSystemProperties - Class in org.apache.ignite
Contains constants for all system properties and environmental variables in Ignite.
IgniteThread - Class in org.apache.ignite.thread
This class adds some necessary plumbing on top of the Thread class.
IgniteThread(GridWorker) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates thread with given worker.
IgniteThread(String, String) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates grid thread with given name for a given Ignite instance.
IgniteThread(String, String, Runnable) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates grid thread with given name for a given Ignite instance.
IgniteThread(String, String, Runnable, int, int, byte) - Constructor for class org.apache.ignite.thread.IgniteThread
Creates grid thread with given name for a given Ignite instance with specified thread group.
IgniteThread(String, ThreadGroup, String) - Constructor for class org.apache.ignite.thread.IgniteThread
 
IgniteThreadFactory - Class in org.apache.ignite.thread
This class provides implementation of ThreadFactory factory for creating grid threads.
IgniteThreadFactory(String, String) - Constructor for class org.apache.ignite.thread.IgniteThreadFactory
Constructs new thread factory for given grid.
IgniteThreadFactory(String, String, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.ignite.thread.IgniteThreadFactory
Constructs new thread factory for given grid.
IgniteThreadFactory(String, String, byte, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.ignite.thread.IgniteThreadFactory
Constructs new thread factory for given grid.
IgniteThreadPoolExecutor - Class in org.apache.ignite.thread
An ExecutorService that executes submitted tasks using pooled grid threads.
IgniteThreadPoolExecutor(String, String, int, int, long, BlockingQueue<Runnable>) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with the given initial parameters.
IgniteThreadPoolExecutor(String, String, int, int, long, BlockingQueue<Runnable>, byte, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with the given initial parameters.
IgniteThreadPoolExecutor(int, int, long, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with the given initial parameters.
IgniteThreadPoolExecutor(int, int, long, BlockingQueue<Runnable>, ThreadFactory, HistogramMetricImpl) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
Creates a new service with the given initial parameters.
IgniteTransactions - Interface in org.apache.ignite
Transactions facade provides ACID-compliant semantic when working with caches.
IgniteUuid - Class in org.apache.ignite.lang
This is a faster performing version of UUID.
IgniteUuid() - Constructor for class org.apache.ignite.lang.IgniteUuid
Empty constructor required for Externalizable.
IgniteUuid(UUID, long) - Constructor for class org.apache.ignite.lang.IgniteUuid
Constructs IgniteUuid from a global and local identifiers.
IgniteWalConverter - Class in org.apache.ignite.development.utils
Print WAL log data in human-readable form.
IgniteWalConverter() - Constructor for class org.apache.ignite.development.utils.IgniteWalConverter
 
IgniteWalConverterArguments - Class in org.apache.ignite.development.utils
Parameters for IgniteWalConverter with parsed and validated.
IgniteWalConverterArguments(File, File, int, File, File, boolean, Set<WALRecord.RecordType>, Long, Long, String, ProcessSensitiveData, boolean, boolean, Collection<T2<Integer, Long>>) - Constructor for class org.apache.ignite.development.utils.IgniteWalConverterArguments
Constructor.
Ignition - Class in org.apache.ignite
This class defines a factory for the main Ignite API.
Ignition() - Constructor for class org.apache.ignite.Ignition
Enforces singleton.
IgnitionListener - Interface in org.apache.ignite
Listener for gird state change notifications.
IgnitionMXBean - Interface in org.apache.ignite.mxbean
This interface defines JMX view on Ignition.
IgnoreIfPeerClassLoadingDisabled - Annotation Type in org.apache.ignite.spi.deployment
This annotation is for all implementations of DeploymentSpi that may be ignored if peer class loading is disabled.
impl - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
impl() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
 
implicit() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
implicit() - Method in interface org.apache.ignite.transactions.Transaction
Flag indicating whether transaction was started automatically by the system or not.
implicitSingle() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
in(String, Collection<?>) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
In.
includedScopes() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters
 
includeNotReadyAddresses(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Deprecated.
set parameters with KubernetesConnectionConfiguration instead.
incomeConnLsnrs - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
incrementAndGet() - Method in interface org.apache.ignite.client.ClientAtomicLong
Increments and gets current value of atomic long.
incrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicLong
Increments and gets current value of atomic long.
incrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicSequence
Increments and returns the value of atomic sequence.
incrementIndex() - Method in class org.apache.ignite.spi.systemview.view.SnapshotView
 
incrementState() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Increments read state.
incrementState() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Increments state.
index() - Method in enum org.apache.ignite.ShutdownPolicy
 
IndexingQueryCacheFilter - Class in org.apache.ignite.spi.indexing
Indexing query filter for specific cache.
IndexingQueryCacheFilter(GridCacheAffinityManager, Set<Integer>, AffinityTopologyVersion, ClusterNode) - Constructor for class org.apache.ignite.spi.indexing.IndexingQueryCacheFilter
Constructor.
IndexingQueryEngineConfiguration - Class in org.apache.ignite.indexing
Query engine configuration for indexing-backed query engine.
IndexingQueryEngineConfiguration() - Constructor for class org.apache.ignite.indexing.IndexingQueryEngineConfiguration
 
IndexingQueryFilter - Interface in org.apache.ignite.spi.indexing
Cache entry filter.
IndexingQueryFilterImpl - Class in org.apache.ignite.spi.indexing
Indexing query filter.
IndexingQueryFilterImpl(GridKernalContext, AffinityTopologyVersion, int[], boolean) - Constructor for class org.apache.ignite.spi.indexing.IndexingQueryFilterImpl
Constructor.
IndexingQueryFilterImpl(GridKernalContext, AffinityTopologyVersion, int[]) - Constructor for class org.apache.ignite.spi.indexing.IndexingQueryFilterImpl
Constructor.
IndexingSpi - Interface in org.apache.ignite.spi.indexing
Indexing SPI allows user to index cache content.
indexName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns index name.
IndexQuery<K,V> - Class in org.apache.ignite.cache.query
Index queries work over distributed indexes and retrieve cache entries that match the specified criteria.
IndexQuery(Class<?>) - Constructor for class org.apache.ignite.cache.query.IndexQuery
Specify index with cache value class.
IndexQuery(String) - Constructor for class org.apache.ignite.cache.query.IndexQuery
Specify index with cache value type.
IndexQuery(Class<?>, String) - Constructor for class org.apache.ignite.cache.query.IndexQuery
Specify index with cache value class and index name.
IndexQuery(String, String) - Constructor for class org.apache.ignite.cache.query.IndexQuery
Specify index with cache value type and index name.
IndexQueryCriteriaBuilder - Class in org.apache.ignite.cache.query
IndexQueryCriteriaBuilder() - Constructor for class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
 
IndexQueryCriterion - Interface in org.apache.ignite.cache.query
Basic interface for IndexQuery criterion.
indexReadyFuture() - Method in interface org.apache.ignite.IgniteCache
Returns future that will be completed when all indexes for this cache are ready to use.
indexType() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns index type.
info(String) - Method in interface org.apache.ignite.IgniteLogger
Logs out information message.
info(String, String) - Method in interface org.apache.ignite.IgniteLogger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out information message.
info(String, String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.NullLogger
Logs out information message.
info(String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out information message.
info(String, String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out information message.
init(FilterConfig) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
init(PlatformAffinityFunction) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Initializes this instance.
init() - Method in interface org.apache.ignite.services.Service
Pre-initializes service before execution.
init(ServiceContext) - Method in interface org.apache.ignite.services.Service
Deprecated.
Use Service.init() instead.
init() - Method in class org.apache.ignite.startup.servlet.ServletStartup
initExtensions(PluginContext, ExtensionRegistry) - Method in interface org.apache.ignite.plugin.PluginProvider
Registers extensions.
initFailureDetectionTimeout() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Initiates and checks failure detection timeout value.
initialCount() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets initial count value of the latch.
initialCount() - Method in class org.apache.ignite.spi.systemview.view.datastructures.CountDownLatchView
 
initializeLocalAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Initializes addresses discovery SPI binds to.
initializeLocalAddresses(Collection<InetSocketAddress>) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Initializes addresses discovery SPI binds to.
initializeLocalAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Initializes addresses discovery SPI binds to.
initiatorId() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
initLocalNode(int, boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
injectables() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
This method returns SPI internal instances that need to be injected as well.
injectables() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
This method returns SPI internal instances that need to be injected as well.
injectResources(Ignite) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Inject ignite instance.
injectResources(Ignite) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Inject resources
injectResources(Ignite) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Inject ignite instance.
inlineSize() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns inline size in bytes.
inProgress() - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Deprecated.
Get defragmentation status.
inputIterator(Object...) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Returns iterator of input records.
insertQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct insert query.
insertQuery(String, Collection<String>, Collection<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct insert query.
INSTANCE - Static variable in class org.apache.ignite.cache.store.jdbc.JdbcTypeDefaultHasher
Singleton instance to use.
INSTANCE - Static variable in class org.apache.ignite.cache.store.jdbc.JdbcTypesDefaultTransformer
Singleton instance to use.
INSTANCE - Static variable in class org.apache.ignite.logger.NullLogger
Singleton instance.
INSTANCE - Static variable in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
Instance.
INSTANCE - Static variable in class org.apache.ignite.thread.SameThreadExecutor
 
INSTANCE_NAME_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
INSTANCE_NAME_TAG - Static variable in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Ignite instance name.
interceptor() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
interceptors - Variable in class org.apache.ignite.services.ServiceConfiguration
Interceptor.
internal() - Method in class org.apache.ignite.events.TaskEvent
Returns true if task is created by Ignite and is used for system needs.
internal() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
internal() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
interval() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
intervalEnd() - Method in class org.apache.ignite.spi.systemview.view.PagesTimestampHistogramView
 
intervalStart() - Method in class org.apache.ignite.spi.systemview.view.PagesTimestampHistogramView
 
IntMetric - Interface in org.apache.ignite.spi.metric
Interface for the metrics that holds int primitive.
invoke(K, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Please refer to documentation for CacheAtomicityMode.ATOMIC for information on system behavior in crash scenarios for atomic caches.
invoke(K, CacheEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Invokes an CacheEntryProcessor against the Cache.Entry specified by the provided key.
invoke(String, Object[], ServiceContext, Callable<Object>) - Method in interface org.apache.ignite.services.ServiceCallInterceptor
Intercepts delegated service call.
invoke(String, Object[], String[]) - Method in class org.apache.ignite.spi.metric.jmx.ReadOnlyDynamicMBean
invokeAll(Map<? extends K, ? extends EntryProcessor<K, V, T>>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously invokes each EntryProcessor from map's values against the correspondent Cache.Entry specified by map's key set.
invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Please refer to documentation for CacheAtomicityMode.ATOMIC for information on system behavior in crash scenarios for atomic caches.
invokeAll(Set<? extends K>, CacheEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Invokes an CacheEntryProcessor against the set of Cache.Entrys specified by the set of keys.
invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
invokeAllAsync(Map<? extends K, ? extends EntryProcessor<K, V, T>>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronous version of the IgniteCache.invokeAll(Map, Object...) method.
invokeAllAsync(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously invokes an EntryProcessor against the set of Cache.Entrys specified by the set of keys.
invokeAllAsync(Set<? extends K>, CacheEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously invokes an CacheEntryProcessor against the set of Cache.Entrys specified by the set of keys.
invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
invokeAsync(K, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously invokes an EntryProcessor against the Cache.Entry specified by the provided key.
invokeAsync(K, CacheEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously invokes an CacheEntryProcessor against the Cache.Entry specified by the provided key.
IoPool - Interface in org.apache.ignite.plugin.extensions.communication
The interface of IO Messaging Pool Extension.
ipFinder - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
IP finder.
ipFinderCleanFreq - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
The frequency with which coordinator cleans IP finder and keeps it in the correct state, which means that coordinator unregisters addresses of the nodes that have left the topology and re-registries missing addresses.
IS_NODE_BASELINE_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
IS_PEER_CLS_LOADING_ENABLED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
IS_REBALANCE_ENABLED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
isActiveOnStart() - Method in class org.apache.ignite.configuration.IgniteConfiguration
isAllSegmentationResolversPassRequired() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets all segmentation resolvers pass required flag.
isAlwaysWriteFullPages() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
isAlwaysWriteFullPages() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
isAsync() - Method in interface org.apache.ignite.lang.IgniteAsyncSupport
Deprecated.
since 2.0. Please use new specialized async method e.g.
     IgniteFuture f = cache.getAsync();
 
instead of old-style async API:
     IgniteCache asyncCache = cache.withAsync();
     asyncCache.get(key);
     IgniteFuture fut = asyncCache.future();
 
isAttemptToEstablishDirectConnectionWhenOnlyInverseIsAllowed(Throwable) - Static method in class org.apache.ignite.spi.communication.tcp.ClientExceptionsUtils
Returns true if the exception that is provided is thrown because an attempt to open a direct connection was made while only inverse connections are allowed.
isAuthenticationEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns true if user authentication is enabled for cluster.
isAutoActivationEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
isAutoAdjustEnabled() - Method in class org.apache.ignite.events.BaselineConfigurationChangedEvent
 
isAutoAdjustmentEnabled() - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
Deprecated.
Use managements API beans, instead.
isAutoBinaryConfigurationEnabled() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets a value indicating whether automatic binary configuration retrieval should be enabled.
isAutoCloseServerCursor() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isAutoStartup() - Method in class org.apache.ignite.IgniteClientSpringBean
isAutoUnsubscribe() - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Gets automatic unsubscription flag value.
isBackup(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Returns true if local node is one of the backup nodes for given key.
isBaselineAutoAdjustEnabled() - Method in interface org.apache.ignite.IgniteCluster
 
isBroken() - Method in interface org.apache.ignite.IgniteLock
Returns true if any node that owned the locked failed before releasing the lock.
isBroken() - Method in interface org.apache.ignite.IgniteSemaphore
Gets broken status of the semaphore.
isCached() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Checks whether entry is currently present in cache or not.
isCacheSanityCheckEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets flag indicating whether cache sanity check is enabled.
isCancelled() - Method in class org.apache.ignite.compute.ComputeJobAdapter
This method tests whether or not this job was cancelled.
isCancelled() - Method in interface org.apache.ignite.compute.ComputeJobResult
Gets job cancellation status.
isCancelled() - Method in interface org.apache.ignite.lang.IgniteFuture
Returns true if this task was cancelled before it completed normally.
isCancelled() - Method in interface org.apache.ignite.services.ServiceContext
Get flag indicating whether service has been cancelled or not.
isCdcEnabled() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets flag indicating whether CDC is enabled.
isCheckMd5() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Gets checkMd5 property.
isCheckMd5() - Method in interface org.apache.ignite.spi.deployment.uri.UriDeploymentSpiMBean
Indicates if this SPI should check new deployment units md5 for redundancy.
isClient() - Method in interface org.apache.ignite.cluster.ClusterNode
Whether this node is cache client (see IgniteConfiguration.isClientMode()).
isClient() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
 
isClient() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Whether this node is cache client (see IgniteConfiguration.isClientMode()).
isClient() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
isClientMode() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets client mode flag.
isClientMode() - Static method in class org.apache.ignite.Ignition
Gets client mode thread-local flag.
isClientMode() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Whether or not discovery is started in client mode.
isClientMode() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Whether or not discovery is started in client mode.
isClientMode() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Whether or not discovery is started in client mode.
isClientMode() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
Whether or not discovery is started in client mode.
isClientMode() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Whether or not discovery is started in client mode.
isClientNodeTopologyException(Throwable, ClusterNode) - Static method in class org.apache.ignite.spi.communication.tcp.ClientExceptionsUtils
Returns true if the exception relates to cluster topology change that prevents a connection, AND the given node is client.
isClientReconnectDisabled() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
If true client does not try to reconnect after server detected client node failure.
isClientReconnectDisabled() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
If true client does not try to reconnect.
isClosed() - Method in class org.apache.ignite.cache.CacheManager
isClusterDiscoveryEnabled() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets a value indicating whether cluster discovery should be enabled.
isCollocated() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Checks if this query is collocated.
isCollocated() - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
isCollocated() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isColocated() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
isCompactFooter() - Method in class org.apache.ignite.configuration.BinaryConfiguration
Get whether to write footers in compact form.
isConfigured() - Static method in class org.apache.ignite.logger.java.JavaLogger
Checks if logger is already configured within this VM or not.
isConfigured() - Static method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Checks if Log4j is already configured within this VM or not.
isCopyOnRead() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
isCopyOnRead() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets the flag indicating whether a copy of the value stored in the on-heap cache (see CacheConfiguration.isOnheapCacheEnabled() should be created for a cache operation return the value.
isCopyOnRead() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isCorrect() - Method in interface org.apache.ignite.events.CacheConsistencyViolationEvent.EntryInfo
 
isDebugEnabled() - Method in interface org.apache.ignite.IgniteLogger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.java.JavaLogger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.jcl.JclLogger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.NullLogger
Tests whether debug level is enabled.
isDebugEnabled() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Tests whether debug level is enabled.
isDefault() - Method in class org.apache.ignite.calcite.CalciteQueryEngineConfiguration
Is this query engine should be used by default.
isDefault() - Method in interface org.apache.ignite.configuration.QueryEngineConfiguration
Is this query engine should be used by default.
isDefault() - Method in class org.apache.ignite.indexing.IndexingQueryEngineConfiguration
Is this query engine should be used by default.
isDefaultKeepDeserialized() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
Gets default keep deserialized flag.
isDirectBuffer() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets flag indicating whether REST TCP server should use direct buffers.
isDirectBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets flag that indicates whether direct or heap allocated buffer is used.
isDirectSendBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets flag defining whether direct send buffer should be used.
isDistributedJoins() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Check if distributed joins are enabled for this query.
isDistributedJoins() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Check if distributed joins are enabled for this query.
isDistributedJoins() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isDone() - Method in interface org.apache.ignite.lang.IgniteFuture
Returns true if this task completed.
isEagerTtl() - Method in class org.apache.ignite.client.ClientCacheConfiguration
Gets flag indicating whether expired cache entries will be eagerly removed from cache.
isEagerTtl() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets flag indicating whether expired cache entries will be eagerly removed from cache.
isEagerTtl() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isEmpty() - Method in interface org.apache.ignite.cache.CacheMetrics
Returns true if this cache is empty.
isEmpty() - Method in class org.apache.ignite.cache.QueryEntityPatch
 
isEmpty() - Method in interface org.apache.ignite.client.ClientIgniteSet
isEmpty() - Method in interface org.apache.ignite.IgniteQueue
isEmpty() - Method in interface org.apache.ignite.IgniteSet
isEmpty() - Method in class org.apache.ignite.lang.IgniteBiTuple
isEnabled(int) - Method in interface org.apache.ignite.IgniteEvents
Check if event is enabled.
isEncryptionEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets flag indicating whether data must be encrypted.
isEncryptionEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isEnded() - Method in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
isEnded() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
isEnded() - Method in interface org.apache.ignite.spi.tracing.SpiSpecificSpan
 
isEnforceJoinOrder() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Checks if join order of tables if enforced.
isEnforceJoinOrder() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isEnum() - Method in interface org.apache.ignite.binary.BinaryType
Check whether type represents enum or not.
isEnum() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Gets whether this is enum type.
isEnum() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Gets whether this is enum type.
isEnum() - Method in class org.apache.ignite.spi.systemview.view.BinaryMetadataView
 
isEventRecordable(int...) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Checks whether all provided event types are recordable.
isEvents() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
isEventsDisabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Checks whether events are disabled for this cache.
isEventsDisabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isExcluded(Class<?>) - Static method in class org.apache.ignite.marshaller.MarshallerExclusions
Checks whether or not given class should be excluded from marshalling.
isExcludeNeighbors() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Checks flag to exclude same-host-neighbors from being backups of each other (default is false).
isFailoverSafe() - Method in interface org.apache.ignite.IgniteLock
Returns true if this lock is safe to use after node failure.
isFailoverSafe() - Method in interface org.apache.ignite.IgniteSemaphore
Returns true if this semaphore is safe to use after node failure.
isFair() - Method in interface org.apache.ignite.IgniteLock
Returns true if this lock is fair.
isFinishing() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
isForbiddenToRequestBinaryMetadata() - Method in class org.apache.ignite.thread.IgniteThread
 
isForceServerMode() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Deprecated.
Will be removed at 3.0.
isGlobalNodeAuthentication() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiNodeAuthenticator
Gets global node authentication flag.
isHeaderWritten() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
 
isHeartbeatEnabled() - Method in class org.apache.ignite.configuration.ClientConfiguration
Gets a value indicating whether heartbeats are enabled.
isHeldByCurrentThread() - Method in interface org.apache.ignite.IgniteLock
Queries if this lock is held by the current thread.
isHelp(String) - Static method in class org.apache.ignite.startup.cmdline.CommandLineStartup
Tests whether argument is help argument.
isIncludeExpired() - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Gets the flag value defining whether to notify about EventType.EXPIRED events.
isIndexRebuildInProgress() - Method in interface org.apache.ignite.cache.CacheMetrics
Return true if index rebuild is in progress.
isIndexRebuildInProgress() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
 
isInfoEnabled() - Method in interface org.apache.ignite.IgniteLogger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.java.JavaLogger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.jcl.JclLogger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.NullLogger
Tests whether info level is enabled.
isInfoEnabled() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Tests whether info level is enabled.
isInternal() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
isInvalidate() - Method in class org.apache.ignite.configuration.CacheConfiguration
Invalidation flag.
isInvalidate() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isInvalidate() - Method in interface org.apache.ignite.transactions.Transaction
Get invalidation flag for this transaction.
isJdbcEnabled() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets whether access through JDBC is enabled.
isJoiningNodeClient() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
isKeepBinary() - Method in class org.apache.ignite.cdc.CdcConfiguration
 
isKeepBinary() - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Gets a value indicating whether platform cache should store keys and values in binary form.
isKeepBinary() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Keep binary flag.
isKeepDeserialized() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
isLastRead() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Tells whether last invocation of any of readXXX(...)
isLateAffinityAssignment() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Starting from Ignite 2.1 late affinity assignment is always enabled.
isLazy() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Deprecated.
Use Query.getPageSize() instead.
isLazy() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isLazyMemoryAllocation() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
 
isLoadPreviousValue() - Method in class org.apache.ignite.configuration.CacheConfiguration
isLoadPreviousValue() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isLocal() - Method in class org.apache.ignite.cache.query.Query
Returns true if this query should be executed on local node only.
isLocal() - Method in interface org.apache.ignite.cluster.ClusterNode
Tests whether or not this node is a local node.
isLocal() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Tests whether or not this node is a local node.
isLocal() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
isLocalLocked(K, boolean) - Method in interface org.apache.ignite.IgniteCache
Checks if specified key is locked.
isLocalNodeCoordinator() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Checks whether local node is coordinator.
isLocked() - Method in interface org.apache.ignite.IgniteLock
Queries if this lock is held by any thread on any node.
isLoggable(LogRecord) - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
isLowerCase() - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
Gets whether to use strings in lower case or not.
isMaintenanceMode() - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
 
isManagementEnabled() - Method in interface org.apache.ignite.cache.CacheMetrics
Checks whether management is enabled on this cache.
isManagementEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isMarshalLocalJobs() - Method in class org.apache.ignite.configuration.IgniteConfiguration
If this flag is set to true, jobs mapped to local node will be marshalled as if it was remote node.
isMessaging() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
isMetricsEnabled() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets whether memory metrics are enabled by default on node startup.
isMetricsEnabled() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Deprecated.
Will be removed in upcoming releases.
isMetricsEnabled() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Gets whether memory metrics are enabled by default on node startup.
isMetricsEnabled() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Gets flag indicating whether persistence metrics collection is enabled.
isMutable() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiCustomMessage
 
isNear() - Method in class org.apache.ignite.events.CacheEvent
Gets flag indicating whether event happened on near or partitioned cache.
isNearCacheEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isNodeInBaseline() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.isNodeInBaseline" instead.
isNoDelay() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets flag indicating whether TCP_NODELAY option should be set for accepted client connections.
isNodeStopping() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
 
isOdbcEnabled() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets whether access through ODBC is enabled.
IsolatedDiscoverySpi - Class in org.apache.ignite.spi.discovery.isolated
Special discovery SPI implementation to start a single-node cluster in "isolated" mode.
IsolatedDiscoverySpi() - Constructor for class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
 
IsolatedNode - Class in org.apache.ignite.spi.discovery.isolated
Special isolated node.
IsolatedNode(UUID, Map<String, Object>, IgniteProductVersion) - Constructor for class org.apache.ignite.spi.discovery.isolated.IsolatedNode
 
isolation() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
isolation() - Method in interface org.apache.ignite.transactions.Transaction
Cache transaction isolation level.
isOnheapCacheEnabled() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
isOnheapCacheEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Checks if the on-heap cache is enabled for the off-heap based page memory.
isOnheapCacheEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isPartitionAwarenessEnabled() - Method in class org.apache.ignite.configuration.ClientConfiguration
Default is true: client sends requests directly to the primary node for the given cache key.
isPeerClassLoadingEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Returns true if peer class loading is enabled, false otherwise.
isPeerClassLoadingEnabled() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.isPeerClassLoadingEnabled" instead.
isPersistenceEnabled() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Gets whether persistence is enabled for this data region.
isPersistentStoreEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Part of legacy configuration API. Doesn't work if new configuration API is used.
isPerTask() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
isPerTask() - Method in interface org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpiMBean
Configuration parameter indicating whether a new round robin order should be created for every task.
isPk() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns boolean value which indicates whether this index is for primary key or not.
isPrimary(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Returns true if given node is the primary node for given key.
isPrimary() - Method in interface org.apache.ignite.events.CacheConsistencyViolationEvent.EntryInfo
 
isPrimary() - Method in class org.apache.ignite.spi.systemview.view.PartitionStateView
 
isPrimaryOrBackup(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Returns true if local node is primary or one of the backup nodes This method is essentially equivalent to calling "Affinity.isPrimary(ClusterNode, Object) || Affinity.isBackup(ClusterNode, Object))", however it is more efficient as it makes both checks at once.
isPrintStat() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Write summary statistics for WAL.
isQuery() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
isQuiet() - Method in interface org.apache.ignite.IgniteLogger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.java.JavaLogger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.jcl.JclLogger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.NullLogger
Tests whether Logger is in "Quiet mode".
isQuiet() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Tests whether Logger is in "Quiet mode".
isReadFromBackup() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
isReadFromBackup() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets flag indicating whether data can be read from backup.
isReadFromBackup() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isReadThrough() - Method in interface org.apache.ignite.cache.CacheMetrics
Determines if a Cache should operate in read-through mode.
isReadThrough() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isRebalanceEnabled() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.isRebalanceEnabled" instead.
isReplicatedOnly() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Deprecated.
No longer used as of Apache Ignite 2.8.
isReplicatedOnly() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
No longer used as of Apache Ignite 2.8.
isReplicatedOnly() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isRestore() - Method in class org.apache.ignite.events.CacheObjectTransformedEvent
 
isRollbackOnly() - Method in interface org.apache.ignite.transactions.Transaction
If transaction was marked as rollback-only.
isRunning() - Method in class org.apache.ignite.IgniteClientSpringBean
isRunning() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Returns true if scheduled task is currently running.
isShared() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Checks whether IP finder is shared or not.
isShared() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Checks whether IP finder is shared or not.
isShared() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
isShutdown() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
isSimpleName() - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
Gets whether to use simple name of class or not.
isSingleton() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
 
isSkipCrc() - Method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Skip CRC calculation/check flag.
isSkipReducerOnUpdate() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isSqlEscapeAll() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
isSqlEscapeAll() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
isSqlEscapeAll() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
isSqlEscapeAll() - Method in class org.apache.ignite.configuration.CacheConfiguration
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
isSqlEscapeAll() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isSqlOnheapCacheEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Gets whether SQL on-heap cache is enabled.
isSqlOnheapCacheEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isSslClientAuth() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets a flag indicating whether or not remote clients will be required to have a valid SSL certificate which validity will be verified with trust manager.
isSslClientAuth() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Gets a flag indicating whether or not remote clients will be required to have a valid SSL certificate which validity will be verified with trust manager.
isSslEnabled() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Whether secure socket layer should be enabled on client connector.
isSslEnabled() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Whether secure socket layer should be enabled on binary rest server.
isSslTrustAll() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
isSslTrustAll() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Gets trust any server certificate flag.
isStarted() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
isStarvationPreventionEnabled() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Gets flag indicating whether job starvation prevention is enabled.
isStarvationPreventionEnabled() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Gets flag indicating whether job starvation prevention is enabled.
isStatisticsEnabled() - Method in interface org.apache.ignite.cache.CacheMetrics
Checks whether statistics collection is enabled in this cache.
isStatisticsEnabled() - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
isStatisticsEnabled - Variable in class org.apache.ignite.services.ServiceConfiguration
Enables or disables service statistics.
isStatisticsEnabled() - Method in class org.apache.ignite.services.ServiceConfiguration
Tells wheter statistics for this service is enabled.
isStatisticsEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isStealingEnabled() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
isStealingEnabled() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets flag indicating whether this node should attempt to steal jobs from other nodes.
isStopping() - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
isStoreByValue() - Method in interface org.apache.ignite.cache.CacheMetrics
Whether storeByValue true or storeByReference false.
isStoreKeepBinary() - Method in class org.apache.ignite.configuration.CacheConfiguration
Flag indicating that CacheStore implementation is working with binary objects instead of Java objects.
isStoreKeepBinary() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isSuccess() - Method in interface org.apache.ignite.cluster.ClusterStartNodeResult
Gets result of success or failure.
isSupported(OptionalFeature) - Method in class org.apache.ignite.cache.CachingProvider
isSystemType(String) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Checks whether the given type is a system one - JDK class or Ignite class.
isTcpNoDelay() - Method in class org.apache.ignite.configuration.ClientConfiguration
 
isTcpNoDelay() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Get TCP NO_DELAY flag.
isTcpNoDelay() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Get TCP NO_DELAY flag.
isTcpNoDelay() - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
isTcpNoDelay() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Gets value for TCP_NODELAY socket option.
isTerminated() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
isThinClientEnabled() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets whether access through thin client is enabled.
isTimedOut() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
isTraceEnabled() - Method in interface org.apache.ignite.IgniteLogger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.java.JavaLogger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.jcl.JclLogger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.NullLogger
Tests whether trace level is enabled.
isTraceEnabled() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Tests whether trace level is enabled.
isTxSerializableEnabled() - Method in class org.apache.ignite.configuration.TransactionConfiguration
Deprecated.
isUnique() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns boolean value which indicates whether this index is unique or not.
isUseAverage() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Gets flag indicating whether to use average CPU load vs. current.
isUseAverage() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
Gets flag indicating whether to use average job counts vs. current.
isUseAverage() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
Gets flag indicating whether to use average execution time vs. current.
isUseIgniteSslContextFactory() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Gets whether to use Ignite SSL context factory configured through IgniteConfiguration.getSslContextFactory() if ClientConnectorConfiguration.getSslContextFactory() is not set.
isUseJtaSynchronization() - Method in class org.apache.ignite.configuration.TransactionConfiguration
 
isUsePairedConnections() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
Returns true if TcpCommunicationSpi should maintain connection for outgoing and incoming messages separately.
isUseProcessors() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Gets flag indicating whether to use average CPU load vs. current (default is true).
isUseWeights() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
isUseWeights() - Method in interface org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpiMBean
Checks whether node weights are considered when doing random load balancing.
isValidationEnabled() - Method in class org.apache.ignite.configuration.SqlConfiguration
Is key & value validation enabled.
isValidForReading() - Method in interface org.apache.ignite.cache.CacheMetrics
Checks whether cache topology is valid for read operations.
isValidForWriting() - Method in interface org.apache.ignite.cache.CacheMetrics
Checks whether cache topology is valid for write operations.
isValidSegment() - Method in interface org.apache.ignite.plugin.segmentation.SegmentationResolver
Checks whether segment is valid.
isWaitForSegmentOnStart() - Method in class org.apache.ignite.configuration.IgniteConfiguration
Gets wait for segment on startup flag.
isWalCompactionEnabled() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
isWalEnabled(String) - Method in interface org.apache.ignite.client.ClientCluster
Checks if write-ahead logging is enabled for specified cache.
isWalEnabled(String) - Method in interface org.apache.ignite.IgniteCluster
Checks if write-ahead logging is enabled for specified cache.
isWalHistorySizeParameterUsed() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
If WalHistorySize was set by user will use this parameter for compatibility.
isWithinTransaction() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Returns true if performing store operation within a transaction, false otherwise.
isWrapperFor(Class<?>) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
isWriteBehindEnabled() - Method in interface org.apache.ignite.cache.CacheMetrics
Returns true if write-behind is enabled.
isWriteBehindEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
Flag indicating whether Ignite should use write-behind behaviour for the cache store.
isWriteBehindEnabled() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
isWriteThrottlingEnabled() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
isWriteThrottlingEnabled() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
isWriteThrough() - Method in interface org.apache.ignite.cache.CacheMetrics
Determines if a Cache should operate in "write-through" mode.
isWriteThrough() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
iteration() - Method in interface org.apache.ignite.client.ClientRetryPolicyContext
Gets the current iteration number (zero-based).
iterator() - Method in class org.apache.ignite.cache.query.BulkLoadContextCursor
iterator() - Method in interface org.apache.ignite.client.ClientIgniteSet
Returns an iterator over the elements in this collection.
iterator() - Method in interface org.apache.ignite.IgniteQueue
iterator() - Method in interface org.apache.ignite.IgniteSet
iterator() - Method in class org.apache.ignite.lang.IgniteBiTuple
iterator() - Method in class org.apache.ignite.lang.IgniteUuid
iterator(Map<String, Object>) - Method in interface org.apache.ignite.spi.systemview.view.FiltrableSystemView
 

J

JavaLogger - Class in org.apache.ignite.logger.java
Logger to use with Java logging.
JavaLogger() - Constructor for class org.apache.ignite.logger.java.JavaLogger
Creates new logger.
JavaLogger(boolean) - Constructor for class org.apache.ignite.logger.java.JavaLogger
Creates new logger.
JavaLogger(Logger) - Constructor for class org.apache.ignite.logger.java.JavaLogger
Creates new logger with given implementation.
JavaLogger(Logger, boolean) - Constructor for class org.apache.ignite.logger.java.JavaLogger
Creates new logger with given implementation.
JavaLoggerFileHandler - Class in org.apache.ignite.logger.java
File logging handler which skips all the messages until node ID is set.
JavaLoggerFileHandler() - Constructor for class org.apache.ignite.logger.java.JavaLoggerFileHandler
 
JavaLoggerFormatter - Class in org.apache.ignite.logger.java
Formatter for JUL logger.
JavaLoggerFormatter() - Constructor for class org.apache.ignite.logger.java.JavaLoggerFormatter
 
JclLogger - Class in org.apache.ignite.logger.jcl
This logger wraps any JCL (Jakarta Commons Logging) loggers.
JclLogger() - Constructor for class org.apache.ignite.logger.jcl.JclLogger
Creates new logger.
JclLogger(Log) - Constructor for class org.apache.ignite.logger.jcl.JclLogger
Creates new logger with given implementation.
JdbcCheckpointSpi - Class in org.apache.ignite.spi.checkpoint.jdbc
This class defines JDBC checkpoint SPI implementation.
JdbcCheckpointSpi() - Constructor for class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
 
JdbcCheckpointSpiMBean - Interface in org.apache.ignite.spi.checkpoint.jdbc
Management bean that provides general administrative and configuration information about jdbc checkpoint SPI.
jdbcCompliant() - Method in class org.apache.ignite.IgniteJdbcDriver
jdbcCompliant() - Method in class org.apache.ignite.IgniteJdbcThinDriver
JdbcDialect - Interface in org.apache.ignite.cache.store.jdbc.dialect
Represents a dialect of SQL implemented by a particular RDBMS.
JdbcIpFinderDialect - Interface in org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
SQL dialect to use with TcpDiscoveryJdbcIpFinder.
JdbcType - Class in org.apache.ignite.cache.store.jdbc
Description for type that could be stored into database by store.
JdbcType() - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcType
Empty constructor (all values are initialized to their defaults).
JdbcType(JdbcType) - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcType
Copy constructor.
JdbcTypeDefaultHasher - Class in org.apache.ignite.cache.store.jdbc
Default implementation of JdbcTypeHasher.
JdbcTypeDefaultHasher() - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcTypeDefaultHasher
 
JdbcTypeField - Class in org.apache.ignite.cache.store.jdbc
Description of how field declared in database and in cache.
JdbcTypeField() - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcTypeField
Default constructor.
JdbcTypeField(int, String, Class<?>, String) - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcTypeField
Full constructor.
JdbcTypeField(JdbcTypeField) - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcTypeField
Copy constructor.
JdbcTypeHasher - Interface in org.apache.ignite.cache.store.jdbc
API for implementing custom hashing logic for binary objects on server side.
JdbcTypesDefaultTransformer - Class in org.apache.ignite.cache.store.jdbc
Default implementation of JdbcTypesTransformer.
JdbcTypesDefaultTransformer() - Constructor for class org.apache.ignite.cache.store.jdbc.JdbcTypesDefaultTransformer
 
JdbcTypesTransformer - Interface in org.apache.ignite.cache.store.jdbc
API for implementing custom mapping logic for loaded from store data.
JDK_CLS_NAMES_FILE - Static variable in class org.apache.ignite.marshaller.MarshallerUtils
Jdk class names file.
JDK_INFO_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
JdkMarshaller - Class in org.apache.ignite.marshaller.jdk
Implementation of Marshaller based on JDK serialization mechanism.
JdkMarshaller() - Constructor for class org.apache.ignite.marshaller.jdk.JdkMarshaller
Default constructor.
JdkMarshaller(IgnitePredicate<String>) - Constructor for class org.apache.ignite.marshaller.jdk.JdkMarshaller
 
jdkMarshaller() - Method in interface org.apache.ignite.marshaller.MarshallerContext
 
jdkMarshaller(String) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Create JDK marshaller with provided node name.
JmxMetricExporterSpi - Class in org.apache.ignite.spi.metric.jmx
Overview Ignite provides this default built-in implementation of MetricExporterSpi it exports metrics as JMX beans.
JmxMetricExporterSpi() - Constructor for class org.apache.ignite.spi.metric.jmx.JmxMetricExporterSpi
 
JobContextResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of ComputeJobContext instance.
JobEvent - Class in org.apache.ignite.events
Grid job event.
JobEvent() - Constructor for class org.apache.ignite.events.JobEvent
No-arg constructor.
JobEvent(ClusterNode, String, int) - Constructor for class org.apache.ignite.events.JobEvent
Creates job event with given parameters.
jobId() - Method in class org.apache.ignite.events.JobEvent
Gets job ID.
jobId(IgniteUuid) - Method in class org.apache.ignite.events.JobEvent
Sets job ID.
jobId() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
jobReceiverVersion(IgniteProductVersion) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Sets thread local job receiver node version.
jobReceiverVersion() - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Returns thread local job receiver node version.
jobSenderVersion(IgniteProductVersion) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Sets thread local job sender node version.
jobSenderVersion() - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Returns thread local job sender node version.
JobStealingCollisionSpi - Class in org.apache.ignite.spi.collision.jobstealing
Collision SPI that supports job stealing from over-utilized nodes to under-utilized nodes.
JobStealingCollisionSpi() - Constructor for class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
 
JobStealingCollisionSpiMBean - Interface in org.apache.ignite.spi.collision.jobstealing
Management MBean for job stealing based collision SPI.
JobStealingDisabled - Annotation Type in org.apache.ignite.spi.collision.jobstealing
This annotation disables job stealing if corresponding feature is configured.
JobStealingFailoverSpi - Class in org.apache.ignite.spi.failover.jobstealing
Job stealing failover SPI needs to always be used in conjunction with JobStealingCollisionSpi SPI.
JobStealingFailoverSpi() - Constructor for class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
 
JobStealingFailoverSpiMBean - Interface in org.apache.ignite.spi.failover.jobstealing
Management bean for JobStealingFailoverSpi.
JobStealingRequest - Class in org.apache.ignite.spi.collision.jobstealing
Job stealing request.
JobStealingRequest() - Constructor for class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Required by Externalizable.
joiningNodeData(Map<Integer, Serializable>) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
joiningNodeData() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
joiningNodeData() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.JoiningNodeDiscoveryData
 
joiningNodeId() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.GridDiscoveryData
 
joiningNodeId() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.JoiningNodeDiscoveryData
 
joiningNodeId() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
joinTimeout - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Join timeout, in milliseconds.
jvmStartTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 

K

keepBinary() - Method in class org.apache.ignite.dump.DumpReaderConfiguration
 
keepBinary() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets flag indicating that objects should be kept in binary format when passed to the stream receiver.
keepBinary(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets flag indicating that objects should be kept in binary format when passes to the steam receiver.
keepBinary() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
keepBinary() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
key() - Method in class org.apache.ignite.cache.affinity.AffinityKey
Gets wrapped key.
key(K) - Method in class org.apache.ignite.cache.affinity.AffinityKey
Sets wrapped key.
key() - Method in interface org.apache.ignite.cdc.CdcEvent
 
key() - Method in interface org.apache.ignite.dump.DumpEntry
 
key() - Method in class org.apache.ignite.events.CacheEvent
Gets cache entry associated with event.
key() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets read entry key.
key() - Method in class org.apache.ignite.events.CheckpointEvent
Gets checkpoint key associated with this event.
key(String) - Method in class org.apache.ignite.events.CheckpointEvent
Sets checkpoint key.
key() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionKey
 
keyAlgorithm - Variable in class org.apache.ignite.ssl.SslContextFactory
Key manager algorithm.
keyAlias() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns alias for key column.
keyColumns() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Gets key columns.
keyKind() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
keysCount() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
keySet() - Method in class org.apache.ignite.lang.IgniteBiTuple
KeystoreEncryptionKey - Class in org.apache.ignite.spi.encryption.keystore
EncryptionKey implementation based on java security.
KeystoreEncryptionSpi - Class in org.apache.ignite.spi.encryption.keystore
EncryptionSPI implementation base on JDK provided cipher algorithm implementations.
KeystoreEncryptionSpi() - Constructor for class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
 
keyStoreFilePath - Variable in class org.apache.ignite.ssl.SslContextFactory
Path to key store file
keyStorePwd - Variable in class org.apache.ignite.ssl.SslContextFactory
Key store password
keyStoreType - Variable in class org.apache.ignite.ssl.SslContextFactory
Key store type.
keyType() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
keyTypeName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns name of key type.
kill(boolean) - Static method in class org.apache.ignite.Ignition
Stops all started grids.
KILL_EXIT_CODE - Static variable in class org.apache.ignite.Ignition
This is kill code that can be used by external tools, like Shell scripts, to auto-stop the Ignite JVM process without restarting.
killNode(ClusterNode) - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
kindForName(String, boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
kindForName(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
knownNode(UUID) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
knownNode(UUID) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
knownNode(UUID) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
KubernetesConnectionConfiguration - Class in org.apache.ignite.kubernetes.configuration
Configuration for Kubernetes connection.
KubernetesConnectionConfiguration() - Constructor for class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
 

L

label() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
label() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates
 
label() - Method in interface org.apache.ignite.transactions.Transaction
Returns transaction's label.
last() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets result of the last execution of scheduled task, or null if task has not been executed, or has not produced a result yet.
LAST_CLUSTER_STATE_CHANGE_TIME_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
lastClusterStateChangeTime() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Deprecated.
Check the ReadOnlyMetricRegistry with "name=ignite.lastClusterStateChangeTime" instead.
lastDataVersion() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
lastFinishTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets finish time of last execution (0 if first execution has not finished).
lastIdleTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets last interval between scheduled executions.
lastLocalId() - Static method in class org.apache.ignite.lang.IgniteUuid
Gets last generated local ID.
lastSendTime() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
lastStartTime() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets latest query start time.
lastStartTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets start time of last execution (0 if never started).
lastStartTime() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
lastUpdateTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
LIFECYCLE_BEANS_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
LifecycleAware - Interface in org.apache.ignite.lifecycle
All components provided in Ignite configuration can implement this interface.
LifecycleBean - Interface in org.apache.ignite.lifecycle
A bean that reacts to node lifecycle events defined in LifecycleEventType.
LifecycleEventType - Enum in org.apache.ignite.lifecycle
Node lifecycle event types.
listen(IgniteInClosure<? super IgniteFuture<V>>) - Method in interface org.apache.ignite.lang.IgniteFuture
Registers a callback to be invoked when the future completes.
listenAsync(IgniteInClosure<? super IgniteFuture<V>>, Executor) - Method in interface org.apache.ignite.lang.IgniteFuture
Registers a callback to be invoked with the specified executor when the future completes.
load(K) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
load(K) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
load(K) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
LOAD_BALANCING_SPI_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
loadAll(Iterable<? extends K>) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
loadAll(Iterable<? extends K>) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
loadAll(Iterable<? extends K>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
LoadAllWarmUpConfiguration - Class in org.apache.ignite.configuration
"Load All" warm-up configuration that loads data into persistent data region until it reaches DataRegionConfiguration.getMaxSize() with index priority.
LoadAllWarmUpConfiguration() - Constructor for class org.apache.ignite.configuration.LoadAllWarmUpConfiguration
 
LoadBalancerResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of ComputeLoadBalancer.
LoadBalancingSpi - Interface in org.apache.ignite.spi.loadbalancing
Load balancing SPI provides the next best balanced node for job execution.
loadCache(IgniteBiInClosure<K, V>, Object...) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Loads all values from underlying persistent storage.
loadCache(IgniteBiInClosure<K, V>, Object...) - Method in interface org.apache.ignite.cache.store.CacheStore
Loads all values from underlying persistent storage.
loadCache(IgniteBiInClosure<K, V>, Object...) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
Default empty implementation.
loadCache(IgniteBiInClosure<K, V>, Object...) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Loads all values from underlying persistent storage.
loadCache(IgniteBiPredicate<K, V>, Object...) - Method in interface org.apache.ignite.IgniteCache
loadCacheAsync(IgniteBiPredicate<K, V>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously executes IgniteCache.localLoadCache(IgniteBiPredicate, Object...) on all cache nodes.
loadCacheQuery(String, Iterable<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct load cache query.
loadCacheQuery(String, Iterable<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct load cache query.
loadCacheRangeQuery(boolean, boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Construct query for select values in range.
loadCacheRangeQuery(String, Collection<String>, Iterable<String>, boolean, boolean) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct load cache query over specified range.
loadCacheRangeQuery(String, Collection<String>, Iterable<String>, boolean, boolean) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct load cache query over specified range.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct query to get ranges bounds.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect
Construct query to get ranges bounds.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct query to get ranges bounds.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
Construct query to get ranges bounds.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.OracleDialect
Construct query to get ranges bounds.
loadCacheSelectRangeQuery(String, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
Construct query to get ranges bounds.
loadCdc(String) - Static method in class org.apache.ignite.cdc.CdcLoader
Loads CdcMain from XML configuration file.
loadCheckpoint(String) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Loads job's state previously saved via ComputeTaskSession.saveCheckpoint(String, Object, ComputeTaskSessionScope, long) method from an underlying storage for a given key.
loadCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Loads checkpoint from storage by its unique key.
loadCheckpoint(String) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointSpi
Loads checkpoint from storage by its unique key.
loadCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Loads checkpoint from storage by its unique key.
loadCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
Loads checkpoint from storage by its unique key.
loadCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Loads checkpoint from storage by its unique key.
loadKeyStore(String, String, char[]) - Method in class org.apache.ignite.ssl.SslContextFactory
Loads key store with configured parameters.
loadQuery(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Construct query for select values with key count less or equal maxKeysPerStmt
loadQuery(String, Collection<String>, Iterable<String>, int) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct load query.
loadQuery(String, Collection<String>, Iterable<String>, int) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct load query.
loadSpringBean(String, String) - Static method in class org.apache.ignite.Ignition
Loads Spring bean by its name from given Spring XML configuration file.
loadSpringBean(URL, String) - Static method in class org.apache.ignite.Ignition
Loads Spring bean by its name from given Spring XML configuration file.
loadSpringBean(InputStream, String) - Static method in class org.apache.ignite.Ignition
Loads Spring bean by its name from given Spring XML configuration file.
LOC_NODE_ID_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
locAddr - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local address.
local() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
local() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
local() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
local() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
localActiveTransactions() - Method in interface org.apache.ignite.IgniteTransactions
Returns a list of active transactions initiated by this node.
localAddress() - Method in class org.apache.ignite.client.events.ConnectionDescription
Gets local address of this connection.
localAddress() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
localClear(K) - Method in interface org.apache.ignite.IgniteCache
Clears entry from the cache and swap storage, without notifying listeners or CacheWriters.
localClearAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Clears entries from the cache and swap storage, without notifying listeners or CacheWriters.
LocalDeploymentSpi - Class in org.apache.ignite.spi.deployment.local
Local deployment SPI that implements only within VM deployment on local node via LocalDeploymentSpi.register(ClassLoader, Class) method.
LocalDeploymentSpi() - Constructor for class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
 
LocalDeploymentSpiMBean - Interface in org.apache.ignite.spi.deployment.local
Management MBean for LocalDeploymentSpi SPI.
localDeployTask(Class<? extends ComputeTask>, ClassLoader) - Method in interface org.apache.ignite.IgniteCompute
Explicitly deploys a task with given class loader on the local node.
localEntries(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Allows for iteration over local cache entries.
localEvents(IgnitePredicate<T>) - Method in interface org.apache.ignite.spi.eventstorage.EventStorageSpi
Queries locally-stored events only.
localEvents(IgnitePredicate<T>) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Queries locally-stored events only.
localEvents(IgnitePredicate<T>) - Method in class org.apache.ignite.spi.eventstorage.NoopEventStorageSpi
Queries locally-stored events only.
localEvict(Collection<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Attempts to evict all entries associated with keys.
localId() - Method in class org.apache.ignite.lang.IgniteUuid
Gets local ID portion of this IgniteUuid.
localIgnite() - Static method in class org.apache.ignite.Ignition
This method is used to address a local Ignite instance, principally from closure.
localListen(IgnitePredicate<? extends Event>, int...) - Method in interface org.apache.ignite.IgniteEvents
Adds an event listener for local events.
localListen(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.IgniteMessaging
Adds local listener for given topic on local node only.
localListener() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
localLoadCache(IgniteBiPredicate<K, V>, Object...) - Method in interface org.apache.ignite.IgniteCache
Delegates to CacheStore.loadCache(IgniteBiInClosure,Object...) method to load state from the underlying persistent storage.
localLoadCacheAsync(IgniteBiPredicate<K, V>, Object...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously loads state from the underlying persistent storage by delegating to CacheStore.loadCache(IgniteBiInClosure,Object...) method.
localMetrics() - Method in interface org.apache.ignite.IgniteCache
Gets local snapshot metrics (statistics) for this cache.
localNode() - Method in interface org.apache.ignite.IgniteCluster
Gets local grid node.
localNode() - Method in interface org.apache.ignite.plugin.CachePluginContext
Gets local grid node.
localNode() - Method in interface org.apache.ignite.plugin.PluginContext
Gets local grid node.
localNode() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets local grid node.
localNodeId() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
localNodeSpecificData() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
localOrder() - Method in interface org.apache.ignite.events.Event
Gets locally unique ID that is atomically incremented for each event.
localOrder() - Method in class org.apache.ignite.events.EventAdapter
Gets locally unique ID that is atomically incremented for each event.
localPeek(K, CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Peeks at a value in the local storage using an optional peek mode.
localPreloadPartition(int) - Method in interface org.apache.ignite.IgniteCache
Efficiently preloads cache partition into page memory if it exists on the local node.
localQuery(IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Queries local node for events using passed-in predicate filter for event selection.
localSize(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached on this node.
localSizeLong(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached on this node as a long value.
localSizeLong(int, CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached on this node for the partition as a long value.
localTasks() - Method in interface org.apache.ignite.IgniteCompute
Gets map of all locally deployed tasks keyed by their task name .
localTransformedListener() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
locHost - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local host.
lock(K) - Method in interface org.apache.ignite.IgniteCache
Creates a Lock instance associated with passed key.
lock() - Method in interface org.apache.ignite.IgniteLock
Acquires the distributed reentrant lock.
lockAll(Collection<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Deprecated.
It is recommended to use Ignite.reentrantLock(String, boolean, boolean, boolean) instead. This method will be removed in future releases.
locked() - Method in class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
lockId() - Method in class org.apache.ignite.events.CacheEvent
ID of the lock if held or null if no lock held.
lockInterruptibly() - Method in interface org.apache.ignite.IgniteLock
Acquires the lock unless the current thread is interrupted.
locNode - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local node.
locNodeAddrs - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Internal and external addresses of local node.
locNodeAttrs - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local node attributes.
locNodeVer - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local node version.
locPort - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local port which node uses.
locPortRange - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Local port range.
log - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Auto-injected logger instance.
log() - Method in interface org.apache.ignite.Ignite
Gets grid's logger.
log() - Method in class org.apache.ignite.IgniteSpringBean
Gets grid's logger.
log(Class<?>) - Method in interface org.apache.ignite.plugin.CachePluginContext
Gets logger for given class.
log(Class<?>) - Method in interface org.apache.ignite.plugin.PluginContext
Gets logger for given class.
log - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Logger.
log - Variable in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Logger.
log - Variable in class org.apache.ignite.spi.IgniteSpiAdapter
 
Log4J2Logger - Class in org.apache.ignite.logger.log4j2
Log4j2-based implementation for logging.
Log4J2Logger() - Constructor for class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates new logger and automatically detects if root logger already has appenders configured.
Log4J2Logger(String) - Constructor for class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates new logger with given configuration path.
Log4J2Logger(File) - Constructor for class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates new logger with given configuration cfgFile.
Log4J2Logger(URL) - Constructor for class org.apache.ignite.logger.log4j2.Log4J2Logger
Creates new logger with given configuration cfgUrl.
logDirectory(String) - Static method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
Resolves logging directory.
LogExporterSpi - Class in org.apache.ignite.spi.metric.log
This SPI implementation exports metrics to Ignite log.
LogExporterSpi() - Constructor for class org.apache.ignite.spi.metric.log.LogExporterSpi
 
LoggerResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of IgniteLogger.
logicalReads() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupIoView
 
login() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Login provided via subject security credentials.
LONG_JVM_PAUSE_LAST_EVENTS_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
LONG_JVM_PAUSES_CNT_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
LONG_JVM_PAUSES_TOTAL_DURATION_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
LongMetric - Interface in org.apache.ignite.spi.metric
Interface for the metrics that holds long primitive.
lostPartitions() - Method in interface org.apache.ignite.IgniteCache
Gets a collection of lost partition IDs.
LruEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction.lru
Eviction policy based on Least Recently Used (LRU) algorithm and supports batch eviction.
LruEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Constructs LRU eviction policy with all defaults.
LruEvictionPolicy(int) - Constructor for class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Constructs LRU eviction policy with maximum size.
LruEvictionPolicyFactory<K,V> - Class in org.apache.ignite.cache.eviction.lru
Factory class for LruEvictionPolicy.
LruEvictionPolicyFactory() - Constructor for class org.apache.ignite.cache.eviction.lru.LruEvictionPolicyFactory
 
LruEvictionPolicyFactory(int) - Constructor for class org.apache.ignite.cache.eviction.lru.LruEvictionPolicyFactory
 
LruEvictionPolicyFactory(int, int, long) - Constructor for class org.apache.ignite.cache.eviction.lru.LruEvictionPolicyFactory
 
LruEvictionPolicyMBean - Interface in org.apache.ignite.cache.eviction.lru
MBean for LRU eviction policy.
lsnr - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Grid discovery listener.
lt(String, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Less Then.
lte(String, Object) - Static method in class org.apache.ignite.cache.query.IndexQueryCriteriaBuilder
Less Then or Equal To.

M

main(String[]) - Static method in class org.apache.ignite.development.utils.IgniteWalConverter
 
main(String[]) - Static method in class org.apache.ignite.startup.cmdline.CdcCommandLineStartup
Main entry point.
main(String[]) - Static method in class org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator
Main method.
main(String[]) - Static method in class org.apache.ignite.startup.cmdline.CommandLineStartup
Main entry point.
main(String[]) - Static method in class org.apache.ignite.startup.cmdline.CommandLineTransformer
Main method being triggered in step 3 of the Workaround.
maintenance() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets maintenance version number.
MaintenanceAction<T> - Interface in org.apache.ignite.maintenance
Maintenance action interface enables user to execute operations related to a particular MaintenanceTask.
MaintenanceRegistry - Interface in org.apache.ignite.maintenance
MaintenanceRegistry is a service local to each Ignite node that allows to request performing maintenance actions on that particular node.
MaintenanceTask - Class in org.apache.ignite.maintenance
Represents request to handle maintenance situation.
MaintenanceTask(String, String, String) - Constructor for class org.apache.ignite.maintenance.MaintenanceTask
 
MaintenanceWorkflowCallback - Interface in org.apache.ignite.maintenance
Abstraction to decouple interaction between MaintenanceRegistry and components that may require maintenance.
major() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets major version number.
makeMessageType(byte, byte) - Static method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Concatenates the two parameter bytes to form a message type value.
makePatch(QueryEntity) - Method in class org.apache.ignite.cache.QueryEntity
Make query entity patch.
map(List<ClusterNode>, T) - Method in interface org.apache.ignite.compute.ComputeTask
This method is called to map or split grid task into multiple grid jobs.
map(List<ClusterNode>, T) - Method in class org.apache.ignite.compute.ComputeTaskSplitAdapter
This method is called to map or split grid task into multiple grid jobs.
mapFuture() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Gets future that will be completed when task "map" step has completed (which means that ComputeTask.map(List, Object) method has finished).
mapKeysToNodes(Collection<? extends K>) - Method in interface org.apache.ignite.cache.affinity.Affinity
This method provides ability to detect which keys are mapped to which nodes.
mapKeyToNode(K) - Method in interface org.apache.ignite.cache.affinity.Affinity
This method provides ability to detect to which primary node the given key is mapped.
mapKeyToPrimaryAndBackups(K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets primary and backup nodes for the key.
mapPartitionsToNodes(Collection<Integer>) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets primary nodes for the given partitions.
mapPartitionToNode(int) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets primary node for the given partition.
mapPartitionToPrimaryAndBackups(int) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets primary and backup nodes for partition.
marshal(Object) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Marshals object to byte array.
marshal(Object, OutputStream) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Marshals object to the output stream.
marshal(Object, OutputStream) - Method in interface org.apache.ignite.marshaller.Marshaller
Marshals object to the output stream.
marshal(Object) - Method in interface org.apache.ignite.marshaller.Marshaller
Marshals object to byte array.
marshal0(Object, OutputStream) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Marshals object to the output stream.
marshal0(Object) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Marshals object to byte array.
marshal0(Object, OutputStream) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Marshals object to the output stream.
marshal0(Object) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Marshals object to byte array.
Marshaller - Interface in org.apache.ignite.marshaller
Marshaller allows to marshal or unmarshal objects in grid.
marshaller() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
MarshallerContext - Interface in org.apache.ignite.marshaller
Marshaller context.
marshallerContext() - Method in interface org.apache.ignite.plugin.PluginContext
 
MarshallerExclusions - Class in org.apache.ignite.marshaller
Controls what classes should be excluded from marshalling by default.
MarshallerUtils - Class in org.apache.ignite.marshaller
Utility marshaller methods.
masterKeyDigest() - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Returns master key digest.
masterKeyDigest(String) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Returns master key digest by name.
masterKeyDigest() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Returns master key digest.
masterKeyDigest(String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Returns master key digest by name.
masterKeyDigest() - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Returns master key digest.
masterKeyDigest(String) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Returns master key digest by name.
match(SpanStatus) - Static method in class org.apache.ignite.spi.tracing.opencensus.StatusMatchTable
 
MAX_FAILOVER_ATTEMPT_ATTR - Static variable in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Maximum attempts attribute key should be the same on all nodes.
MAX_PAGE_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Max memory page size.
MAX_PARTITIONS_COUNT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
Maximum number of partitions.
MAX_STEALING_ATTEMPT_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Maximum stealing attempts attribute name.
MAX_TAG_LENGTH - Static variable in interface org.apache.ignite.IgniteCluster
Maximum length of IgniteCluster.tag() tag.
maxActiveJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
maxCanceledJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
maxConcurrentAsyncOperations() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
maximumTime() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets maximum execution time of query.
maximumTime() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets maximum execution time of query.
maxJobsExecuteTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
maxJobsWaitTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
maxParamsCnt - Variable in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Max query parameters count.
maxPerNodeCnt - Variable in class org.apache.ignite.services.ServiceConfiguration
Max per-node count.
maxPerNodeCount() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets maximum allowed number of deployed services on each node, 0 for unlimited.
maxPerNodeCount() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets maximum allowed number of deployed services on each node, 0 for unlimited.
maxPerNodeCount() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
maxQueryIteratorsCount() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
maxRejectedJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
maxThreadCount() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
maxWaitingJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
MBEAN_SERVER_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
MemoryAllocator - Interface in org.apache.ignite.mem
Base interface for offheap memory allocator.
MemoryConfiguration - Class in org.apache.ignite.configuration
Deprecated.
MemoryConfiguration() - Constructor for class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
 
MemoryEventStorageSpi - Class in org.apache.ignite.spi.eventstorage.memory
In-memory EventStorageSpi implementation.
MemoryEventStorageSpi() - Constructor for class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
 
MemoryEventStorageSpiMBean - Interface in org.apache.ignite.spi.eventstorage.memory
Management bean for MemoryEventStorageSpi.
memoryMetrics() - Method in interface org.apache.ignite.Ignite
Deprecated.
Check the ReadOnlyMetricRegistry with "name=io.dataregion.{data_region_name}" instead.
memoryMetrics(String) - Method in interface org.apache.ignite.Ignite
Deprecated.
Check the ReadOnlyMetricRegistry with "name=io.dataregion.{data_region_name}" instead.
memoryMetrics() - Method in class org.apache.ignite.IgniteSpringBean
memoryMetrics(String) - Method in class org.apache.ignite.IgniteSpringBean
MemoryMetrics - Interface in org.apache.ignite
Deprecated.
Check the ReadOnlyMetricRegistry with "name=io.dataregion.{data_region_name}" instead.
MemoryPolicyConfiguration - Class in org.apache.ignite.configuration
Deprecated.
MemoryPolicyConfiguration() - Constructor for class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
 
memSize - Variable in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Memory size occupied by elements in container.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.H2Dialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.OracleDialect
Construct merge query.
mergeQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
Construct merge query.
message() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets optional message for this event.
message() - Method in interface org.apache.ignite.events.Event
Gets optional message for this event.
message(String) - Method in class org.apache.ignite.events.EventAdapter
Sets optional event message.
message() - Method in class org.apache.ignite.events.EventAdapter
Gets optional message for this event.
message() - Method in interface org.apache.ignite.Ignite
Gets messaging facade over all cluster nodes.
message(ClusterGroup) - Method in interface org.apache.ignite.Ignite
Gets messaging facade over nodes within the cluster group.
message() - Method in class org.apache.ignite.IgniteSpringBean
Gets messaging facade over all cluster nodes.
message(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Gets messaging facade over nodes within the cluster group.
Message - Interface in org.apache.ignite.plugin.extensions.communication
Base class for all communication messages.
message() - Method in class org.apache.ignite.spi.IgniteNodeValidationResult
 
MESSAGE_FULL_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Full message size (with message type) in bytes.
MESSAGE_FULL_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Full message size (with message type) in bytes.
MESSAGE_FULL_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Full message size (with message type) in bytes.
MESSAGE_FULL_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Full message size (with message type) in bytes.
MessageCollectionItemType - Enum in org.apache.ignite.plugin.extensions.communication
Enum representing possible types of collection items.
MessageFactory - Interface in org.apache.ignite.plugin.extensions.communication
Deprecated.
messageFactory() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets message factory.
MessageFactoryProvider - Interface in org.apache.ignite.plugin.extensions.communication
Provider of communication message factories.
MessageFormatter - Interface in org.apache.ignite.plugin.extensions.communication
Provides a custom format for communication messages.
messageFormatter() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets message formatter.
MessageReader - Interface in org.apache.ignite.plugin.extensions.communication
Communication message reader.
messageTemplate(String) - Method in class org.apache.ignite.events.DiscoveryEvent
Template to generate DiscoveryEvent.message() lazily.
MessageWriter - Interface in org.apache.ignite.plugin.extensions.communication
Communication message writer.
MessagingListenActor<T> - Class in org.apache.ignite.messaging
Convenience actor-base adapter for IgniteMessaging.localListen(Object, IgniteBiPredicate) method.
MessagingListenActor() - Constructor for class org.apache.ignite.messaging.MessagingListenActor
 
meta() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Gets metadata added by eviction policy.
METADATA - Static variable in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Tags metadata.
MetastorageView - Class in org.apache.ignite.spi.systemview.view
Metastorage key representation for a SystemView.
MetastorageView(String, String) - Constructor for class org.apache.ignite.spi.systemview.view.MetastorageView
 
Metric - Interface in org.apache.ignite.spi.metric
Base interface for all metrics.
MetricExporterSpi - Interface in org.apache.ignite.spi.metric
Exporter of metric information to the external recipient.
metricRegistries() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Returns all registered metric registries.
metricRegistry() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
 
MetricRegistryMBean - Class in org.apache.ignite.spi.metric.jmx
MBean for exporting values of metric registry.
MetricRegistryMBean(ReadOnlyMetricRegistry) - Constructor for class org.apache.ignite.spi.metric.jmx.MetricRegistryMBean
 
metrics() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets a metrics snapshot for this cluster group.
metrics() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets metrics snapshot for this node.
metrics() - Method in interface org.apache.ignite.IgniteCache
Gets whole cluster snapshot metrics (statistics) for this cache.
metrics(ClusterGroup) - Method in interface org.apache.ignite.IgniteCache
Gets cluster group snapshot metrics for caches in cluster group.
metrics() - Method in interface org.apache.ignite.IgniteTransactions
 
metrics() - Method in interface org.apache.ignite.spi.discovery.DiscoveryMetricsProvider
This method always returns up-to-date metrics data about local node.
metrics() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets metrics snapshot for this node.
MetricsMxBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use managements API beans, instead.
metricsProvider - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Metrics provider.
metricsUpdateFreq - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Metrics update messages issuing frequency.
MetricsView - Class in org.apache.ignite.spi.systemview.view
Metrics representation for a SystemView.
MetricsView(Metric) - Constructor for class org.apache.ignite.spi.systemview.view.MetricsView
 
MIN_PAGE_SIZE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Min memory page size.
minimumTime() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets minimum execution time of query.
minimumTime() - Method in interface org.apache.ignite.cache.query.QueryMetrics
Gets minimum execution time of query.
minor() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets minor version number.
mkString(Iterable<T>, C1<T, String>, String, String, String) - Static method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Concatenates elements using provided separator.
mkString(Iterable<String>, String, String, String) - Static method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Concatenates elements using provided separator.
mkString(Iterable<String>, String) - Static method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Concatenates strings using provided separator.
MSG_EXPIRE_TIME_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Stealing request expiration time attribute name.
MXBeanDescription - Annotation Type in org.apache.ignite.mxbean
Provides description for MBean classes and methods.
MXBeanParameter - Annotation Type in org.apache.ignite.mxbean
Provides name and description for MBean method parameter.
MXBeanParametersDescriptions - Annotation Type in org.apache.ignite.mxbean
Deprecated.
Use MXBeanParameter instead.
MXBeanParametersNames - Annotation Type in org.apache.ignite.mxbean
Deprecated.
Use MXBeanParameter instead.
MySQLDialect - Class in org.apache.ignite.cache.store.jdbc.dialect
A dialect compatible with the MySQL database.
MySQLDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.MySQLDialect
 

N

name() - Method in interface org.apache.ignite.binary.BinaryField
Get field's name.
name() - Method in interface org.apache.ignite.cache.CacheMetrics
Gets name of this cache.
name() - Method in interface org.apache.ignite.client.ClientAtomicLong
Name of atomic long.
name() - Method in interface org.apache.ignite.client.ClientIgniteSet
Gets set name.
name() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets service name.
name() - Method in interface org.apache.ignite.events.Event
Gets name of this event.
name() - Method in class org.apache.ignite.events.EventAdapter
Gets event type name.
name() - Method in interface org.apache.ignite.Ignite
Gets the name of the Ignite instance.
name() - Method in interface org.apache.ignite.IgniteAtomicLong
Name of atomic long.
name() - Method in interface org.apache.ignite.IgniteAtomicReference
Name of atomic reference.
name() - Method in interface org.apache.ignite.IgniteAtomicSequence
Name of atomic sequence.
name() - Method in interface org.apache.ignite.IgniteAtomicStamped
Name of atomic stamped.
name() - Method in interface org.apache.ignite.IgniteCondition
Name of ignite condition.
name() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets name of the latch.
name() - Method in interface org.apache.ignite.IgniteLock
Name of atomic reentrant lock.
name() - Method in interface org.apache.ignite.IgniteQueue
Gets queue name.
name() - Method in interface org.apache.ignite.IgniteSemaphore
Gets name of the semaphore.
name() - Method in interface org.apache.ignite.IgniteSet
Gets set name.
name() - Method in class org.apache.ignite.IgniteSpringBean
Gets the name of the Ignite instance.
name() - Method in interface org.apache.ignite.maintenance.MaintenanceAction
 
name() - Method in class org.apache.ignite.maintenance.MaintenanceTask
 
name() - Method in interface org.apache.ignite.plugin.PluginProvider
 
name - Variable in class org.apache.ignite.services.ServiceConfiguration
Service name.
name() - Method in interface org.apache.ignite.services.ServiceContext
Gets service name.
name() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets service name.
name() - Method in interface org.apache.ignite.spi.metric.Metric
 
name() - Method in interface org.apache.ignite.spi.metric.ReadOnlyMetricRegistry
 
name() - Method in class org.apache.ignite.spi.systemview.view.BaselineNodeAttributeView
 
name() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionAttributeView
 
name() - Method in class org.apache.ignite.spi.systemview.view.ConfigurationView
 
name() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
name() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
name() - Method in class org.apache.ignite.spi.systemview.view.MetastorageView
 
name() - Method in class org.apache.ignite.spi.systemview.view.MetricsView
 
name() - Method in class org.apache.ignite.spi.systemview.view.NodeAttributeView
 
name() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
name() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
name() - Method in class org.apache.ignite.spi.systemview.view.SnapshotView
 
name() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewView
 
name() - Method in interface org.apache.ignite.spi.systemview.view.SystemView
 
near() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
NearCacheConfiguration<K,V> - Class in org.apache.ignite.configuration
Client (near) cache configuration.
NearCacheConfiguration() - Constructor for class org.apache.ignite.configuration.NearCacheConfiguration
Empty constructor.
NearCacheConfiguration(NearCacheConfiguration<K, V>) - Constructor for class org.apache.ignite.configuration.NearCacheConfiguration
Creates near cache configuration copying properties from passed in configuration.
nearCacheEvictionPolicyFactory() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
nearCacheStartSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
NEED_WAIT - Static variable in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Need wait.
nestedCauses() - Method in exception org.apache.ignite.spi.IgniteSpiMultiException
Gets nested causes for this multi-exception.
netTimeout - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Network timeout.
NeverFailoverSpi - Class in org.apache.ignite.spi.failover.never
This class provides failover SPI implementation that never fails over.
NeverFailoverSpi() - Constructor for class org.apache.ignite.spi.failover.never.NeverFailoverSpi
 
NeverFailoverSpiMBean - Interface in org.apache.ignite.spi.failover.never
Management bean for NeverFailoverSpi.
newCondition() - Method in interface org.apache.ignite.IgniteLock
This method is not supported in IgniteLock, Any invocation of this method will result in UnsupportedOperationException.
newJoinerDiscoveryData(int) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
newTag() - Method in class org.apache.ignite.events.ClusterTagUpdatedEvent
Value of cluster tag after update request that triggered this event.
newThread(Runnable) - Method in class org.apache.ignite.spi.IgniteSpiThreadFactory
newThread(Runnable) - Method in class org.apache.ignite.thread.IgniteThreadFactory
newValue() - Method in class org.apache.ignite.events.CacheEvent
Gets new value for this event.
nextExecutionTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets next execution time of scheduled task.
nextExecutionTimes(int, long) - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets an array of the next execution times after passed start timestamp.
nextTimeout(long) - Method in class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
Get next timeout based on previously timeout calculated by strategy.
nextTimeout(long) - Method in interface org.apache.ignite.spi.TimeoutStrategy
Get next timeout based on previously timeout calculated by strategy.
nextTimeout() - Method in interface org.apache.ignite.spi.TimeoutStrategy
Get next timeout.
nextTimeoutChunk(long) - Method in class org.apache.ignite.spi.IgniteSpiOperationTimeoutHelper
Returns a timeout value to use for the next network operation.
NO_PERMISSIONS - Static variable in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
 
node(UUID) - Method in interface org.apache.ignite.client.ClientClusterGroup
Gets a node for given ID from this cluster group.
node() - Method in interface org.apache.ignite.client.ClientClusterGroup
Gets first node from the list of nodes in this cluster group.
node(UUID) - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets a node for given ID from this cluster group.
node() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets first node from the list of nodes in this cluster group.
node() - Method in interface org.apache.ignite.events.Event
Node where event occurred and was recorded
node(ClusterNode) - Method in class org.apache.ignite.events.EventAdapter
Sets node where even is occurred (i.e. node local to the event).
node() - Method in class org.apache.ignite.events.EventAdapter
Node where event occurred and was recorded
node(UUID) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets a node instance based on its ID.
NODE_ID_MSG_TYPE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Node ID message type.
NODE_ID_TAG - Static variable in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Ignite node id.
NODE_STOPPING - Static variable in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
 
NODE_WEIGHT_ATTR_NAME - Static variable in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Name of node attribute used to indicate load weight of a node (value is "ignite.node.weight.attr.name").
nodeAddresses(ClusterNode, boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
nodeAttributes() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets node attributes.
nodeAttributes(Map<String, ?>) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets node attributes.
nodeAttributes() - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
NodeAttributeView - Class in org.apache.ignite.spi.systemview.view
Node attribute representation for a SystemView.
NodeAttributeView(UUID, String, Object) - Constructor for class org.apache.ignite.spi.systemview.view.NodeAttributeView
 
nodeAuth - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Node authenticator.
nodeConsistentId() - Method in class org.apache.ignite.spi.systemview.view.BaselineNodeAttributeView
 
nodeFilter - Variable in class org.apache.ignite.services.ServiceConfiguration
Node filter.
nodeFilter() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
nodeFilter(CacheConfiguration<?, ?>) - Static method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
nodeFilter() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
nodeFilter() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
nodeId(UUID, String) - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
Sets Node id and instantiates FileHandler delegate.
nodeId(String, UUID, String) - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
Sets Node id and instantiates FileHandler delegate.
nodeId() - Method in exception org.apache.ignite.plugin.PluginValidationException
 
nodeId() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
nodeId() - Method in class org.apache.ignite.spi.IgniteNodeValidationResult
 
nodeId() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
nodeId() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
nodeId() - Method in class org.apache.ignite.spi.systemview.view.NodeAttributeView
 
nodeId() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
nodeId() - Method in class org.apache.ignite.spi.systemview.view.PartitionStateView
 
nodeId() - Method in interface org.apache.ignite.transactions.Transaction
ID of the node on which this transaction started.
nodeIdBytes() - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
 
nodeIdBytesWithType(UUID) - Static method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
 
NodeIdMessage - Class in org.apache.ignite.spi.communication.tcp.messages
Node ID message.
NodeIdMessage() - Constructor for class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
 
NodeIdMessage(UUID) - Constructor for class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
 
nodeIdsForAttribute(String, String, boolean, boolean) - Method in interface org.apache.ignite.mxbean.ClusterMetricsMXBean
 
nodeLocalMap() - Method in interface org.apache.ignite.IgniteCluster
Gets node-local storage instance.
NodeMetricsView - Class in org.apache.ignite.spi.systemview.view
Node metrics representation for a SystemView.
NodeMetricsView(ClusterNode) - Constructor for class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
nodeName(String) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Set node name.
nodeOrder() - Method in interface org.apache.ignite.cache.CacheEntryVersion
 
nodeOrder() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
nodes() - Method in interface org.apache.ignite.client.ClientClusterGroup
Gets the read-only collection of nodes in this cluster group.
nodes() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets the read-only collection of nodes in this cluster group.
nodes() - Method in interface org.apache.ignite.plugin.PluginContext
Gets a collection of all grid nodes.
nodes() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets a collection of all grid nodes.
nodeSpecificData() - Method in interface org.apache.ignite.spi.discovery.DiscoveryDataBag.GridDiscoveryData
 
nodeSpecificData(Map<UUID, Map<Integer, Serializable>>) - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
 
nodeStartTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
NodeValidationFailedEvent - Class in org.apache.ignite.events
This event is triggered if any of GridComponents fail to validate the joining node while join message processing.
NodeValidationFailedEvent(ClusterNode, ClusterNode, IgniteNodeValidationResult) - Constructor for class org.apache.ignite.events.NodeValidationFailedEvent
Creates new node validation event with given parameters.
nonheapMemoryCommited() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
nonheapMemoryInit() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
nonheapMemoryMax() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
nonheapMemoryTotal() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
nonheapMemoryUsed() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
NOOP_CONFIGURATION - Static variable in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Default noop configuration.
NoopCheckpointSpi - Class in org.apache.ignite.spi.checkpoint.noop
No-op implementation of CheckpointSpi.
NoopCheckpointSpi() - Constructor for class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
 
NoopCollisionSpi - Class in org.apache.ignite.spi.collision.noop
No-op implementation of CollisionSpi.
NoopCollisionSpi() - Constructor for class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
 
NoopEncryptionSpi - Class in org.apache.ignite.spi.encryption.noop
No operation EncryptionSPI implementation.
NoopEncryptionSpi() - Constructor for class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
 
NoopEventStorageSpi - Class in org.apache.ignite.spi.eventstorage
No-op implementation of EventStorageSpi.
NoopEventStorageSpi() - Constructor for class org.apache.ignite.spi.eventstorage.NoopEventStorageSpi
 
NoOpFailureHandler - Class in org.apache.ignite.failure
Just ignores any failure.
NoOpFailureHandler() - Constructor for class org.apache.ignite.failure.NoOpFailureHandler
 
NoopIndexingSpi - Class in org.apache.ignite.spi.indexing.noop
Default implementation of IndexingSpi which does not index cache.
NoopIndexingSpi() - Constructor for class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
 
NoopMetricExporterSpi - Class in org.apache.ignite.spi.metric.noop
No-op implementation of metric exporter SPI.
NoopMetricExporterSpi() - Constructor for class org.apache.ignite.spi.metric.noop.NoopMetricExporterSpi
 
NoopSpiSpecificSpan - Class in org.apache.ignite.spi.tracing
Noop and null-safe implementation of SpiSpecificSpan.
NoopTracingSpi - Class in org.apache.ignite.spi.tracing
Noop and null-safe implementation of Tracing SPI.
NoopTracingSpi() - Constructor for class org.apache.ignite.spi.tracing.NoopTracingSpi
 
NoOpWarmUpConfiguration - Class in org.apache.ignite.configuration
Noop warm-up configuration.
NoOpWarmUpConfiguration() - Constructor for class org.apache.ignite.configuration.NoOpWarmUpConfiguration
 
notifyExisting() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
notifyListener(UUID, Message, IgniteRunnable) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
nullable() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
nullable() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewColumnView
 
NullLogger - Class in org.apache.ignite.logger
Logger which does not output anything.
NullLogger() - Constructor for class org.apache.ignite.logger.NullLogger
 
NUMERIC_TYPES - Static variable in interface org.apache.ignite.cache.store.jdbc.JdbcTypesTransformer
Numeric types.

O

ObjectMetric<T> - Interface in org.apache.ignite.spi.metric
Interface for the metrics that holds typed value.
OdbcConfiguration - Class in org.apache.ignite.configuration
Deprecated.
OdbcConfiguration() - Constructor for class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Creates ODBC server configuration with all default values.
OdbcConfiguration(OdbcConfiguration) - Constructor for class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Creates ODBC server configuration by copying all properties from given configuration.
offer(T) - Method in interface org.apache.ignite.IgniteQueue
offer(T, long, TimeUnit) - Method in interface org.apache.ignite.IgniteQueue
oldValue() - Method in class org.apache.ignite.events.CacheEvent
Gets old value associated with this event.
oldValue() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets read entry old value (applicable for continuous queries).
oldValueRequired() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
onAckReceived() - Method in interface org.apache.ignite.plugin.extensions.communication.Message
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Method called when ack message received.
onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Method called when ack message received.
onAfterPut(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called after new value has been stored.
onAfterPut(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called after new value has been stored.
onAfterRemove(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called after value has been removed.
onAfterRemove(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called after value has been removed.
onAttributeSet(Object, Object) - Method in interface org.apache.ignite.compute.ComputeTaskSessionAttributeListener
Called on attribute change (set or update).
onBeforePut(Cache.Entry<K, V>, V) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called within IgniteCache.put(Object, Object) and similar operations before new value is stored in cache.
onBeforePut(Cache.Entry<K, V>, V) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called within IgniteCache.put(Object, Object) and similar operations before new value is stored in cache.
onBeforeRemove(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called within IgniteCache.remove(Object) and similar operations to provide control over returned value.
onBeforeRemove(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called within IgniteCache.remove(Object) and similar operations to provide control over returned value.
onBeforeStart() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
This method is called by built-in managers implementation to avoid repeating SPI start attempts.
onCacheChange(Iterator<CdcCacheEvent>) - Method in interface org.apache.ignite.cdc.CdcConsumer
Handles caches changes(create, edit) events.
onCacheConfigs(Iterator<StoredCacheData>) - Method in interface org.apache.ignite.dump.DumpConsumer
Handles cache configs.
onCacheDestroy(Iterator<Integer>) - Method in interface org.apache.ignite.cdc.CdcConsumer
Handles cache destroy events.
onCheckpointRemoved(String) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointListener
Notification for removed checkpoint.
onClientDisconnected(IgniteFuture<?>) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Client node disconnected callback.
onClientDisconnected(IgniteFuture<?>) - Method in interface org.apache.ignite.spi.IgniteSpi
Client node disconnected callback.
onClientDisconnected(IgniteFuture<?>) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Client node disconnected callback.
onClientReconnected(boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Client node reconnected callback.
onClientReconnected(boolean) - Method in interface org.apache.ignite.spi.IgniteSpi
Client node reconnected callback.
onClientReconnected(boolean) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Client node reconnected callback.
onCollision(CollisionContext) - Method in interface org.apache.ignite.spi.collision.CollisionSpi
This is a callback called: new grid job arrived executing job finished its execution topology changed periodically (on EventType.EVT_NODE_METRICS_UPDATED) When new job arrives it is added to the end of the wait list and this method is called.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
This is a callback called: new grid job arrived executing job finished its execution topology changed periodically (on EventType.EVT_NODE_METRICS_UPDATED) When new job arrives it is added to the end of the wait list and this method is called.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
This is a callback called: new grid job arrived executing job finished its execution topology changed periodically (on EventType.EVT_NODE_METRICS_UPDATED) When new job arrives it is added to the end of the wait list and this method is called.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
This is a callback called: new grid job arrived executing job finished its execution topology changed periodically (on EventType.EVT_NODE_METRICS_UPDATED) When new job arrives it is added to the end of the wait list and this method is called.
onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
This is a callback called: new grid job arrived executing job finished its execution topology changed periodically (on EventType.EVT_NODE_METRICS_UPDATED) When new job arrives it is added to the end of the wait list and this method is called.
onConnectionClosed(ConnectionClosedEvent) - Method in interface org.apache.ignite.client.events.ConnectionEventListener
 
onContextDestroyed() - Method in interface org.apache.ignite.spi.IgniteSpi
Callback invoked prior to stopping grid before SPI context is destroyed.
onContextDestroyed() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Callback invoked prior to stopping grid before SPI context is destroyed.
onContextDestroyed0() - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextDestroyed0() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Method to be called in the beginning of onContextDestroyed() method.
onContextInitialized(IgniteSpiContext) - Method in interface org.apache.ignite.spi.IgniteSpi
Callback invoked when SPI context is initialized.
onContextInitialized(IgniteSpiContext) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Callback invoked when SPI context is initialized.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Method to be called in the end of onContextInitialized method.
onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
Method to be called in the end of onContextInitialized method.
onDisconnected(Exception) - Method in interface org.apache.ignite.client.ClientDisconnectListener
Client disconnected callback.
onDisconnected(UUID) - Method in interface org.apache.ignite.spi.communication.CommunicationListener
Callback invoked when connection with remote node is lost.
onDiscovery(DiscoveryNotification) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiListener
Notification for grid node discovery events.
onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Callback for whenever entry is accessed.
onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in interface org.apache.ignite.cache.eviction.EvictionPolicy
Callback for whenever entry is accessed.
onEntryProcessorEntered(boolean) - Static method in class org.apache.ignite.thread.IgniteThread
Callback before entry processor execution is started.
onEntryProcessorLeft() - Static method in class org.apache.ignite.thread.IgniteThread
Callback after entry processor execution is finished.
onePhaseCommit() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
onError(Throwable) - Method in class org.apache.ignite.messaging.MessagingListenActor
This method is called in case when method MessagingListenActor.receive(UUID, Object) threw an exception.
onEvents(Iterator<CdcEvent>) - Method in interface org.apache.ignite.cdc.CdcConsumer
Handles entry changes events.
onExchange(DiscoveryDataBag) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiDataExchange
Notifies discovery manager about data received from remote node.
onExchange(DiscoveryDataPacket, ClassLoader) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
onExternalCollision() - Method in interface org.apache.ignite.spi.collision.CollisionExternalListener
Callback invoked by Collision SPI whenever an external collision event occurs.
onFailure(Ignite, FailureContext) - Method in class org.apache.ignite.failure.AbstractFailureHandler
Handles failure occurred on ignite instance.
onFailure(Ignite, FailureContext) - Method in interface org.apache.ignite.failure.FailureHandler
Handles failure occurred on ignite instance.
onForbidBinaryMetadataRequestSectionEntered() - Static method in class org.apache.ignite.thread.IgniteThread
Callback on entering critical section where binary metadata requests are forbidden.
onForbidBinaryMetadataRequestSectionLeft() - Static method in class org.apache.ignite.thread.IgniteThread
Callback on leaving critical section where binary metadata requests are forbidden.
onGet(K, V) - Method in interface org.apache.ignite.cache.CacheInterceptor
This method is called within IgniteCache.get(Object) and similar operations to provide control over returned value.
onGet(K, V) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
This method is called within IgniteCache.get(Object) and similar operations to provide control over returned value.
onHandshakeFail(HandshakeFailEvent) - Method in interface org.apache.ignite.client.events.ConnectionEventListener
 
onHandshakeStart(HandshakeStartEvent) - Method in interface org.apache.ignite.client.events.ConnectionEventListener
 
onHandshakeSuccess(HandshakeSuccessEvent) - Method in interface org.apache.ignite.client.events.ConnectionEventListener
 
onHeaderWritten() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Callback called when header of the message is written.
onIgniteStart() - Method in interface org.apache.ignite.plugin.CachePluginProvider
Callback that notifies that Ignite has successfully started, including all internal components.
onIgniteStart() - Method in interface org.apache.ignite.plugin.PluginProvider
Callback that notifies that Ignite has successfully started, including all internal components.
onIgniteStop(boolean) - Method in interface org.apache.ignite.plugin.CachePluginProvider
Callback to notify that Ignite is about to stop.
onIgniteStop(boolean) - Method in interface org.apache.ignite.plugin.PluginProvider
Callback to notify that Ignite is about to stop.
onLifecycleEvent(LifecycleEventType) - Method in interface org.apache.ignite.lifecycle.LifecycleBean
This method is called when lifecycle event occurs.
online() - Method in class org.apache.ignite.spi.systemview.view.BaselineNodeView
 
onLocalNodeInitialized(ClusterNode) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiListener
Notification of local node initialization.
onMappings(Iterator<TypeMapping>) - Method in interface org.apache.ignite.cdc.CdcConsumer
Handles new mappings from type name to id.
onMappings(Iterator<TypeMapping>) - Method in interface org.apache.ignite.dump.DumpConsumer
Handles type mappings.
onMasterNodeLeft(ComputeTaskSession) - Method in interface org.apache.ignite.compute.ComputeJobMasterLeaveAware
A method which is executed in case master node has left topology during job execution.
onMessage(UUID, T, IgniteRunnable) - Method in interface org.apache.ignite.spi.communication.CommunicationListener
NOTE: CommunicationSpi should ignore very first 4 bytes received from sender node and pass the rest of the received message to the listener.
onMessageReceived(Message, Object) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Collects statistics for message received by SPI.
onMessageSent(Message, Object) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Collects statistics for message sent by SPI.
onNodeLeft(Object) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
 
onPartition(int, int, Iterator<DumpEntry>) - Method in interface org.apache.ignite.dump.DumpConsumer
Handles cache data.
onReceive(Object) - Method in interface org.apache.ignite.configuration.ConnectorMessageInterceptor
Intercepts received objects.
onRequestFail(RequestFailEvent) - Method in interface org.apache.ignite.client.events.RequestEventListener
 
onRequestStart(RequestStartEvent) - Method in interface org.apache.ignite.client.events.RequestEventListener
 
onRequestSuccess(RequestSuccessEvent) - Method in interface org.apache.ignite.client.events.RequestEventListener
 
onSend(Object) - Method in interface org.apache.ignite.configuration.ConnectorMessageInterceptor
Intercepts received objects.
onSessionEnd(CacheStoreSession, boolean) - Method in interface org.apache.ignite.cache.store.CacheStoreSessionListener
On session end callback.
onSessionEnd(CacheStoreSession, boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
On session end callback.
onSessionStart(CacheStoreSession) - Method in interface org.apache.ignite.cache.store.CacheStoreSessionListener
On session start callback.
onSessionStart(CacheStoreSession) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
On session start callback.
onSpiContextDestroyed() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Callback invoked prior to stopping grid before SPI context is destroyed.
onSpiContextDestroyed() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Callback invoked prior to stopping grid before SPI context is destroyed.
onSpiContextInitialized(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Callback invoked when SPI context is initialized after TcpDiscoverySpi.spiStart(String) method is completed, SPI context can be stored for future access.
onSpiContextInitialized(IgniteSpiContext) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Callback invoked when SPI context is initialized after TcpDiscoverySpi.spiStart(String) method is completed, SPI context can be stored for future access.
onSpiContextInitialized(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Callback invoked when SPI context is initialized after TcpDiscoverySpi.spiStart(String) method is completed, SPI context can be stored for future access.
onStateChange(String, IgniteState) - Method in interface org.apache.ignite.IgnitionListener
Listener for grid factory state change notifications.
onTimeout() - Method in interface org.apache.ignite.spi.IgniteSpiTimeoutObject
Timeout callback.
onTypes(Iterator<BinaryType>) - Method in interface org.apache.ignite.cdc.CdcConsumer
Handles new binary types.
onTypes(Iterator<BinaryType>) - Method in interface org.apache.ignite.dump.DumpConsumer
Handles binary types.
onUndeploy(ClassLoader) - Method in class org.apache.ignite.marshaller.AbstractMarshaller
Undeployment callback invoked when class loader is being undeployed.
onUndeploy(ClassLoader) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Undeployment callback invoked when class loader is being undeployed.
onUnregistered(ClassLoader) - Method in interface org.apache.ignite.spi.deployment.DeploymentListener
Called when a deployment has been unregistered..
onUpdated(Iterable<? extends T>) - Method in interface org.apache.ignite.cache.query.ContinuousQueryWithTransformer.EventListener
Called after one or more entries have been updated.
OomExceptionHandler - Class in org.apache.ignite.thread
OOM exception handler for system threads.
OomExceptionHandler(GridKernalContext) - Constructor for class org.apache.ignite.thread.OomExceptionHandler
 
OpenCensusMetricExporterSpi - Class in org.apache.ignite.spi.metric.opencensus
OpenCensus monitoring exporter.
OpenCensusMetricExporterSpi() - Constructor for class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
 
OpenCensusSpanAdapter - Class in org.apache.ignite.spi.tracing.opencensus
Span implementation based on OpenCensus library.
OpenCensusTraceExporter - Class in org.apache.ignite.spi.tracing.opencensus
Wrapper of OpenCensus trace exporters adopted for Ignite lifecycle.
OpenCensusTraceExporter(SpanExporter.Handler) - Constructor for class org.apache.ignite.spi.tracing.opencensus.OpenCensusTraceExporter
 
OpenCensusTracingSpi - Class in org.apache.ignite.spi.tracing.opencensus
Tracing SPI implementation based on OpenCensus library.
OpenCensusTracingSpi() - Constructor for class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
This constructor is used if environment (JVM) already has OpenCensus tracing.
OpenCensusTracingSpi(SpanExporter.Handler...) - Constructor for class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
This constructor is used if environment (JVM) hasn't OpenCensus tracing.
openChannel(ClusterNode, Message) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
openConnection(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Gets connection from a pool.
openFileInputStream(String) - Method in class org.apache.ignite.ssl.SslContextFactory
By default, this method simply opens a raw file input stream.
openSocket(InetSocketAddress, IgniteSpiOperationTimeoutHelper) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
openSocket(Socket, InetSocketAddress, IgniteSpiOperationTimeoutHelper) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Connects to remote address sending U.IGNITE_HEADER when connection is established.
operation() - Method in interface org.apache.ignite.client.ClientRetryPolicyContext
Gets the operation type.
operationCode() - Method in class org.apache.ignite.client.events.RequestEvent
 
operationName() - Method in class org.apache.ignite.client.events.RequestEvent
 
OracleDialect - Class in org.apache.ignite.cache.store.jdbc.dialect
A dialect compatible with the Oracle database.
OracleDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.OracleDialect
 
OracleJdbcIpFinderDialect - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
Oracle JDBC dialect to use along with TcpDiscoveryJdbcIpFinder.
OracleJdbcIpFinderDialect() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.OracleJdbcIpFinderDialect
 
order() - Method in interface org.apache.ignite.cache.CacheEntryVersion
Order of the update.
order() - Method in interface org.apache.ignite.cluster.ClusterNode
Node order within grid topology.
order() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Node order within grid topology.
org.apache.ignite - package org.apache.ignite
Contains entry-point Ignite & HPC APIs.
org.apache.ignite.binary - package org.apache.ignite.binary
Contains Ignite Binary Objects API classes.
org.apache.ignite.cache - package org.apache.ignite.cache
Contains main Data Grid APIs.
org.apache.ignite.cache.affinity - package org.apache.ignite.cache.affinity
Contains cache node affinity implementations.
org.apache.ignite.cache.affinity.rendezvous - package org.apache.ignite.cache.affinity.rendezvous
Contains HRW-based cache affinity for partitioned cache.
org.apache.ignite.cache.eviction - package org.apache.ignite.cache.eviction
Contains cache eviction policy implementations.
org.apache.ignite.cache.eviction.fifo - package org.apache.ignite.cache.eviction.fifo
Contains cache FIFO eviction policy implementations.
org.apache.ignite.cache.eviction.lru - package org.apache.ignite.cache.eviction.lru
Contains cache LRU eviction policy implementations.
org.apache.ignite.cache.eviction.random - package org.apache.ignite.cache.eviction.random
Contains cache randomized eviction policy implementations.
org.apache.ignite.cache.eviction.sorted - package org.apache.ignite.cache.eviction.sorted
Contains cache sorted eviction policy implementation.
org.apache.ignite.cache.jta - package org.apache.ignite.cache.jta
Contains JTA (Java Transaction API) related public classes and interfaces.
org.apache.ignite.cache.jta.jndi - package org.apache.ignite.cache.jta.jndi
Contains JNDI-based transaction manager lookup.
org.apache.ignite.cache.jta.reflect - package org.apache.ignite.cache.jta.reflect
Contains reflection-based transaction manager lookup.
org.apache.ignite.cache.jta.websphere - package org.apache.ignite.cache.jta.websphere
Contains WebSphere integrations.
org.apache.ignite.cache.query - package org.apache.ignite.cache.query
Contains APIs for creating and executing cache queries.
org.apache.ignite.cache.query.annotations - package org.apache.ignite.cache.query.annotations
Contains query-related annotations.
org.apache.ignite.cache.store - package org.apache.ignite.cache.store
Contains cache store interfaces.
org.apache.ignite.cache.store.jdbc - package org.apache.ignite.cache.store.jdbc
Contains reference JDBC-based cache store implementation.
org.apache.ignite.cache.store.jdbc.dialect - package org.apache.ignite.cache.store.jdbc.dialect
Contains SQL dialects for different RDBMS.
org.apache.ignite.cache.websession - package org.apache.ignite.cache.websession
Contains classes for Web Sessions Caching.
org.apache.ignite.calcite - package org.apache.ignite.calcite
Contains Calcite-based query engine classes and interfaces.
org.apache.ignite.cdc - package org.apache.ignite.cdc
 
org.apache.ignite.client - package org.apache.ignite.client
Contains Ignite Thin Client API classes.
org.apache.ignite.client.events - package org.apache.ignite.client.events
 
org.apache.ignite.cluster - package org.apache.ignite.cluster
Contains cluster-related classes.
org.apache.ignite.compute - package org.apache.ignite.compute
Contains Compute Grid functionality.
org.apache.ignite.configuration - package org.apache.ignite.configuration
Contains configuration-related classes.
org.apache.ignite.development.utils - package org.apache.ignite.development.utils
Contains development utilities for Ignite useful for PDS artifacts analysis.
org.apache.ignite.dump - package org.apache.ignite.dump
 
org.apache.ignite.events - package org.apache.ignite.events
Contains Event Subscription functionality together with various events emitted by Ignite.
org.apache.ignite.failure - package org.apache.ignite.failure
Contains Failure handling public API with standard FailureHandler implementations.
org.apache.ignite.indexing - package org.apache.ignite.indexing
Contains Ignite-indexing module classes and interfaces.
org.apache.ignite.kubernetes.configuration - package org.apache.ignite.kubernetes.configuration
Contains Kubernetes configuration classes.
org.apache.ignite.lang - package org.apache.ignite.lang
Contains general language constructs and functional APIs for distributed computations.
org.apache.ignite.lifecycle - package org.apache.ignite.lifecycle
Contains lifecycle-related classes.
org.apache.ignite.logger - package org.apache.ignite.logger
Contains logging functionality used throughout the system.
org.apache.ignite.logger.java - package org.apache.ignite.logger.java
Contains Java logging implementation for logging.
org.apache.ignite.logger.jcl - package org.apache.ignite.logger.jcl
Contains Jakarta commons logging implementation for logging.
org.apache.ignite.logger.log4j2 - package org.apache.ignite.logger.log4j2
Contains default Log4j2 implementation for logging.
org.apache.ignite.logger.slf4j - package org.apache.ignite.logger.slf4j
Contains SLF4J implementation for logging.
org.apache.ignite.maintenance - package org.apache.ignite.maintenance
Contains public interfaces for maintenance mechanism.
org.apache.ignite.marshaller - package org.apache.ignite.marshaller
Contains various supported marshallers.
org.apache.ignite.marshaller.jdk - package org.apache.ignite.marshaller.jdk
Contains JDK java.io based marshaller.
org.apache.ignite.mem - package org.apache.ignite.mem
 
org.apache.ignite.messaging - package org.apache.ignite.messaging
Contains Topic-based Messaging functionality.
org.apache.ignite.mxbean - package org.apache.ignite.mxbean
Contains annotations for Dynamic MBeans.
org.apache.ignite.platform - package org.apache.ignite.platform
Contains platform-related classes.
org.apache.ignite.platform.cpp - package org.apache.ignite.platform.cpp
Contains C++ platform-related classes.
org.apache.ignite.platform.dotnet - package org.apache.ignite.platform.dotnet
Contains .Net platform-related classes.
org.apache.ignite.plugin - package org.apache.ignite.plugin
Contains plugins management API.
org.apache.ignite.plugin.extensions.communication - package org.apache.ignite.plugin.extensions.communication
Contains extendable components for communication.
org.apache.ignite.plugin.platform - package org.apache.ignite.plugin.platform
Contains platform plugins management API.
org.apache.ignite.plugin.security - package org.apache.ignite.plugin.security
Contains APIs for security, authentication, and authorization.
org.apache.ignite.plugin.segmentation - package org.apache.ignite.plugin.segmentation
Contains segmentation "split-brain" related classes.
org.apache.ignite.resources - package org.apache.ignite.resources
Contains resource injection annotations.
org.apache.ignite.scheduler - package org.apache.ignite.scheduler
Contains Job Scheduling functionality.
org.apache.ignite.services - package org.apache.ignite.services
Contains main Managed Services APIs.
org.apache.ignite.spi - package org.apache.ignite.spi
Contains common classes and interfaces for SPI implementations.
org.apache.ignite.spi.checkpoint - package org.apache.ignite.spi.checkpoint
Contains APIs for checkpoint SPI.
org.apache.ignite.spi.checkpoint.cache - package org.apache.ignite.spi.checkpoint.cache
Contains cache-based implementation for checkpoint SPI.
org.apache.ignite.spi.checkpoint.jdbc - package org.apache.ignite.spi.checkpoint.jdbc
Contains JDBC implementation for checkpoint SPI.
org.apache.ignite.spi.checkpoint.noop - package org.apache.ignite.spi.checkpoint.noop
Contains default no-op checkpoint SPI implementation.
org.apache.ignite.spi.checkpoint.sharedfs - package org.apache.ignite.spi.checkpoint.sharedfs
Contains shared file system implementation for checkpoint SPI.
org.apache.ignite.spi.collision - package org.apache.ignite.spi.collision
Contains APIs for collision SPI.
org.apache.ignite.spi.collision.fifoqueue - package org.apache.ignite.spi.collision.fifoqueue
Contains FIFO based collision SPI implementation.
org.apache.ignite.spi.collision.jobstealing - package org.apache.ignite.spi.collision.jobstealing
Contains job stealing collision SPI implementation.
org.apache.ignite.spi.collision.noop - package org.apache.ignite.spi.collision.noop
Contains default no-op collision SPI implementation.
org.apache.ignite.spi.collision.priorityqueue - package org.apache.ignite.spi.collision.priorityqueue
Contains priority based collision SPI implementation.
org.apache.ignite.spi.communication - package org.apache.ignite.spi.communication
Contains APIs for grid communication SPI.
org.apache.ignite.spi.communication.tcp - package org.apache.ignite.spi.communication.tcp
Contains default TCP/IP-based implementation for communication SPI.
org.apache.ignite.spi.communication.tcp.messages - package org.apache.ignite.spi.communication.tcp.messages
Contains implementation messages.
org.apache.ignite.spi.deployment - package org.apache.ignite.spi.deployment
Contains APIs for deployment SPI.
org.apache.ignite.spi.deployment.local - package org.apache.ignite.spi.deployment.local
Contains default local deployment SPI implementation.
org.apache.ignite.spi.deployment.uri - package org.apache.ignite.spi.deployment.uri
Contains URI-based deployment SPI implementation.
org.apache.ignite.spi.discovery - package org.apache.ignite.spi.discovery
Contains APIs for topology manager SPI.
org.apache.ignite.spi.discovery.isolated - package org.apache.ignite.spi.discovery.isolated
Contains implementation of special "isolated" mode for single-node cluster.
org.apache.ignite.spi.discovery.tcp - package org.apache.ignite.spi.discovery.tcp
Contains default TCP/IP implementation for discovery SPI.
org.apache.ignite.spi.discovery.tcp.ipfinder - package org.apache.ignite.spi.discovery.tcp.ipfinder
Contains IP finder interface and adapter.
org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc - package org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
Contains JDBC IP finder implementation.
org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes - package org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes
Contains Kubernetes IP finder implementation.
org.apache.ignite.spi.discovery.tcp.ipfinder.multicast - package org.apache.ignite.spi.discovery.tcp.ipfinder.multicast
Contains multicast-based IP finder.
org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs - package org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs
Contains shared filesystem-based IP finder.
org.apache.ignite.spi.discovery.tcp.ipfinder.vm - package org.apache.ignite.spi.discovery.tcp.ipfinder.vm
Contains local JVM-based IP finder.
org.apache.ignite.spi.discovery.zk - package org.apache.ignite.spi.discovery.zk
Contains Zookeeper Discovery Spi classes and interfaces.
org.apache.ignite.spi.encryption - package org.apache.ignite.spi.encryption
Contains APIs for encryption SPI.
org.apache.ignite.spi.encryption.keystore - package org.apache.ignite.spi.encryption.keystore
Contains encryption SPI implementation based on standard jdk keystore.
org.apache.ignite.spi.encryption.noop - package org.apache.ignite.spi.encryption.noop
Contains no-op encryption SPI implementation.
org.apache.ignite.spi.eventstorage - package org.apache.ignite.spi.eventstorage
Contains APIs for event storage SPI.
org.apache.ignite.spi.eventstorage.memory - package org.apache.ignite.spi.eventstorage.memory
Contains default in-memory implementation for event storage SPI.
org.apache.ignite.spi.failover - package org.apache.ignite.spi.failover
Contains APIs for failover SPI.
org.apache.ignite.spi.failover.always - package org.apache.ignite.spi.failover.always
Contains default "always" failover SPI.
org.apache.ignite.spi.failover.jobstealing - package org.apache.ignite.spi.failover.jobstealing
Contains job stealing failover SPI.
org.apache.ignite.spi.failover.never - package org.apache.ignite.spi.failover.never
Contains "never" failover SPI.
org.apache.ignite.spi.indexing - package org.apache.ignite.spi.indexing
Contains APIs for indexing SPI.
org.apache.ignite.spi.indexing.noop - package org.apache.ignite.spi.indexing.noop
Contains default no-op indexing SPI implementation.
org.apache.ignite.spi.loadbalancing - package org.apache.ignite.spi.loadbalancing
Contains APIs for load balancing SPI.
org.apache.ignite.spi.loadbalancing.adaptive - package org.apache.ignite.spi.loadbalancing.adaptive
Contains adaptive load balancing SPI.
org.apache.ignite.spi.loadbalancing.roundrobin - package org.apache.ignite.spi.loadbalancing.roundrobin
Contains default round-robin implementation for load balancing SPI.
org.apache.ignite.spi.loadbalancing.weightedrandom - package org.apache.ignite.spi.loadbalancing.weightedrandom
Contains weighted random-base implementation for load balancing SPI.
org.apache.ignite.spi.metric - package org.apache.ignite.spi.metric
Contains common classes and interfaces for metric SPI implementations.
org.apache.ignite.spi.metric.jmx - package org.apache.ignite.spi.metric.jmx
Contains JMX based implementation of MetricExporterSpi.
org.apache.ignite.spi.metric.log - package org.apache.ignite.spi.metric.log
Contains push to log implementation of MetricExporterSpi.
org.apache.ignite.spi.metric.noop - package org.apache.ignite.spi.metric.noop
Contains no-op implementation of MetricExporterSpi.
org.apache.ignite.spi.metric.opencensus - package org.apache.ignite.spi.metric.opencensus
 
org.apache.ignite.spi.systemview - package org.apache.ignite.spi.systemview
Contains common classes and interfaces for system view SPI implementations.
org.apache.ignite.spi.systemview.view - package org.apache.ignite.spi.systemview.view
Contains SystemView clases that exists in Ignite.
org.apache.ignite.spi.systemview.view.datastructures - package org.apache.ignite.spi.systemview.view.datastructures
 
org.apache.ignite.spi.systemview.view.sql - package org.apache.ignite.spi.systemview.view.sql
 
org.apache.ignite.spi.tracing - package org.apache.ignite.spi.tracing
Contains common classes and interfaces for tracing SPI implementations.
org.apache.ignite.spi.tracing.opencensus - package org.apache.ignite.spi.tracing.opencensus
Contains API for OpenCensus Tracing framework integration.
org.apache.ignite.ssl - package org.apache.ignite.ssl
Contains classes for working with SSL.
org.apache.ignite.startup - package org.apache.ignite.startup
Contains Ignite runtime startup classes.
org.apache.ignite.startup.cmdline - package org.apache.ignite.startup.cmdline
Contains default command line startup.
org.apache.ignite.startup.servlet - package org.apache.ignite.startup.servlet
Contains servlet-based startup.
org.apache.ignite.stream - package org.apache.ignite.stream
Contains Ignite Streamer classes.
org.apache.ignite.stream.socket - package org.apache.ignite.stream.socket
Contains socket streamer implementation.
org.apache.ignite.thread - package org.apache.ignite.thread
Contains threads-related utility classes.
org.apache.ignite.transactions - package org.apache.ignite.transactions
Contains transaction-related classes.
originatingNodeId() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
originNodeId() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets ID of grid node that initiated the service deployment.
originNodeId() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets ID of grid node that initiated the service deployment.
originNodeId() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
originNodeId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
originNodeId() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
originNodeId() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
OS_INFO_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
OS_USER_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
otherClusterVersion() - Method in interface org.apache.ignite.cache.CacheEntryVersion
If source of the update is "local" cluster then null will be returned.
otherNodeId() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
OUT_OF_RESOURCES_TCP_MSG - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Deprecated.
This constant is not used and will be removed in future releases.
outboundMessagesQueue() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 

P

pageFreeSpace() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
PageReplacementMode - Enum in org.apache.ignite.configuration
Defines memory page replacement algorithm.
PageReplacementStartedEvent - Class in org.apache.ignite.events
Event type indicating that page replacement started in one of the configured data regions.
PageReplacementStartedEvent(ClusterNode, String, String) - Constructor for class org.apache.ignite.events.PageReplacementStartedEvent
 
pagesCount() - Method in class org.apache.ignite.spi.systemview.view.PagesTimestampHistogramView
 
pageSize(int) - Method in interface org.apache.ignite.client.ClientIgniteSet
Sets the page size to be used for batched network data retrieval in ClientIgniteSet.iterator() and ClientIgniteSet.toArray().
pageSize() - Method in interface org.apache.ignite.client.ClientIgniteSet
Gets the page size to be used for batched network data retrieval in ClientIgniteSet.iterator() and ClientIgniteSet.toArray().
pageSize() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
PagesListView - Class in org.apache.ignite.spi.systemview.view
Pages-list representation for a SystemView.
PagesListView(PagesList, int) - Constructor for class org.apache.ignite.spi.systemview.view.PagesListView
 
PagesTimestampHistogramView - Class in org.apache.ignite.spi.systemview.view
Pages timestamp histogramm representation for a SystemView.
PagesTimestampHistogramView(String, long, long, long) - Constructor for class org.apache.ignite.spi.systemview.view.PagesTimestampHistogramView
 
pairedConnection() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
PARAM_ENFORCE_JOIN_ORDER - Static variable in class org.apache.ignite.IgniteJdbcDriver
Parameter: enforce join order flag (SQL hint).
PARAM_LAZY - Static variable in class org.apache.ignite.IgniteJdbcDriver
Parameter: replicated only flag (SQL hint).
PARAM_SCHEMA - Static variable in class org.apache.ignite.IgniteJdbcDriver
Parameter: schema name.
parameters() - Method in class org.apache.ignite.maintenance.MaintenanceTask
 
parse(I, Object...) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
This method should transform raw data records into valid key-value pairs to be stored into cache.
parse(PrintStream, String...) - Static method in class org.apache.ignite.development.utils.IgniteWalConverterArguments
Parse command line arguments and return filled IgniteWalConverterArguments
partiallyFilledPagesFreeSpace() - Method in interface org.apache.ignite.DataRegionMetricsProvider
Calculates free space of partially filled pages for this data region.
partition(K) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets partition id for the given key.
partition(Object) - Method in interface org.apache.ignite.cache.affinity.AffinityFunction
Gets partition number for a given key starting from 0.
partition(Object) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets partition number for a given key starting from 0.
partition() - Method in interface org.apache.ignite.cdc.CdcEvent
Ignite split dataset into smaller chunks to distribute them across the cluster.
partition(Object) - Method in interface org.apache.ignite.client.ClientPartitionAwarenessMapper
Gets a partition number for a given key starting from 0.
partition() - Method in interface org.apache.ignite.events.CacheConsistencyViolationEvent.EntriesInfo
 
partition() - Method in class org.apache.ignite.events.CacheEvent
Gets partition for the event which is the partition the key belongs to.
partition() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets partition for the event.
partition(Object) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Gets partition number for a given key starting from 0.
partition() - Method in interface org.apache.ignite.spi.failover.FailoverContext
partition(String, Object) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Calculates partition number for given key.
partition() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
partitionId() - Method in class org.apache.ignite.spi.systemview.view.CachePagesListView
 
partitionId() - Method in class org.apache.ignite.spi.systemview.view.PartitionStateView
 
PartitionLossPolicy - Enum in org.apache.ignite.cache
Partition loss policy.
partitionLossPolicy() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
partitionLossPolicy() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
partitions() - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets number of partitions in cache according to configured affinity function.
partitions() - Method in interface org.apache.ignite.cache.affinity.AffinityFunction
Gets total number of partitions available.
partitions() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Gets total number of partitions available.
partitions() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Gets total number of partitions available.
partitionsCount() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
PartitionStateView - Class in org.apache.ignite.spi.systemview.view
Partition state representation for a SystemView.
PartitionStateView(int, UUID, int, GridDhtPartitionState, boolean) - Constructor for class org.apache.ignite.spi.systemview.view.PartitionStateView
 
patch(Collection<SchemaAbstractOperation>) - Static method in class org.apache.ignite.cache.QueryEntityPatch
Builder method for patch with operations.
pattern() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
Gets scheduling pattern.
peek() - Method in interface org.apache.ignite.IgniteQueue
PerformanceStatisticsMBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use managements API beans, instead.
permissions() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Deprecated.
SecuritySubject must contain only immutable set of information that represents a security principal. Security permissions are part of authorization process and have nothing to do with SecuritySubject. This method will be removed in the future releases.
perNodeBufferSize() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets size of per node key-value pairs buffer.
perNodeBufferSize(int) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets size of per node key-value pairs buffer.
perNodeParallelOperations() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets maximum number of parallel stream operations for a single node.
perNodeParallelOperations(int) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets maximum number of parallel stream operations for a single node.
PersistentStoreConfiguration - Class in org.apache.ignite.configuration
Deprecated.
PersistentStoreConfiguration() - Constructor for class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
perThreadBufferSize(int) - Method in interface org.apache.ignite.IgniteDataStreamer
Allows to set buffer size for thread in case of stream by IgniteDataStreamer.addData(Object, Object) call.
perThreadBufferSize() - Method in interface org.apache.ignite.IgniteDataStreamer
physicalReads() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupIoView
 
pingNode(UUID) - Method in interface org.apache.ignite.IgniteCluster
Pings a remote node.
pingNode(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Pings node with given node ID to see whether it is alive.
pingNode(UUID) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Pings the remote node to see if it's alive.
pingNode(UUID) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Pings the remote node to see if it's alive.
pingNode(UUID) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Pings the remote node to see if it's alive.
pingNode(UUID) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Pings the remote node to see if it's alive.
pingNode(UUID) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Pings a remote node.
pingNodeByAddress(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Pings node with given host name to see if it is alive.
pk() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
PlatformCacheConfiguration - Class in org.apache.ignite.configuration
Platform cache configuration.
PlatformCacheConfiguration() - Constructor for class org.apache.ignite.configuration.PlatformCacheConfiguration
 
PlatformCachePluginConfigurationClosure - Interface in org.apache.ignite.plugin.platform
Platform cache configuration handler: updates plugin configuration using data sent from platform code.
PlatformCachePluginConfigurationClosureFactory - Interface in org.apache.ignite.plugin.platform
Factory for @PlatformCachePluginConfigurationClosure with a unique id.
PlatformConfiguration - Interface in org.apache.ignite.configuration
Platform configuration marker interface.
PlatformCppConfiguration - Class in org.apache.ignite.platform.cpp
Platform CPP configuration.
PlatformCppConfiguration() - Constructor for class org.apache.ignite.platform.cpp.PlatformCppConfiguration
Default constructor.
PlatformCppConfiguration(PlatformConfiguration) - Constructor for class org.apache.ignite.platform.cpp.PlatformCppConfiguration
Copying constructor.
PlatformDotNetAffinityFunction - Class in org.apache.ignite.platform.dotnet
AffinityFunction implementation which can be used to configure .NET affinity function in Java Spring configuration.
PlatformDotNetAffinityFunction() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
 
PlatformDotNetBinaryConfiguration - Class in org.apache.ignite.platform.dotnet
Mirror of .Net class BinaryConfiguration.cs
PlatformDotNetBinaryConfiguration() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
Default constructor.
PlatformDotNetBinaryConfiguration(PlatformDotNetBinaryConfiguration) - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
Copy constructor.
PlatformDotNetBinaryTypeConfiguration - Class in org.apache.ignite.platform.dotnet
Mirror of .Net class BinaryTypeConfiguration.cs
PlatformDotNetBinaryTypeConfiguration() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Default constructor.
PlatformDotNetBinaryTypeConfiguration(PlatformDotNetBinaryTypeConfiguration) - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Copy constructor.
PlatformDotNetCacheStoreFactory - Class in org.apache.ignite.platform.dotnet
Wrapper for .NET cache store implementations.
PlatformDotNetCacheStoreFactory() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
 
PlatformDotNetCacheStoreFactoryNative - Class in org.apache.ignite.platform.dotnet
Cache store factory that wraps native factory object.
PlatformDotNetCacheStoreFactoryNative(Object) - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactoryNative
Ctor.
PlatformDotNetConfiguration - Class in org.apache.ignite.platform.dotnet
Mirror of .Net class IgniteConfiguration.cs
PlatformDotNetConfiguration() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
Default constructor.
PlatformDotNetConfiguration(PlatformDotNetConfiguration) - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
Copy constructor.
PlatformDotNetLifecycleBean - Class in org.apache.ignite.platform.dotnet
Lifecycle bean implementation which can be used to configure .Net lifecycle beans in Java Spring configuration.
PlatformDotNetLifecycleBean() - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Constructor.
PlatformDotNetLifecycleBean(String) - Constructor for class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Constructor.
PlatformJavaObjectFactory<T> - Interface in org.apache.ignite.platform
Object factory used for advanced interop between platform and Java.
PlatformPluginConfigurationClosure - Interface in org.apache.ignite.plugin.platform
Platform configuration handler: updates plugin configuration using data sent from platform code.
PlatformPluginConfigurationClosureFactory - Interface in org.apache.ignite.plugin.platform
Factory for @PlatformPluginConfigurationClosure with a unique id.
PlatformServiceMethod - Annotation Type in org.apache.ignite.platform
Annotation for setting mapping between java interface's method and platform service's method.
platformType() - Method in interface org.apache.ignite.cdc.TypeMapping
 
platformType() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets platform type.
PlatformType - Enum in org.apache.ignite.platform
Interop platform type.
plugin(String) - Method in interface org.apache.ignite.Ignite
Gets an instance of deployed Ignite plugin.
plugin(String) - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of deployed Ignite plugin.
plugin() - Method in interface org.apache.ignite.plugin.PluginProvider
 
PluginConfiguration - Interface in org.apache.ignite.plugin
Plugin configuration.
PluginContext - Interface in org.apache.ignite.plugin
Plugin context.
PluginNotFoundException - Exception in org.apache.ignite.plugin
Exception thrown if plugin is not found.
PluginNotFoundException(String) - Constructor for exception org.apache.ignite.plugin.PluginNotFoundException
 
PluginProvider<C extends PluginConfiguration> - Interface in org.apache.ignite.plugin
Pluggable Ignite component.
PluginValidationException - Exception in org.apache.ignite.plugin
Plugin validation exception.
PluginValidationException(String, String, UUID) - Constructor for exception org.apache.ignite.plugin.PluginValidationException
Constructs invalid plugin exception.
policy() - Method in class org.apache.ignite.thread.IgniteThread
 
poll() - Method in interface org.apache.ignite.IgniteQueue
poll(long, TimeUnit) - Method in interface org.apache.ignite.IgniteQueue
port() - Method in class org.apache.ignite.spi.communication.tcp.AttributeNames
Deprecated.
 
precision() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
precision() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewColumnView
 
predefined() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlSchemaView
 
predicate() - Method in interface org.apache.ignite.cluster.ClusterGroup
Gets predicate that defines a subset of nodes for this cluster group.
preloadPartition(int) - Method in interface org.apache.ignite.IgniteCache
Efficiently preloads cache primary partition into page memory.
preloadPartitionAsync(int) - Method in interface org.apache.ignite.IgniteCache
Efficiently preloads cache partition into page memory.
prepare(int[]) - Method in class org.apache.ignite.cache.query.Query
Prepares the partitions.
prepareAndExecuteMaintenance() - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Examine all components if they need to execute maintenance actions.
prepareBuilders(String, Collection<JdbcType>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Prepare internal store specific builders for provided types metadata.
prepareBuilders(String, Collection<JdbcType>) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Prepare internal store specific builders for provided types metadata.
previousAssignment(int) - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
Gets affinity assignment for given partition on previous topology version.
previousState() - Method in class org.apache.ignite.events.ClusterStateChangeEvent
 
previousState() - Method in class org.apache.ignite.events.ClusterStateChangeStartedEvent
 
previousTag() - Method in class org.apache.ignite.events.ClusterTagUpdatedEvent
Value of cluster tag before update request that triggered this event.
primary() - Method in interface org.apache.ignite.cdc.CdcEvent
 
primaryPartitions(ClusterNode) - Method in interface org.apache.ignite.cache.affinity.Affinity
Gets partition ids for which the given cluster node has primary ownership.
printLastErrors() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Prints errors.
printStackTrace(PrintStream) - Method in exception org.apache.ignite.spi.IgniteSpiMultiException
PriorityQueueCollisionSpi - Class in org.apache.ignite.spi.collision.priorityqueue
This class provides implementation for Collision SPI based on priority queue.
PriorityQueueCollisionSpi() - Constructor for class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
 
PriorityQueueCollisionSpiMBean - Interface in org.apache.ignite.spi.collision.priorityqueue
Management bean that provides access to the priority queue collision SPI configuration.
processedPartitions() - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Deprecated.
Get count of processed partitions.
processSessionCreationError(ClusterNode, Collection<InetSocketAddress>, IgniteCheckedException) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Process errors if TCP/IP GridNioSession creation to remote node hasn't been performed.
processSystemClasses(ClassLoader, Collection<PluginProvider>, Consumer<String>) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Find all system class names (for JDK or Ignite classes) and process them with a given consumer.
produce() - Method in interface org.apache.ignite.lang.IgniteProducer
 
PROP_CACHE - Static variable in class org.apache.ignite.IgniteJdbcDriver
Cache name property name.
PROP_CFG - Static variable in class org.apache.ignite.IgniteJdbcDriver
Cache name property name.
PROP_COLLOCATED - Static variable in class org.apache.ignite.IgniteJdbcDriver
Collocated property name.
PROP_DISTRIBUTED_JOINS - Static variable in class org.apache.ignite.IgniteJdbcDriver
Distributed joins property name.
PROP_ENFORCE_JOIN_ORDER - Static variable in class org.apache.ignite.IgniteJdbcDriver
Transactions allowed property name.
PROP_HOST - Static variable in class org.apache.ignite.IgniteJdbcDriver
Hostname property name.
PROP_LAZY - Static variable in class org.apache.ignite.IgniteJdbcDriver
Lazy property name.
PROP_LOCAL - Static variable in class org.apache.ignite.IgniteJdbcDriver
Local property name.
PROP_MULTIPLE_STMTS - Static variable in class org.apache.ignite.IgniteJdbcDriver
Allow query with multiple statements.
PROP_NODE_ID - Static variable in class org.apache.ignite.IgniteJdbcDriver
Node ID property name.
PROP_PORT - Static variable in class org.apache.ignite.IgniteJdbcDriver
Port number property name.
PROP_SCHEMA - Static variable in class org.apache.ignite.IgniteJdbcDriver
Schema property name.
PROP_SKIP_REDUCER_ON_UPDATE - Static variable in class org.apache.ignite.IgniteJdbcDriver
Skip reducer on update update property name.
PROP_STREAMING - Static variable in class org.apache.ignite.IgniteJdbcDriver
DML streaming property name.
PROP_STREAMING_ALLOW_OVERWRITE - Static variable in class org.apache.ignite.IgniteJdbcDriver
Whether DML streaming will overwrite existing cache entries.
PROP_STREAMING_FLUSH_FREQ - Static variable in class org.apache.ignite.IgniteJdbcDriver
DML stream auto flush frequency property name.
PROP_STREAMING_PER_NODE_BUF_SIZE - Static variable in class org.apache.ignite.IgniteJdbcDriver
DML stream node buffer size property name.
PROP_STREAMING_PER_NODE_PAR_OPS - Static variable in class org.apache.ignite.IgniteJdbcDriver
DML stream parallel operations per node property name.
PROP_TX_ALLOWED - Static variable in class org.apache.ignite.IgniteJdbcDriver
Transactions allowed property name.
properties() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Gets current session properties.
proto - Variable in class org.apache.ignite.ssl.AbstractSslContextFactory
SSL protocol.
protocol() - Method in class org.apache.ignite.client.events.ConnectionDescription
 
protocols - Variable in class org.apache.ignite.ssl.AbstractSslContextFactory
Enabled protocols.
provideDiscoveryData(UUID) - Method in interface org.apache.ignite.plugin.PluginProvider
Gets plugin discovery data object that will be sent to the new node during discovery process.
publish(LogRecord) - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
put(K, V) - Method in interface org.apache.ignite.client.ClientCache
Associates the specified value with the specified key in the cache.
put(K, V) - Method in interface org.apache.ignite.IgniteCache
put(T) - Method in interface org.apache.ignite.IgniteQueue
put(V1, V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
put(String, String) - Method in class org.apache.ignite.services.ServiceCallContextBuilder
Put string attribute.
put(String, byte[]) - Method in class org.apache.ignite.services.ServiceCallContextBuilder
Put binary attribute.
put(String, K, V, long) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Puts object in cache.
putAll(Map<? extends K, ? extends V>) - Method in interface org.apache.ignite.client.ClientCache
Copies all of the entries from the specified map to the ClientCache.
putAll(Map<? extends K, ? extends V>) - Method in interface org.apache.ignite.IgniteCache
Keys are locked in the order in which they appear in map.
putAll(Map<? extends V1, ? extends V2>) - Method in class org.apache.ignite.lang.IgniteBiTuple
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.apache.ignite.client.ClientCache
Copies all of the entries from the specified map to the ClientCache.
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously copies all of the entries from the specified map to the Cache.
putAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Associates the specified value with the specified key in the cache asynchronously.
putAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously associates the specified value with the specified key in the cache.
putIfAbsent(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically associates the specified key with the given value if it is not already associated with a value.
putIfAbsent(K, V) - Method in interface org.apache.ignite.IgniteCache
For CacheAtomicityMode.ATOMIC return value on primary node crash may be incorrect because of the automatic retries.
putIfAbsent(String, K, V, long) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Puts object into cache if there was no previous object associated with given key.
putIfAbsentAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically associates the specified key with the given value if it is not already associated with a value.
putIfAbsentAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously associates the specified key with the given value if it is not already associated with a value.
putMetaIfAbsent(T) - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Adds given metadata value only if it was absent.

Q

Query<R> - Class in org.apache.ignite.cache.query
Main API for configuring and executing cache queries.
query() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
 
query(Query<R>) - Method in interface org.apache.ignite.client.ClientCache
Queries cache.
query(ContinuousQuery<K, V>, ClientDisconnectListener) - Method in interface org.apache.ignite.client.ClientCache
Start ContinuousQuery on the cache.
query(SqlFieldsQuery) - Method in interface org.apache.ignite.client.ClientCache
Convenience method to execute SqlFieldsQuery.
query(SqlFieldsQuery) - Method in interface org.apache.ignite.client.IgniteClient
Execute SQL query and get cursor to iterate over results.
query(Query<R>) - Method in interface org.apache.ignite.IgniteCache
Queries cache.
query(SqlFieldsQuery) - Method in interface org.apache.ignite.IgniteCache
Queries cache.
query(Query<T>, IgniteClosure<T, R>) - Method in interface org.apache.ignite.IgniteCache
Queries the cache transforming the entries on the server nodes.
query(SqlFieldsQuery) - Method in class org.apache.ignite.IgniteClientSpringBean
Execute SQL query and get cursor to iterate over results.
query(String, Collection<Object>, IndexingQueryFilter) - Method in interface org.apache.ignite.spi.indexing.IndexingSpi
Executes query.
query(String, Collection<Object>, IndexingQueryFilter) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
Executes query.
QueryCancelledException - Exception in org.apache.ignite.cache.query
The exception is thrown if a query was cancelled or timed out while executing.
QueryCancelledException() - Constructor for exception org.apache.ignite.cache.query.QueryCancelledException
Default constructor.
QueryCancelledException(String) - Constructor for exception org.apache.ignite.cache.query.QueryCancelledException
 
QueryCursor<T> - Interface in org.apache.ignite.cache.query
Query result cursor.
QueryDetailMetrics - Interface in org.apache.ignite.cache.query
Query metrics aggregated by query type and its textual representation.
queryDetailMetrics() - Method in interface org.apache.ignite.IgniteCache
Gets query detail metrics.
queryDetailMetricsSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
QueryEngineConfiguration - Interface in org.apache.ignite.configuration
Interface for the configuration of the query engine.
queryEntities() - Method in interface org.apache.ignite.cdc.CdcCacheEvent
Returns current state of configured QueryEntity.
QueryEntity - Class in org.apache.ignite.cache
Query entity is a description of cache entry (composed of key and value) in a way of how it must be indexed and can be queried.
QueryEntity() - Constructor for class org.apache.ignite.cache.QueryEntity
Creates an empty query entity.
QueryEntity(QueryEntity) - Constructor for class org.apache.ignite.cache.QueryEntity
Copy constructor.
QueryEntity(String, String) - Constructor for class org.apache.ignite.cache.QueryEntity
Creates a query entity with the given key and value types.
QueryEntity(Class<?>, Class<?>) - Constructor for class org.apache.ignite.cache.QueryEntity
Creates a query entity with the given key and value types.
QueryEntityPatch - Class in org.apache.ignite.cache
Query entity patch which contain SchemaAbstractOperation operations for changing query entity.
QueryGroupIndex - Annotation Type in org.apache.ignite.cache.query.annotations
Describes group index.
QueryGroupIndex.List - Annotation Type in org.apache.ignite.cache.query.annotations
List of group indexes for type.
queryId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
queryId() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
QueryIndex - Class in org.apache.ignite.cache
Contains list of fields to be indexed.
QueryIndex() - Constructor for class org.apache.ignite.cache.QueryIndex
Creates an empty index.
QueryIndex(String) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates single-field sorted ascending index.
QueryIndex(String, boolean) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates single-field sorted index.
QueryIndex(String, boolean, String) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates single-field sorted index.
QueryIndex(String, QueryIndexType) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates index for one field.
QueryIndex(String, QueryIndexType, boolean) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates index for one field.
QueryIndex(String, QueryIndexType, boolean, String) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates index for one field.
QueryIndex(Collection<String>, QueryIndexType) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates index for a collection of fields.
QueryIndex(LinkedHashMap<String, Boolean>, QueryIndexType) - Constructor for class org.apache.ignite.cache.QueryIndex
Creates index for a collection of fields.
QueryIndexType - Enum in org.apache.ignite.cache
Index type.
QueryMetrics - Interface in org.apache.ignite.cache.query
Cache query metrics used to obtain statistics on query.
queryMetrics() - Method in interface org.apache.ignite.IgniteCache
Gets query metrics.
QueryMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use managements API beans, instead.
queryParallelism() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
QueryRetryException - Exception in org.apache.ignite.cache.query
The exception is thrown if a query was cancelled or timed out while executing.
QueryRetryException(String) - Constructor for exception org.apache.ignite.cache.query.QueryRetryException
 
QuerySqlField - Annotation Type in org.apache.ignite.cache.query.annotations
Annotates fields for SQL queries.
QuerySqlField.Group - Annotation Type in org.apache.ignite.cache.query.annotations
Describes group of index and position of field in this group.
QuerySqlFunction - Annotation Type in org.apache.ignite.cache.query.annotations
Annotates public static methods in classes to be used in SQL queries as custom functions.
QueryTextField - Annotation Type in org.apache.ignite.cache.query.annotations
Annotation for fields to be indexed for full text search using Lucene.
queryType() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
 
queryType() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets query type.
queryType() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets query type.
queue() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Gets read-only view on internal FIFO queue in proper order.
queue() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Gets read-only view on internal FIFO queue in proper order.
queue() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Gets read-only view of backed queue in proper order.
queue(String, int, CollectionConfiguration) - Method in interface org.apache.ignite.Ignite
Will get a named queue from cache and create one if it has not been created yet and cfg is not null.
queue(String, int, CollectionConfiguration) - Method in class org.apache.ignite.IgniteSpringBean
Will get a named queue from cache and create one if it has not been created yet and cfg is not null.
queueLength() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
QueueView - Class in org.apache.ignite.spi.systemview.view.datastructures
Queue representation for a SystemView.
QueueView(GridCacheQueueProxy<?>) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 

R

randomUuid() - Static method in class org.apache.ignite.lang.IgniteUuid
Creates new pseudo-random ID.
rawReader() - Method in interface org.apache.ignite.binary.BinaryReader
Gets raw reader.
rawWriter() - Method in interface org.apache.ignite.binary.BinaryWriter
Gets raw writer.
READ_ONLY_MODE_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
READ_ONLY_MODE_DURATION_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
readAffinityTopologyVersion(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads AffinityTopologyVersion.
readBinary(BinaryReader) - Method in interface org.apache.ignite.binary.Binarylizable
Reads fields from provided reader.
readBinary(Object, BinaryReader) - Method in class org.apache.ignite.binary.BinaryReflectiveSerializer
Reads fields from provided reader.
readBinary(Object, BinaryReader) - Method in interface org.apache.ignite.binary.BinarySerializer
Reads fields from provided reader.
readBinary(BinaryReader) - Method in class org.apache.ignite.lang.IgniteUuid
Reads fields from provided reader.
readBitSet(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads BitSet.
readBoolean() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readBoolean(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readBoolean(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads boolean value.
readBooleanArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readBooleanArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readBooleanArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads boolean array.
readByte() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readByte(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readByte(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads byte value.
readByteArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readByteArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readByteArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads byte array.
readChar() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readChar(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readChar(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads char value.
readCharArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readCharArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readCharArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads char array.
readCollection() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readCollection(BinaryCollectionFactory<T>) - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readCollection(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readCollection(String, BinaryCollectionFactory<T>) - Method in interface org.apache.ignite.binary.BinaryReader
 
readCollection(String, MessageCollectionItemType) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads collection.
readDate() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDate(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDateArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDateArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDecimal() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDecimal(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDecimalArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDecimalArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDouble() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDouble(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDouble(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads double value.
readDoubleArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readDoubleArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readDoubleArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads double array.
readEnum() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readEnum(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readEnumArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readEnumArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
reader(UUID, MessageFactory) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFormatter
Creates new message reader instance.
readExternal(ObjectInput) - Method in class org.apache.ignite.cache.affinity.AffinityKey
readExternal(ObjectInput) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
readExternal(ObjectInput) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
readExternal(ObjectInput) - Method in class org.apache.ignite.IgniteSpringBean
readExternal(ObjectInput) - Method in class org.apache.ignite.lang.IgniteBiTuple
readExternal(ObjectInput) - Method in class org.apache.ignite.lang.IgniteProductVersion
readExternal(ObjectInput) - Method in class org.apache.ignite.lang.IgniteUuid
readExternal(ObjectInput) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
readExternal(ObjectInput) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
readFloat() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readFloat(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readFloat(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads float value.
readFloatArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readFloatArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readFloatArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads float array.
readFrom(ByteBuffer, MessageReader) - Method in interface org.apache.ignite.plugin.extensions.communication.Message
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Reads this message from provided byte buffer.
readFrom(ByteBuffer, MessageReader) - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Reads this message from provided byte buffer.
readIgniteUuid(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads IgniteUuid.
readInt() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readInt(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readInt(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads int value.
readInt(String, int) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads int value.
readIntArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readIntArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readIntArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads int array.
readLong() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readLong(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readLong(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads long value.
readLongArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readLongArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readLongArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads long array.
readMap() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readMap(BinaryMapFactory<K, V>) - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readMap(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readMap(String, BinaryMapFactory<K, V>) - Method in interface org.apache.ignite.binary.BinaryReader
 
readMap(String, MessageCollectionItemType, MessageCollectionItemType, boolean) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads map.
readMessage(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads nested message.
readMessage(Socket, InputStream, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Reads message from the socket limiting read time.
readObject() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readObject(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readObjectArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readObjectArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readObjectArray(String, MessageCollectionItemType, Class<T>) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads array of objects.
ReadOnlyDynamicMBean - Class in org.apache.ignite.spi.metric.jmx
Base class for read only DynamicMBean implementations.
ReadOnlyDynamicMBean() - Constructor for class org.apache.ignite.spi.metric.jmx.ReadOnlyDynamicMBean
 
ReadOnlyMetricManager - Interface in org.apache.ignite.spi.metric
Read only metric manager.
ReadOnlyMetricRegistry - Interface in org.apache.ignite.spi.metric
Read only metric registry.
ReadOnlySystemViewRegistry - Interface in org.apache.ignite.spi.systemview
Read only system view registry.
readReceipt(Socket, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Reads message delivery receipt from the socket.
ReadRepairStrategy - Enum in org.apache.ignite.cache
Read repair strategies.
readShort() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readShort(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readShort(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads short value.
readShortArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readShortArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readShortArray(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads short array.
readString() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readString(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readString(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads String.
readStringArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readStringArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readTime() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readTime(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readTimeArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readTimeArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readTimestamp() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readTimestamp(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readTimestampArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readTimestampArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readUuid() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readUuid(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
readUuid(String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Reads UUID.
readUuidArray() - Method in interface org.apache.ignite.binary.BinaryRawReader
 
readUuidArray(String) - Method in interface org.apache.ignite.binary.BinaryReader
 
rebalance() - Method in interface org.apache.ignite.IgniteCache
Deprecated.
Use baseline topology feature instead. Please, be aware this API will be removed in the next releases.
rebalanceBatchesPrefetchCount() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceBatchSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceDelay() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
rebalanceDelay() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceEnabled(boolean) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Enable or disable cache partition rebalance per node.
rebalanceMode() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
rebalanceMode() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceOrder() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
rebalanceOrder() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceThrottle() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalanceTimeout() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
rebalancingStartTime() - Method in interface org.apache.ignite.cache.CacheMetrics
Deprecated.
receive(UUID, T) - Method in class org.apache.ignite.messaging.MessagingListenActor
This method receives the message.
receive(IgniteCache<K, V>, Collection<Map.Entry<K, V>>) - Method in interface org.apache.ignite.stream.StreamReceiver
Updates cache with batch of entries.
receive(IgniteCache<K, V>, Collection<Map.Entry<K, V>>) - Method in class org.apache.ignite.stream.StreamTransformer
Updates cache with batch of entries.
receive(IgniteCache<K, V>, Collection<Map.Entry<K, V>>) - Method in class org.apache.ignite.stream.StreamVisitor
Updates cache with batch of entries.
received() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
 
received() - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
 
RECEIVED_MESSAGES_BY_NODE_CONSISTENT_ID_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages by node consistent id metric description.
RECEIVED_MESSAGES_BY_NODE_CONSISTENT_ID_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages by node consistent id metric name.
RECEIVED_MESSAGES_BY_TYPE_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages by type metric description.
RECEIVED_MESSAGES_BY_TYPE_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages by type metric name.
RECEIVED_MESSAGES_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages metric description.
RECEIVED_MESSAGES_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Received messages metric name.
receivedBytesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets received bytes count.
receivedBytesCount() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
receiveDiscoveryData(UUID, Serializable) - Method in interface org.apache.ignite.plugin.PluginProvider
Receives plugin discovery data object from remote nodes (called on new node during discovery process).
receivedMessagesByNode() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets received messages counts (grouped by node).
receivedMessagesByType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets received messages counts (grouped by type).
receivedMessagesByTypeMetricName(Short) - Static method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Generate metric name by message direct type id.
receivedMessagesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets received messages count.
receivedMessagesCount() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
receiver(StreamReceiver<K, V>) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets custom stream receiver to this data streamer.
reconnectFuture() - Method in exception org.apache.ignite.IgniteClientDisconnectedException
 
record(Event) - Method in interface org.apache.ignite.spi.eventstorage.EventStorageSpi
Records single event.
record(Event) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Records single event.
record(Event) - Method in class org.apache.ignite.spi.eventstorage.NoopEventStorageSpi
Records single event.
recordEvent(Event) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Records local event.
recordLocal(Event) - Method in interface org.apache.ignite.IgniteEvents
Records customer user generated event.
RecordSizeCountStat - Class in org.apache.ignite.development.utils
Statistic for record size, used to accumulate information about several record and calculating average.
RecordSizeCountStat() - Constructor for class org.apache.ignite.development.utils.RecordSizeCountStat
 
RECOVERY_LAST_ID_MSG_TYPE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Recovery last received ID message type.
RecoveryLastReceivedMessage - Class in org.apache.ignite.spi.communication.tcp.messages
Recovery acknowledgment message.
RecoveryLastReceivedMessage() - Constructor for class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Default constructor required by Message.
RecoveryLastReceivedMessage(long) - Constructor for class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
 
reduce(List<ComputeJobResult>) - Method in interface org.apache.ignite.compute.ComputeTask
Reduces (or aggregates) results received so far into one compound result to be returned to caller via ComputeTaskFuture.get() method.
reduce() - Method in interface org.apache.ignite.lang.IgniteReducer
Reduces collected values into one.
reentrantLock(String, boolean, boolean, boolean) - Method in interface org.apache.ignite.Ignite
Gets or creates reentrant lock.
reentrantLock(String, boolean, boolean, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Gets or creates reentrant lock.
ReentrantLockView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteLock representation for a SystemView.
ReentrantLockView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.ReentrantLockView
 
refreshJobSiblings() - Method in interface org.apache.ignite.compute.ComputeTaskSession
Refreshes collection of job siblings.
RegexpMetricFilter - Class in org.apache.ignite.spi.metric
Metric registry filter based on regular expression.
RegexpMetricFilter(String) - Constructor for class org.apache.ignite.spi.metric.RegexpMetricFilter
 
register() - Static method in class org.apache.ignite.IgniteJdbcThinDriver
 
register(short, Supplier<Message>) - Method in interface org.apache.ignite.plugin.extensions.communication.IgniteMessageFactory
Register message factory with given direct type.
register(ClassLoader, Class<?>) - Method in interface org.apache.ignite.spi.deployment.DeploymentSpi
Registers a class loader with this SPI.
register(ClassLoader, Class<?>) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Registers a class loader with this SPI.
register(ClassLoader, Class<?>) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Registers a class loader with this SPI.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Registers new addresses.
registerAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Registers new addresses.
registerAll(IgniteMessageFactory) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFactoryProvider
Registers all messages factories.
registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in interface org.apache.ignite.client.ClientCache
Registers a CacheEntryListener.
registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>, ClientDisconnectListener) - Method in interface org.apache.ignite.client.ClientCache
Registers a CacheEntryListener.
registerClass(Class<?>) - Method in interface org.apache.ignite.IgniteBinary
Register binary type for specified class.
registerClassName(byte, int, String, boolean) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Method to register typeId->class name mapping in marshaller context cluster-wide.
registerClassName(byte, int, String) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Deprecated.
Use MarshallerContext.registerClassName(byte, int, java.lang.String, boolean) instead. This particular method will be deleted in future releases.
registerClassNameLocally(byte, int, String) - Method in interface org.apache.ignite.marshaller.MarshallerContext
Method to register typeId->class name mapping in marshaller context on local node only.
registeredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Gets addresses registered in the IP finder, initializes addresses having no port (or 0 port) with TcpDiscoverySpi.DFLT_PORT.
registerEnum(String, Map<String, Integer>) - Method in interface org.apache.ignite.IgniteBinary
Register enum type.
registerExtension(Class<T>, T) - Method in interface org.apache.ignite.plugin.ExtensionRegistry
Registers extension provided by plugin.
registerMaintenanceTask(MaintenanceTask) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Method to register MaintenanceTask locally on the node where method is called.
registerMaintenanceTask(MaintenanceTask, UnaryOperator<MaintenanceTask>) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Method to register MaintenanceTask locally on the node where method is called.
registerMBean(String, T, Class<T>) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Registers SPI MBean.
registerMetrics(MetricRegistry) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
Register thread pool metrics.
registerMetrics(MetricRegistry) - Method in class org.apache.ignite.thread.IgniteThreadPoolExecutor
Register thread pool metrics.
registerPort(int, IgnitePortProtocol, Class<?>) - Method in interface org.apache.ignite.plugin.PluginContext
Registers open port.
registerPort(int, IgnitePortProtocol) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Registers open port.
registerWorkflowCallback(String, MaintenanceWorkflowCallback) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Registers MaintenanceWorkflowCallback for a MaintenanceTask with a given name.
registerWorkflowCallbackIfTaskExists(String, IgniteThrowableFunction<MaintenanceTask, MaintenanceWorkflowCallback>) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Call the MaintenanceRegistry.registerWorkflowCallback(String, MaintenanceWorkflowCallback) if the active maintenance task with given name exists.
release() - Method in interface org.apache.ignite.IgniteSemaphore
Releases a permit, returning it to the semaphore.
release(int) - Method in interface org.apache.ignite.IgniteSemaphore
Releases the given number of permits, returning them to the semaphore.
releaseDate() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets release date.
remoteAddress() - Method in class org.apache.ignite.client.events.ConnectionDescription
Gets address of remote peer of this connection.
remoteAddress() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
remoteFilter() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
remoteListen(IgniteBiPredicate<UUID, T>, IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Adds event listener for specified events to all nodes in the cluster group (possibly including local node if it belongs to the cluster group as well).
remoteListen(int, long, boolean, IgniteBiPredicate<UUID, T>, IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Adds event listener for specified events to all nodes in the cluster group (possibly including local node if it belongs to the cluster group as well).
remoteListen(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.IgniteMessaging
Adds a message listener for a given topic to all nodes in the cluster group (possibly including this node if it belongs to the cluster group as well).
remoteListenAsync(IgniteBiPredicate<UUID, T>, IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Asynchronously adds event listener for specified events to all nodes in the cluster group (possibly including local node if it belongs to the cluster group as well).
remoteListenAsync(int, long, boolean, IgniteBiPredicate<UUID, T>, IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Asynchronously adds event listener for specified events to all nodes in the cluster group (possibly including local node if it belongs to the cluster group as well).
remoteListenAsync(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.IgniteMessaging
Asynchronously adds a message listener for a given topic to all nodes in the cluster group (possibly including this node if it belongs to the cluster group as well).
remoteMessage() - Method in exception org.apache.ignite.plugin.PluginValidationException
 
remoteNodes() - Method in interface org.apache.ignite.spi.IgniteSpiContext
Gets a collection of remote grid nodes.
remoteQuery(IgnitePredicate<T>, long, int...) - Method in interface org.apache.ignite.IgniteEvents
Queries nodes in this cluster group for events using passed in predicate filter for event selection.
remoteQueryAsync(IgnitePredicate<T>, long, int...) - Method in interface org.apache.ignite.IgniteEvents
Asynchronously queries nodes in this cluster group for events using passed in predicate filter for event selection.
remoteTransformer() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
remove(K) - Method in interface org.apache.ignite.client.ClientCache
Removes the mapping for a key from this cache if it is present.
remove(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically removes the mapping for a key only if currently mapped to the given value.
remove(Object) - Method in interface org.apache.ignite.client.ClientIgniteSet
remove(K) - Method in interface org.apache.ignite.IgniteCache
remove(K, V) - Method in interface org.apache.ignite.IgniteCache
For CacheAtomicityMode.ATOMIC return value on primary node crash may be incorrect because of the automatic retries.
remove(Object) - Method in interface org.apache.ignite.IgniteQueue
remove(Object) - Method in interface org.apache.ignite.IgniteSet
remove(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
remove(String, K) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Removes object from cache.
remove(String, Object) - Method in interface org.apache.ignite.spi.indexing.IndexingSpi
Removes index entry by key.
remove(String, Object) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
Removes index entry by key.
removeAll(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Removes entries for the specified keys.
removeAll() - Method in interface org.apache.ignite.client.ClientCache
Removes all of the mappings from this cache.
removeAll(Collection<?>) - Method in interface org.apache.ignite.client.ClientIgniteSet
removeAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Keys are locked in the order in which they appear in key set.
removeAll() - Method in interface org.apache.ignite.IgniteCache
Removes all of the mappings from this cache.
removeAll(Collection<?>) - Method in interface org.apache.ignite.IgniteQueue
removeAll(Collection<?>) - Method in interface org.apache.ignite.IgniteSet
removeAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.client.ClientCache
Removes entries for the specified keys.
removeAllAsync() - Method in interface org.apache.ignite.client.ClientCache
Removes all of the mappings from this cache.
removeAllAsync(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
Asynchronously removes entries for the specified keys.
removeAllAsync() - Method in interface org.apache.ignite.IgniteCache
Asynchronously removes all of the mappings from this cache.
removeAsync(K) - Method in interface org.apache.ignite.client.ClientCache
Removes the mapping for a key from this cache if it is present.
removeAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically removes the mapping for a key only if currently mapped to the given value.
removeAsync(K) - Method in interface org.apache.ignite.IgniteCache
Asynchronously removes the mapping for a key from this cache if it is present.
removeAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously removes the mapping for a key only if currently mapped to the given value.
removeAttributeListener(ComputeTaskSessionAttributeListener) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Removes given listener.
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
removeCheckpoint(String) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Removes previously saved job's state for a given key from an underlying storage.
removeCheckpoint(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
This method allows manually remove the checkpoint with given key.
removeCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
This method instructs the checkpoint provider to clean saved data for a given key.
removeCheckpoint(String) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointSpi
This method instructs the checkpoint provider to clean saved data for a given key.
removeCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
This method instructs the checkpoint provider to clean saved data for a given key.
removeCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
This method instructs the checkpoint provider to clean saved data for a given key.
removeCheckpoint(String) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
This method instructs the checkpoint provider to clean saved data for a given key.
removeClosedManager(CacheManager) - Method in class org.apache.ignite.cache.CachingProvider
 
removed() - Method in interface org.apache.ignite.client.ClientAtomicLong
Gets status of atomic.
removed() - Method in interface org.apache.ignite.client.ClientIgniteSet
Gets a value indicating whether this set has been removed (ClientIgniteSet.close() was called).
removed() - Method in interface org.apache.ignite.IgniteAtomicLong
Gets status of atomic.
removed() - Method in interface org.apache.ignite.IgniteAtomicReference
Gets status of atomic.
removed() - Method in interface org.apache.ignite.IgniteAtomicSequence
Gets status of atomic sequence.
removed() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets status of atomic.
removed() - Method in interface org.apache.ignite.IgniteCountDownLatch
Gets removed status of the latch.
removed() - Method in interface org.apache.ignite.IgniteLock
Gets status of reentrant lock.
removed() - Method in interface org.apache.ignite.IgniteQueue
Gets status of queue.
removed() - Method in interface org.apache.ignite.IgniteSemaphore
Gets removed status of the semaphore.
removed() - Method in interface org.apache.ignite.IgniteSet
Gets status of set.
removed() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
removed() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
removeData(K) - Method in interface org.apache.ignite.IgniteDataStreamer
Adds key for removal on remote node.
removeField(String) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Removes field from this builder.
removeIncomeConnectionListener(IgniteInClosure<Socket>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
removeListener(IgnitionListener) - Static method in class org.apache.ignite.Ignition
Removes lsnr added by Ignition.addListener(IgnitionListener) method.
removeLocalEventListener(GridLocalEventListener) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Removes local event listener.
removeLocalMessageListener(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Removes a previously registered local message listener.
removeMessageListener(GridMessageListener, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
removeMeta(Object) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
 
removeMeta() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Removes metadata by name.
removeMeta(T) - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Removes metadata only if its current value is equal to val passed in.
removeMeta(Object) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
removeMeta(Object) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
removeMeta(Object) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Removes holder from backed queue and marks holder as removed.
removeMetricRegistry(String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Removes metric registry with given name.
removeNode(UUID) - Method in interface org.apache.ignite.cache.affinity.AffinityFunction
Removes node from affinity.
removeNode(UUID) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Removes node from affinity.
removeNode(UUID) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Removes node from affinity.
removeQuery(String, Iterable<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct remove query.
removeQuery(String, Iterable<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct remove query.
removeSendMessageListener(IgniteInClosure<TcpDiscoveryAbstractMessage>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
removeTimeoutObject(IgniteSpiTimeoutObject) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
 
removeTimeoutObject(IgniteSpiTimeoutObject) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
RendezvousAffinityFunction - Class in org.apache.ignite.cache.affinity.rendezvous
Affinity function for partitioned cache based on Highest Random Weight algorithm.
RendezvousAffinityFunction() - Constructor for class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Empty constructor with all defaults.
RendezvousAffinityFunction(boolean) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Initializes affinity with flag to exclude same-host-neighbors from being backups of each other and specified number of backups.
RendezvousAffinityFunction(boolean, int) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Initializes affinity with flag to exclude same-host-neighbors from being backups of each other, and specified number of backups and partitions.
RendezvousAffinityFunction(int, IgniteBiPredicate<ClusterNode, ClusterNode>) - Constructor for class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Initializes optional counts for replicas and backups.
repeat(String, int, String, String, String) - Static method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Concatenates elements using provided delimiter.
replace(K, V, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the entry for a key only if currently mapped to a given value.
replace(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the entry for a key only if currently mapped to some value.
replace(K, V, V) - Method in interface org.apache.ignite.IgniteCache
For CacheAtomicityMode.ATOMIC return value on primary node crash may be incorrect because of the automatic retries.
replace(K, V) - Method in interface org.apache.ignite.IgniteCache
replaceAsync(K, V, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the entry for a key only if currently mapped to a given value.
replaceAsync(K, V) - Method in interface org.apache.ignite.client.ClientCache
Atomically replaces the entry for a key only if currently mapped to some value.
replaceAsync(K, V, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronous version of the IgniteCache.replace(Object, Object, Object).
replaceAsync(K, V) - Method in interface org.apache.ignite.IgniteCache
Asynchronously replaces the entry for a key only if currently mapped to a given value.
replaceMeta(T, T) - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Replaces given metadata with new newVal value only if its current value is equal to curVal.
requestedTask(String) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
 
RequestEvent - Class in org.apache.ignite.client.events
 
RequestEvent(ConnectionDescription, long, short, String) - Constructor for class org.apache.ignite.client.events.RequestEvent
 
RequestEventListener - Interface in org.apache.ignite.client.events
 
RequestFailEvent - Class in org.apache.ignite.client.events
 
RequestFailEvent(ConnectionDescription, long, short, String, long, Throwable) - Constructor for class org.apache.ignite.client.events.RequestFailEvent
 
requestId() - Method in class org.apache.ignite.client.events.RequestEvent
 
RequestStartEvent - Class in org.apache.ignite.client.events
 
RequestStartEvent(ConnectionDescription, long, short, String) - Constructor for class org.apache.ignite.client.events.RequestStartEvent
 
RequestSuccessEvent - Class in org.apache.ignite.client.events
 
RequestSuccessEvent(ConnectionDescription, long, short, String, long) - Constructor for class org.apache.ignite.client.events.RequestSuccessEvent
 
reset() - Method in interface org.apache.ignite.cache.affinity.AffinityFunction
Resets cache affinity to its initial state.
reset() - Method in interface org.apache.ignite.cache.affinity.AffinityKeyMapper
Deprecated.
Resets cache affinity mapper to its initial state.
reset() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Resets cache affinity to its initial state.
reset() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Resets cache affinity to its initial state.
reset() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Resets this reader.
reset() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Resets this writer.
reset() - Method in interface org.apache.ignite.spi.metric.Metric
Resets metric state.
reset(TracingConfigurationCoordinates) - Method in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Reset tracing configuration for the specific tracing coordinates (scope, label, etc.) to default values.
resetAll(Scope) - Method in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Reset tracing configuration for the specific scope, or all tracing configurations if scope not specified.
resetLostPartitions(Collection<String>) - Method in interface org.apache.ignite.Ignite
Clears partition's lost state and moves caches to a normal mode.
resetLostPartitions(Collection<String>) - Method in class org.apache.ignite.IgniteSpringBean
Clears partition's lost state and moves caches to a normal mode.
resetMetrics() - Method in interface org.apache.ignite.IgniteCluster
Resets local I/O, job, and task execution metrics.
resetMetrics() - Method in interface org.apache.ignite.IgniteTransactions
Resets transaction metrics.
resetMetrics(String) - Method in interface org.apache.ignite.mxbean.MetricsMxBean
Deprecated.
Resets metrics for of a given registry.
resetMetrics() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Resets metrics for this SPI instance.
resetMetrics() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Resets metrics for this instance.
resetMetrics() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Resets metrics for this SPI instance.
resetQueryDetailMetrics() - Method in interface org.apache.ignite.IgniteCache
Reset query detail metrics.
resetQueryMetrics() - Method in interface org.apache.ignite.IgniteCache
Reset query metrics.
resetThreadedQueryInitiatorId() - Static method in class org.apache.ignite.cache.query.SqlFieldsQuery
Used at the job worker to clear originator for current thread.
resolve(CommunicationFailureContext) - Method in interface org.apache.ignite.configuration.CommunicationFailureResolver
 
resolve(CommunicationFailureContext) - Method in class org.apache.ignite.configuration.DefaultCommunicationFailureResolver
resolveCommunicationFailure(ClusterNode, Exception) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
resolveCommunicationFailure(ClusterNode, Exception) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
resolveCommunicationFailure(ClusterNode, Exception) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
resolveCommunicationFailure(ClusterNode, Exception) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
resolvedAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Resolves addresses registered in the IP finder, removes duplicates and local host address and returns the collection of.
resolveDialect() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Perform dialect resolution.
resolveNodeHash(ClusterNode) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Resolves node hash.
respond(Object) - Method in class org.apache.ignite.messaging.MessagingListenActor
Responds to the original sender node with given message and continues to listen for the new messages.
respond(UUID, Object) - Method in class org.apache.ignite.messaging.MessagingListenActor
Responds to the provided node with given message and continues to listen for the new messages.
restart(boolean) - Static method in class org.apache.ignite.Ignition
Restarts all started grids.
restart(boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Restart JVM.
RESTART_EXIT_CODE - Static variable in class org.apache.ignite.Ignition
This is restart code that can be used by external tools, like Shell scripts, to auto-restart the Ignite JVM process.
restartFuture() - Method in exception org.apache.ignite.IgniteCacheRestartingException
 
restartNodes() - Method in interface org.apache.ignite.IgniteCluster
Restarts nodes satisfying optional set of predicates.
restartNodes(Collection<UUID>) - Method in interface org.apache.ignite.IgniteCluster
Restarts nodes defined by provided IDs.
RestartProcessFailureHandler - Class in org.apache.ignite.failure
This handler could be used only with ignite.
RestartProcessFailureHandler() - Constructor for class org.apache.ignite.failure.RestartProcessFailureHandler
 
restoreSnapshot(String, Collection<String>) - Method in interface org.apache.ignite.IgniteSnapshot
Restore cache group(s) from the snapshot.
restoreSnapshot(String, Collection<String>, int) - Method in interface org.apache.ignite.IgniteSnapshot
Restore cache group(s) from the snapshot and its increments.
restoreSnapshot(String, String, String) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
Deprecated.
Restore cluster-wide snapshot.
restoreSnapshot(String, String, String, int) - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
Deprecated.
Restore cluster-wide snapshot and its increments.
result(ComputeJobResult, List<ComputeJobResult>) - Method in interface org.apache.ignite.compute.ComputeTask
Asynchronous callback invoked every time a result from remote execution is received.
result(ComputeJobResult, List<ComputeJobResult>) - Method in class org.apache.ignite.compute.ComputeTaskAdapter
Default implementation which will wait for all jobs to complete before calling ComputeTask.reduce(List) method.
resultPolicy() - Method in class org.apache.ignite.events.JobEvent
Gets job result policy.
resultPolicy(ComputeJobResultPolicy) - Method in class org.apache.ignite.events.JobEvent
Sets job result policy.
resume() - Method in interface org.apache.ignite.transactions.Transaction
Resume a transaction if it was previously suspended.
retainAll(Collection<?>) - Method in interface org.apache.ignite.client.ClientIgniteSet
retainAll(Collection<?>) - Method in interface org.apache.ignite.IgniteQueue
retainAll(Collection<?>) - Method in interface org.apache.ignite.IgniteSet
retryReadyFuture() - Method in exception org.apache.ignite.cluster.ClusterTopologyException
 
retryReadyFuture(IgniteFuture<?>) - Method in exception org.apache.ignite.cluster.ClusterTopologyException
 
REV_HASH_SIZE - Static variable in class org.apache.ignite.lang.IgniteProductVersion
revisionHash() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets revision hash.
revisionTimestamp() - Method in class org.apache.ignite.lang.IgniteProductVersion
Gets revision timestamp.
rollback() - Method in interface org.apache.ignite.client.ClientTransaction
Rolls back this transaction.
rollback() - Method in interface org.apache.ignite.transactions.Transaction
Rolls back this transaction.
rollbackAsync() - Method in interface org.apache.ignite.transactions.Transaction
Asynchronously rolls back this transaction.
rollbackTime() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The last time, when transaction was rollbacked.
rollbackTime() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets last time transaction was rollback.
rotate() - Method in interface org.apache.ignite.mxbean.PerformanceStatisticsMBean
Deprecated.
Rotate performance statistics in the cluster.
RoundRobinLoadBalancingSpi - Class in org.apache.ignite.spi.loadbalancing.roundrobin
This SPI iterates through nodes in round-robin fashion and pick the next sequential node.
RoundRobinLoadBalancingSpi() - Constructor for class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
 
RoundRobinLoadBalancingSpiMBean - Interface in org.apache.ignite.spi.loadbalancing.roundrobin
Management bean for RoundRobinLoadBalancingSpi SPI.
routineId() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
row() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets read results set row.
run() - Method in class org.apache.ignite.dump.DumpReader
run(IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes provided job on a node within the underlying cluster group.
run(Collection<? extends IgniteRunnable>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs on grid nodes within the underlying cluster group.
run() - Method in class org.apache.ignite.spi.IgniteSpiThread
runAsync(IgniteRunnable) - Method in interface org.apache.ignite.IgniteCompute
Executes provided job asynchronously on a node within the underlying cluster group.
runAsync(Collection<? extends IgniteRunnable>) - Method in interface org.apache.ignite.IgniteCompute
Executes collection of jobs asynchronously on grid nodes within the underlying cluster group.
runIoTest(long, long, int, long, int, int, boolean) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Runs IO latency test against all remote server nodes in cluster.
runLocal(Runnable) - Method in interface org.apache.ignite.IgniteScheduler
Executes given closure on internal system thread pool asynchronously.
runLocal(Runnable, long, TimeUnit) - Method in interface org.apache.ignite.IgniteScheduler
Executes given closure after the delay.

S

SameThreadExecutor - Class in org.apache.ignite.thread
 
SAMPLING_RATE_ALWAYS - Static variable in class org.apache.ignite.spi.tracing.TracingConfigurationParameters
Max valid sampling rate with special meaning that span will be always created.
SAMPLING_RATE_NEVER - Static variable in class org.apache.ignite.spi.tracing.TracingConfigurationParameters
Min valid sampling rate with special meaning that span won't be created.
samplingRate() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters
 
sandboxPermissions() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Deprecated.
SecuritySubject must contain only immutable set of information that represents a security principal. Security permissions are part of authorization process and have nothing to do with SecuritySubject. This method will be removed in the future releases.
saveCheckpoint(String, Object) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Saves intermediate state of a job or task to a storage.
saveCheckpoint(String, Object, ComputeTaskSessionScope, long) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Saves intermediate state of a job to a storage.
saveCheckpoint(String, Object, ComputeTaskSessionScope, long, boolean) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Saves intermediate state of a job or task to a storage.
saveCheckpoint(String, byte[], long, boolean) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Saves checkpoint to the storage.
saveCheckpoint(String, byte[], long, boolean) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointSpi
Saves checkpoint to the storage.
saveCheckpoint(String, byte[], long, boolean) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Saves checkpoint to the storage.
saveCheckpoint(String, byte[], long, boolean) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
Saves checkpoint to the storage.
saveCheckpoint(String, byte[], long, boolean) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Saves checkpoint to the storage.
scale() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
scale() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewColumnView
 
ScanQuery<K,V> - Class in org.apache.ignite.cache.query
Scan query over cache entries.
ScanQuery() - Constructor for class org.apache.ignite.cache.query.ScanQuery
Create scan query returning all entries.
ScanQuery(int) - Constructor for class org.apache.ignite.cache.query.ScanQuery
Creates partition scan query returning all entries for given partition.
ScanQuery(IgniteBiPredicate<K, V>) - Constructor for class org.apache.ignite.cache.query.ScanQuery
Create scan query with filter.
ScanQuery(Integer, IgniteBiPredicate<K, V>) - Constructor for class org.apache.ignite.cache.query.ScanQuery
Create scan query with filter.
scanQueryFilter() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets scan query filter.
scanQueryFilter() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets scan query filter.
ScanQueryView - Class in org.apache.ignite.spi.systemview.view
Scan query iterator representation for a SystemView.
ScanQueryView(UUID, long, boolean, IgniteSpiCloseableIterator<IgniteBiTuple<K, V>>) - Constructor for class org.apache.ignite.spi.systemview.view.ScanQueryView
 
schedule(String) - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Deprecated.
Schedule defragmentation for given caches.
scheduleLocal(Runnable, String) - Method in interface org.apache.ignite.IgniteScheduler
Schedules job for execution using local cron-based scheduling.
scheduleLocal(Callable<R>, String) - Method in interface org.apache.ignite.IgniteScheduler
Schedules job for execution using local cron-based scheduling.
scheduler() - Method in interface org.apache.ignite.Ignite
Gets an instance of cron-based scheduler.
scheduler() - Method in class org.apache.ignite.IgniteSpringBean
Gets an instance of cron-based scheduler.
SchedulerFuture<R> - Interface in org.apache.ignite.scheduler
Future for cron-based scheduled execution.
schema() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewView
 
schemaName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns schema name.
schemaName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlSchemaView
 
schemaName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
schemaName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns schema name.
schemaName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewColumnView
 
schemaName() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
schemaName() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
schemasIds() - Method in class org.apache.ignite.spi.systemview.view.BinaryMetadataView
 
Scope - Enum in org.apache.ignite.spi.tracing
Tracing span scope.
scope() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates
 
searchHistogram(String, ReadOnlyMetricRegistry) - Static method in class org.apache.ignite.spi.metric.jmx.MetricRegistryMBean
Parse attribute name for a histogram and search it's value.
SecurityBasicPermissionSet - Class in org.apache.ignite.plugin.security
Simple implementation of SecurityPermissionSet interface.
SecurityBasicPermissionSet() - Constructor for class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
 
SecurityCredentials - Class in org.apache.ignite.plugin.security
Security credentials used for node authentication.
SecurityCredentials() - Constructor for class org.apache.ignite.plugin.security.SecurityCredentials
Empty constructor required by Externalizable.
SecurityCredentials(String, String) - Constructor for class org.apache.ignite.plugin.security.SecurityCredentials
Constructs security credentials based on login and password.
SecurityCredentials(String, String, Object) - Constructor for class org.apache.ignite.plugin.security.SecurityCredentials
Constructs security credentials based on login, password, and custom user object.
SecurityCredentialsBasicProvider - Class in org.apache.ignite.plugin.security
Basic implementation for SecurityCredentialsProvider.
SecurityCredentialsBasicProvider(SecurityCredentials) - Constructor for class org.apache.ignite.plugin.security.SecurityCredentialsBasicProvider
Constructs security credentials provider based on security credentials passed in.
SecurityCredentialsProvider - Interface in org.apache.ignite.plugin.security
Security credentials provider for specifying security credentials.
SecurityException - Exception in org.apache.ignite.plugin.security
Common security exception for the grid.
SecurityException(String, Throwable) - Constructor for exception org.apache.ignite.plugin.security.SecurityException
Constructs security grid exception with given message and cause.
SecurityException(Throwable) - Constructor for exception org.apache.ignite.plugin.security.SecurityException
Creates new security grid exception given throwable as a cause and source of error message.
SecurityException(String) - Constructor for exception org.apache.ignite.plugin.security.SecurityException
Constructs security grid exception with given message.
SecurityPermission - Enum in org.apache.ignite.plugin.security
Supported security permissions within grid.
SecurityPermissionSet - Interface in org.apache.ignite.plugin.security
Security permission set for authorized security subjects.
SecurityPermissionSetBuilder - Class in org.apache.ignite.plugin.security
Provides a convenient way to create a permission set.
SecurityPermissionSetBuilder() - Constructor for class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
 
SecuritySubject - Interface in org.apache.ignite.plugin.security
Security subject representing authenticated node with a set of permissions.
SecuritySubjectType - Enum in org.apache.ignite.plugin.security
Supported security subject types.
SegmentationPolicy - Enum in org.apache.ignite.plugin.segmentation
Policy that defines how node will react on topology segmentation.
SegmentationResolver - Interface in org.apache.ignite.plugin.segmentation
This is interface for segmentation (a.k.a "split-brain" problem) resolvers.
semaphore(String, int, boolean, boolean) - Method in interface org.apache.ignite.Ignite
Gets or creates semaphore.
semaphore(String, int, boolean, boolean) - Method in class org.apache.ignite.IgniteSpringBean
Gets or creates semaphore.
SemaphoreView - Class in org.apache.ignite.spi.systemview.view.datastructures
IgniteSemaphore representation for a SystemView.
SemaphoreView(GridCacheRemovable) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.SemaphoreView
 
send(ComputeJob, ClusterNode) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
Sends given job to a specific grid node.
send(Map<? extends ComputeJob, ClusterNode>) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
Sends collection of grid jobs to assigned nodes.
send(ComputeJob) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
Sends job to a node automatically picked by the underlying load balancer.
send(Collection<? extends ComputeJob>) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
Sends collection of jobs to nodes automatically picked by the underlying load balancer.
send(Object, Object) - Method in interface org.apache.ignite.IgniteMessaging
Sends given message with specified topic to the nodes in the underlying cluster group.
send(Object, Collection<?>) - Method in interface org.apache.ignite.IgniteMessaging
Sends given messages with the specified topic to the nodes in the underlying cluster group.
send(ClusterNode, Serializable, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Sends a message to a remote node.
sendCustomEvent(DiscoverySpiCustomMessage) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Sends custom message across the ring.
sendCustomEvent(DiscoverySpiCustomMessage) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sends custom message across the ring.
sendCustomEvent(DiscoverySpiCustomMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sends custom message across the ring.
sendCustomEvent(DiscoverySpiCustomMessage) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sends custom message across the ring.
sendMessage(ClusterNode, T) - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Sends given message to destination node.
sendMessage(ClusterNode, Message) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sends given message to destination node.
sendMessage(ClusterNode, Message, IgniteInClosure<IgniteException>) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sends given message to destination node.
sendMessage() - Method in class org.apache.ignite.spi.IgniteNodeValidationResult
 
sendOrdered(Object, Object, long) - Method in interface org.apache.ignite.IgniteMessaging
Sends given message with specified topic to the nodes in the underlying cluster group.
sendServerExceptionStackTraceToClient() - Method in class org.apache.ignite.configuration.ThinClientConfiguration
 
sendServerExceptionStackTraceToClient(boolean) - Method in class org.apache.ignite.configuration.ThinClientConfiguration
SENT_MESSAGES_BY_NODE_CONSISTENT_ID_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages by node consistent id metric description.
SENT_MESSAGES_BY_NODE_CONSISTENT_ID_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages by node consistent id metric name.
SENT_MESSAGES_BY_TYPE_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages by type metric description.
SENT_MESSAGES_BY_TYPE_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages by type metric name.
SENT_MESSAGES_METRIC_DESC - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages metric description.
SENT_MESSAGES_METRIC_NAME - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Sent messages metric name.
sentBytesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets sent bytes count.
sentBytesCount() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
sentMessagesByNode() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets sent messages counts (grouped by node).
sentMessagesByType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets sent messages counts (grouped by type).
sentMessagesByTypeMetricName(Short) - Static method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Generate metric name by message direct type id.
sentMessagesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
Gets sent messages count.
sentMessagesCount() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
serialize(NoopSpiSpecificSpan) - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
Serializes span to byte array to send context over network.
serialize(OpenCensusSpanAdapter) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
Serializes span to byte array to send context over network.
serialize(S) - Method in interface org.apache.ignite.spi.tracing.TracingSpi
Serializes span to byte array to send context over network.
SerializeSeparately - Annotation Type in org.apache.ignite.configuration
This annotation is needed to mark fields of CacheConfiguration to serialize them separately during sending over network or storing to disk.
serverKeepBinary(boolean) - Method in interface org.apache.ignite.client.ClientIgniteSet
Sets a value indicating whether user objects should be kept in binary form on the server, or deserialized.
serverKeepBinary() - Method in interface org.apache.ignite.client.ClientIgniteSet
Gets a value indicating whether user objects should be kept in binary form on the server, or deserialized.
serverNodeId() - Method in class org.apache.ignite.client.events.ConnectionDescription
 
service(String) - Method in interface org.apache.ignite.IgniteServices
Deprecated.
Use the proxies like IgniteServices.serviceProxy(String, Class, boolean). References to local services corrupt the service statistics and bring no real performance optimization.
Service - Interface in org.apache.ignite.services
An instance of grid-managed service.
ServiceCallContext - Interface in org.apache.ignite.services
Service call context.
ServiceCallContextBuilder - Class in org.apache.ignite.services
Service call context builder.
ServiceCallContextBuilder() - Constructor for class org.apache.ignite.services.ServiceCallContextBuilder
 
ServiceCallInterceptor - Interface in org.apache.ignite.services
Service call interceptor.
serviceClass() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets service class.
serviceClass() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets service class.
serviceClass() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
ServiceConfiguration - Class in org.apache.ignite.services
Managed service configuration.
ServiceConfiguration() - Constructor for class org.apache.ignite.services.ServiceConfiguration
 
ServiceContext - Interface in org.apache.ignite.services
Service execution context.
ServiceContextResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injecting a service context into a service instance.
ServiceDeploymentException - Exception in org.apache.ignite.services
Exception indicating service deployment failure.
ServiceDeploymentException(String, Collection<ServiceConfiguration>) - Constructor for exception org.apache.ignite.services.ServiceDeploymentException
Creates service deployment exception with error message.
ServiceDeploymentException(Throwable, Collection<ServiceConfiguration>) - Constructor for exception org.apache.ignite.services.ServiceDeploymentException
Creates service deployment exception with Throwable as a cause.
ServiceDeploymentException(String, Throwable, Collection<ServiceConfiguration>) - Constructor for exception org.apache.ignite.services.ServiceDeploymentException
Creates service deployment exception with error message and Throwable as a cause.
serviceDescriptor(String) - Method in interface org.apache.ignite.client.ClientServices
Gets metadata about deployed services in the grid.
ServiceDescriptor - Interface in org.apache.ignite.services
Service deployment descriptor.
serviceDescriptors() - Method in interface org.apache.ignite.client.ClientServices
Gets metadata about all deployed services in the grid.
serviceDescriptors() - Method in interface org.apache.ignite.IgniteServices
Gets metadata about all deployed services in the grid.
serviceId() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
ServiceMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use managements API beans, instead.
servicePermissions() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Map of service names to service permissions.
servicePermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Map of service names to service permissions.
serviceProxy(String, Class<? super T>) - Method in interface org.apache.ignite.client.ClientServices
Gets a remote handle on the service.
serviceProxy(String, Class<? super T>, long) - Method in interface org.apache.ignite.client.ClientServices
Gets a remote handle on the service with timeout.
serviceProxy(String, Class<? super T>, ServiceCallContext) - Method in interface org.apache.ignite.client.ClientServices
Gets a remote handle on the service with the specified caller context.
serviceProxy(String, Class<? super T>, ServiceCallContext, long) - Method in interface org.apache.ignite.client.ClientServices
Gets a remote handle on the service with the specified caller context and timeout.
serviceProxy(String, Class<? super T>, boolean) - Method in interface org.apache.ignite.IgniteServices
Gets a handle on remote or local service.
serviceProxy(String, Class<? super T>, boolean, long) - Method in interface org.apache.ignite.IgniteServices
Gets a handle on remote or local service with the timeout.
serviceProxy(String, Class<? super T>, boolean, ServiceCallContext) - Method in interface org.apache.ignite.IgniteServices
Gets a handle on remote or local service with the specified caller context.
serviceProxy(String, Class<? super T>, boolean, ServiceCallContext, long) - Method in interface org.apache.ignite.IgniteServices
Gets a handle on remote or local service with the specified caller context and the timeout.
ServiceResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of Ignite service(s) by specified service name.
services() - Method in interface org.apache.ignite.client.IgniteClient
Gets services facade over all cluster nodes started in server mode.
services(ClientClusterGroup) - Method in interface org.apache.ignite.client.IgniteClient
Gets services facade over nodes within the cluster group.
services() - Method in interface org.apache.ignite.Ignite
Gets services facade over all cluster nodes started in server mode.
services(ClusterGroup) - Method in interface org.apache.ignite.Ignite
Gets services facade over nodes within the cluster group.
services() - Method in class org.apache.ignite.IgniteClientSpringBean
Gets services facade over all cluster nodes started in server mode.
services(ClientClusterGroup) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets services facade over nodes within the cluster group.
services(String) - Method in interface org.apache.ignite.IgniteServices
Deprecated.
Use the proxies like IgniteServices.serviceProxy(String, Class, boolean). References to local services corrupt the service statistics and bring no real performance optimization.
services() - Method in class org.apache.ignite.IgniteSpringBean
Gets services facade over all cluster nodes started in server mode.
services(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
Gets services facade over nodes within the cluster group.
ServiceView - Class in org.apache.ignite.spi.systemview.view
Service representation for a SystemView.
ServiceView(ServiceInfo) - Constructor for class org.apache.ignite.spi.systemview.view.ServiceView
 
ServletContextListenerStartup - Class in org.apache.ignite.startup.servlet
This class defines Ignite startup based on servlet context listener.
ServletContextListenerStartup() - Constructor for class org.apache.ignite.startup.servlet.ServletContextListenerStartup
 
ServletStartup - Class in org.apache.ignite.startup.servlet
This class defines servlet-based Ignite startup.
ServletStartup() - Constructor for class org.apache.ignite.startup.servlet.ServletStartup
 
session() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
session() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
 
sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Tells store to commit or rollback a transaction depending on the value of the 'commit' parameter.
sessionEnd(boolean) - Method in interface org.apache.ignite.cache.store.CacheStore
Deprecated.
Use CacheStoreSessionListener instead (refer to its JavaDoc for details).
sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
Default empty implementation for ending transactions.
sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Tells store to commit or rollback a transaction depending on the value of the 'commit' parameter.
sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Default empty implementation for ending transactions.
sessionId() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
ComputeJobView.sessionId() value equal to the value of ComputeTaskView.sessionId() if both records represents parts of the same computation.
sessionId() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
ComputeTaskView.sessionId() value equal to the value of ComputeJobView.sessionId() if both records represents parts of the same computation.
set(String, ClientCollectionConfiguration) - Method in interface org.apache.ignite.client.IgniteClient
Gets a distributed set from cache.
set(String, CollectionConfiguration) - Method in interface org.apache.ignite.Ignite
Will get a named set from cache and create one if it has not been created yet and cfg is not null.
set(T) - Method in interface org.apache.ignite.IgniteAtomicReference
Unconditionally sets the value.
set(T, S) - Method in interface org.apache.ignite.IgniteAtomicStamped
Unconditionally sets the value and the stamp.
set(String, ClientCollectionConfiguration) - Method in class org.apache.ignite.IgniteClientSpringBean
Gets a distributed set from cache.
set(String, CollectionConfiguration) - Method in class org.apache.ignite.IgniteSpringBean
Will get a named set from cache and create one if it has not been created yet and cfg is not null.
set(V1, V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
Sets both values in the tuple.
set(TracingConfigurationCoordinates, TracingConfigurationParameters) - Method in interface org.apache.ignite.spi.tracing.TracingConfigurationManager
Set new tracing configuration for the specific tracing coordinates (scope, label, etc.).
set1(V1) - Method in class org.apache.ignite.lang.IgniteBiTuple
Sets first value.
set2(V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
Sets second value.
setAccountToken(String) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Specifies the path to the service token file.
setAccountToken(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Deprecated.
set parameters with KubernetesConnectionConfiguration instead.
setAckTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets timeout for receiving acknowledgement for sent message.
setActiveJobsThreshold(int) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Sets number of jobs that can be executed in parallel.
setActiveJobsThreshold(int) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Sets number of jobs that can be executed in parallel.
setActiveOnStart(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setAddr(InetAddress) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets server address.
setAddresses(String...) - Method in class org.apache.ignite.configuration.ClientConfiguration
Set addresses of Ignite server nodes within a cluster.
setAddresses(String...) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets the addresses of the Ignite nodes to connect; address string format: host[:portRangeFrom[..portRangeTo]].
setAddresses(Collection<String>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Parses provided values and initializes the internal collection of addresses.
setAddressesFinder(ClientAddressFinder) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setAddressFilter(IgnitePredicate<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets filter for IP addresses.
setAddressRequestAttempts(int) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Sets number of attempts to send multicast address request.
setAddressResolver(AddressResolver) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets address resolver for addresses mapping determination.
setAddressResolver(AddressResolver) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets address resolver.
setAffinity(AffinityFunction) - Method in class org.apache.ignite.configuration.AtomicConfiguration
Sets atomic cache affinity function.
setAffinity(AffinityFunction) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets affinity for cache keys.
setAffinityBackupFilter(IgniteBiPredicate<ClusterNode, List<ClusterNode>>) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Sets optional backup filter.
setAffinityKey(Object) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets affinity key used for key-to-node affinity calculation.
setAffinityKeyFieldName(String) - Method in class org.apache.ignite.cache.CacheKeyConfiguration
Sets affinity key field name.
setAffinityKeyFieldName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
setAffinityMapper(AffinityKeyMapper) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets custom affinity mapper.
setAlias(String) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Gets table alias for type.
setAliases(Map<String, String>) - Method in class org.apache.ignite.cache.QueryEntity
Sets mapping from full property name in dot notation to an alias that will be used as SQL column name.
setAllSegmentationResolversPassRequired(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets all segmentation resolvers pass required flag.
setAlwaysWriteFullPages(boolean) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets flag that enforces writing full page to WAL on every change (instead of delta record).
setAlwaysWriteFullPages(boolean) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
setApplicationAndNode(String, UUID) - Method in class org.apache.ignite.logger.java.JavaLogger
Sets application name and node ID.
setApplicationAndNode(String, UUID) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Sets application name and node ID.
setApplicationContext(ApplicationContext) - Method in class org.apache.ignite.IgniteSpringBean
setArgs(Object...) - Method in class org.apache.ignite.cache.query.SpiQuery
Sets SQL arguments.
setArgs(Object...) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets SQL arguments.
setArgs(Object...) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets SQL arguments.
setArguments(Object...) - Method in class org.apache.ignite.compute.ComputeJobAdapter
Sets given arguments.
setAssemblies(List<String>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
 
setAsyncCallbackPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets async callback thread pool size to use within grid.
setAsyncContinuationExecutor(Executor) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets the async continuation executor.
setAsyncContinuationExecutor(Executor) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets the continuation executor for cache async APIs.
setAtomicConfiguration(AtomicConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setAtomicityMode(CacheAtomicityMode) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setAtomicityMode(CacheAtomicityMode) - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
setAtomicityMode(CacheAtomicityMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache atomicity mode.
setAtomicityMode(CacheAtomicityMode) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setAtomicSequenceReserveSize(int) - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Sets default number of sequence values reserved for IgniteAtomicSequence instances.
setAtomicSequenceReserveSize(int) - Method in class org.apache.ignite.configuration.AtomicConfiguration
Sets default number of sequence values reserved for IgniteAtomicSequence instances.
setAttribute(Object, Object) - Method in interface org.apache.ignite.compute.ComputeJobContext
Sets an attribute into this job context.
setAttribute(Object, Object) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Sets session attributed.
setAttribute(Attribute) - Method in class org.apache.ignite.spi.metric.jmx.ReadOnlyDynamicMBean
setAttributes(Map<?, ?>) - Method in interface org.apache.ignite.compute.ComputeJobContext
Sets map of attributes into this job context.
setAttributes(Map<?, ?>) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Sets task attributes.
setAttributes(Map<String, Object>) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
 
setAttributes(AttributeList) - Method in class org.apache.ignite.spi.metric.jmx.ReadOnlyDynamicMBean
setAuthenticationEnabled(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets flag indicating whether the user authentication is enabled for cluster.
setAuthenticator(DiscoverySpiNodeAuthenticator) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Sets discovery SPI node authenticator.
setAuthenticator(DiscoverySpiNodeAuthenticator) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sets discovery SPI node authenticator.
setAuthenticator(DiscoverySpiNodeAuthenticator) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets discovery SPI node authenticator.
setAuthenticator(DiscoverySpiNodeAuthenticator) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets discovery SPI node authenticator.
setAutoActivationEnabled(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setAutoAdjustmentEnabled(boolean) - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
Deprecated.
Use managements API beans, instead.
setAutoAdjustmentTimeout(long) - Method in interface org.apache.ignite.mxbean.BaselineAutoAdjustMXBean
Deprecated.
Use managements API beans, instead.
setAutoBinaryConfigurationEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets a value indicating whether automatic binary configuration retrieval should be enabled.
setAutoCloseServerCursor(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setAutoUnsubscribe(boolean) - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Sets automatic unsubscribe flag.
setAutoUnsubscribe(boolean) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets automatic unsubscribe flag.
setAutoUnsubscribe(boolean) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets automatic unsubscribe flag.
setBackupFilter(IgniteBiPredicate<ClusterNode, ClusterNode>) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Deprecated.
Use affinityBackupFilter instead.
setBackups(int) - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Sets the number of backup nodes.
setBackups(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setBackups(int) - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
setBackups(int) - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
setBackups(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets number of nodes used to back up single partition for CacheMode.PARTITIONED cache.
setBackups(int) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setBaselineTopology(Collection<? extends BaselineNode>) - Method in interface org.apache.ignite.IgniteCluster
Sets baseline topology.
setBaselineTopology(long) - Method in interface org.apache.ignite.IgniteCluster
Sets baseline topology constructed from the cluster topology of the given version (the method succeeds only if the cluster topology has not changed).
setBatchQueueSize(int) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Sets batch queue size.
setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Sets batch size.
setBatchSize(int) - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Sets batch size.
setBatchSize(int) - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Sets batch size.
setBatchSize(int) - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Sets batch size.
setBatchSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Set maximum batch size for write and delete operations.
setBatchSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Set maximum batch size for write and delete operations.
setBinaryConfiguration(BinaryConfiguration) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setBinaryConfiguration(BinaryConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets configuration for Ignite Binary objects.
setBinaryConfiguration(PlatformDotNetBinaryConfiguration) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
 
setBuffer(ByteBuffer) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Sets but buffer to read from.
setBuffer(ByteBuffer) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Sets but buffer to write to.
setBuildIndexThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets index create/rebuild thread pool size to use within grid.
setCacheConfiguration(CacheConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets cache configurations.
setCacheKeyConfiguration(CacheKeyConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets cache key configuration.
setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in class org.apache.ignite.configuration.CacheConfiguration
setCacheMetrics(Map<Integer, CacheMetrics>) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Sets node cache metrics.
setCacheMode(CacheMode) - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Sets the cache mode.
setCacheMode(CacheMode) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setCacheMode(CacheMode) - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
setCacheMode(CacheMode) - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
setCacheMode(CacheMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets caching mode.
setCacheMode(CacheMode) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setCacheName(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets associated cache name.
setCacheName(String) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets cache name used for key-to-node affinity calculation.
setCacheName(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Sets cache name to be used by this SPI.
setCachePermissions(Map<String, Collection<SecurityPermission>>) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set cache permission map.
setCacheSanityCheckEnabled(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets cache sanity check flag.
setCacheStoreFactory(Factory<? extends CacheStore<? super K, ? super V>>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets factory for persistent storage for cache data.
setCacheStoreSessionListenerFactories(Factory<? extends CacheStoreSessionListener>...) - Method in class org.apache.ignite.configuration.CacheConfiguration
Cache store session listener factories.
setCacheStoreSessionListenerFactories(Factory<CacheStoreSessionListener>...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Cache store session listener factories.
setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in class org.apache.ignite.configuration.CacheConfiguration
setCdcEnabled(boolean) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets flag indicating whether CDC enabled.
setCdcWalDirectoryMaxSize(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets the CDC directory maximum size in bytes.
setCdcWalPath(String) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a path for the CDC directory.
setCheckFrequency(long) - Method in class org.apache.ignite.cdc.CdcConfiguration
 
setCheckMd5(boolean) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
If set to true then SPI should exclude files with same md5s from deployment.
setCheckpointFrequency(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets the checkpoint frequency which is a minimal interval when the dirty pages will be written to the Persistent Store.
setCheckpointingFrequency(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets the checkpointing frequency which is a minimal interval when the dirty pages will be written to the Persistent Store.
setCheckpointingPageBufferSize(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets amount of memory allocated for the checkpointing temporary buffer.
setCheckpointingThreads(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a number of threads to use for the checkpointing purposes.
setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Sets the checkpoint listener.
setCheckpointListener(CheckpointListener) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointSpi
Sets the checkpoint listener.
setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets the checkpoint listener.
setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
Sets the checkpoint listener.
setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Sets the checkpoint listener.
setCheckpointPageBufferSize(long) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets amount of memory allocated for the checkpoint temporary buffer.
setCheckpointReadLockTimeout(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets timeout for checkpoint read lock acquisition.
setCheckpointReadLockTimeout(long) - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
setCheckpointSpi(CheckpointSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of CheckpointSpi.
setCheckpointTableName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint table name.
setCheckpointThreads(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a number of threads to use for the checkpoint purposes.
setCheckpointWriteOrder(CheckpointWriteOrder) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
This property defines order of writing pages to disk storage during checkpoint.
setCheckpointWriteOrder(CheckpointWriteOrder) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
This property defines order of writing pages to disk storage during checkpoint.
setCipherSuites(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Override default cipher suites.
setCipherSuites(String...) - Method in class org.apache.ignite.ssl.AbstractSslContextFactory
Sets enabled cipher suites.
setClassLoader(ClassLoader) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets loader which will be used for instantiating execution context (EntryProcessors, CacheEntryListeners, CacheLoaders and ExpiryPolicys).
setClassName(String) - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Sets class name to use.
setClassNames(Collection<String>) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Sets class names of binary objects explicitly.
setClient(boolean) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets flag indicating if this is client node context.
setClientConfiguration(ClientConfiguration) - Method in class org.apache.ignite.IgniteClientSpringBean
Sets Ignite client configuration.
setClientConnectorConfiguration(ClientConnectorConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets client connector configuration.
setClientFailureDetectionTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets failure detection timeout to use in TcpDiscoverySpi and TcpCommunicationSpi.
setClientMode(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets client mode flag.
setClientMode(boolean) - Static method in class org.apache.ignite.Ignition
Sets client mode thread-local flag.
setClientReconnectDisabled(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets client reconnect disabled flag.
setClientReconnectDisabled(boolean) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets client reconnect disabled flag.
setClusterDiscoveryEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets a value indicating whether cluster discovery should be enabled.
setClusterStateOnStart(ClusterState) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets state of cluster on start.
setCollisionSpi(CollisionSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of CollisionSpi.
setCollocated(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets flag defining if this query is collocated.
setCollocated(boolean) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setCollocated(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setColocated(boolean) - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
setCommunicationFailureResolver(CommunicationFailureResolver) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setCommunicationSpi(CommunicationSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of CommunicationSpi.
setComp(Comparator<EvictableEntry<K, V>>) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
Sets entries comparator.
setCompactFooter(boolean) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Set whether to write footers in compact form.
setComponentClass(Class<T>) - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
 
setConcurrencyLevel(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets the number of concurrent segments in Ignite internal page mapping tables.
setConcurrencyLevel(int) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Sets the number of concurrent segments in Ignite internal page mapping tables.
setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.IgniteSpringBean
Sets Ignite configuration.
setConnectionRecoveryTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets timeout that defines how long server node would try to recovery connection.
setConnectionUrl(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets connection URL.
setConnectionUrl(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets connection URL.
setConnectorConfiguration(ConnectorConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setConsistentId(Serializable) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets consistent globally unique node ID which survives node restarts.
setConsistentId(Serializable) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Sets consistent globally unique node ID which survives node restarts.
setConsumer(CdcConsumer) - Method in class org.apache.ignite.cdc.CdcConfiguration
 
setContext(MarshallerContext) - Method in class org.apache.ignite.marshaller.AbstractMarshaller
Sets marshaller context.
setContext(MarshallerContext) - Method in interface org.apache.ignite.marshaller.Marshaller
Sets marshaller context.
setConverter(SocketMessageConverter<T>) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets message converter.
setCopyOnRead(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setCopyOnRead(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets copy on read flag.
setCreateTableQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets create table query.
setCreateTableQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets create table query.
setCriteria(IndexQueryCriterion...) - Method in class org.apache.ignite.cache.query.IndexQuery
Sets conjunction (AND) criteria for index query.
setCriteria(List<IndexQueryCriterion>) - Method in class org.apache.ignite.cache.query.IndexQuery
Sets conjunction (AND) criteria for index query.
setCurrentReadClass(Class<? extends Message>) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Sets type of message currently read.
setCurrentWriteClass(Class<? extends Message>) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Sets type of message currently written.
setDatabaseFieldName(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
setDatabaseFieldType(int) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
setDatabaseSchema(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets database schema name.
setDatabaseTable(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Table name in database.
setDataExchange(DiscoverySpiDataExchange) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Sets a handler for initial data exchange between Ignite nodes.
setDataExchange(DiscoverySpiDataExchange) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sets a handler for initial data exchange between Ignite nodes.
setDataExchange(DiscoverySpiDataExchange) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets a handler for initial data exchange between Ignite nodes.
setDataExchange(DiscoverySpiDataExchange) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets a handler for initial data exchange between Ignite nodes.
setDataRegionConfigurations(DataRegionConfiguration...) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets data regions configurations.
setDataRegionName(String) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setDataRegionName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets a name of DataRegionConfiguration for this cache.
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
 
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets data source.
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets data source.
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Deprecated.
setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
Sets data source.
setDataSource(DataSource) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets DataSource to use for database access.
setDataSource(DataSource) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Sets data source.
setDataSourceBean(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets name of the data source bean.
setDataSourceBean(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets name of the data source bean.
setDataSourceFactory(Factory<DataSource>) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets factory for underlying datasource.
setDataStorageConfiguration(DataStorageConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets durable memory configuration.
setDataStreamerThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Set thread pool size that will be used to process data stream messages.
setDefault(boolean) - Method in class org.apache.ignite.calcite.CalciteQueryEngineConfiguration
Sets whether this query engine should be used by default.
setDefault(boolean) - Method in interface org.apache.ignite.configuration.QueryEngineConfiguration
Sets whether this query engine should be used by default.
setDefault(boolean) - Method in class org.apache.ignite.indexing.IndexingQueryEngineConfiguration
Sets whether this query engine should be used by default.
setDefaultAllowAll(boolean) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set default allow all.
setDefaultDataRegionConfiguration(DataRegionConfiguration) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Overrides configuration of default data region which has been created automatically.
setDefaultFieldValues(Map<String, Object>) - Method in class org.apache.ignite.cache.QueryEntity
Sets fields default values.
setDefaultIdMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
setDefaultKeepDeserialized(boolean) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
Sets default keep deserialized flag.
setDefaultLockTimeout(long) - Method in class org.apache.ignite.client.ClientCacheConfiguration
Deprecated.
Default lock timeout configuration property has no effect.
setDefaultLockTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
Default lock timeout configuration property has no effect.
setDefaultMemoryPolicyName(String) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Sets the name for the default memory policy that will initialize the default memory region.
setDefaultMemoryPolicySize(long) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Overrides size of default memory policy which is created automatically.
setDefaultNameMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
setDefaultPriority(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets default priority to use if a job does not have priority attribute set.
setDefaultPriority(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Sets default priority to use if a job does not have priority attribute set.
setDefaultQueryTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setDefaultQueryTimeout(long) - Method in class org.apache.ignite.configuration.SqlConfiguration
Deprecated.
Since 2.9. Please use distributed default query timeout.
setDefaultSerializer(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
setDefaultTxConcurrency(TransactionConcurrency) - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Sets default transaction concurrency.
setDefaultTxConcurrency(TransactionConcurrency) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets default transaction concurrency.
setDefaultTxIsolation(TransactionIsolation) - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Sets default transaction isolation.
setDefaultTxIsolation(TransactionIsolation) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets default transaction isolation.
setDefaultTxTimeout(long) - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
Sets default transaction timeout in milliseconds.
setDefaultTxTimeout(long) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets default transaction timeout in milliseconds.
setDefaultWarmUpConfiguration(WarmUpConfiguration) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets default warm-up configuration.
setDefragmentationThreadPoolSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets maximum number of partitions which can be defragmented at the same time.
setDeleteQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets delete entry query.
setDeleteQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets delete entry query.
setDelimiter(byte[]) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets message delimiter.
setDeploymentMode(DeploymentMode) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets task classes and resources sharing mode.
setDeploymentSpi(DeploymentSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of DeploymentSpi.
setDialect(JdbcDialect) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Set database dialect.
setDialect(JdbcDialect) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Set database dialect.
setDirectBuffer(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets whether to use direct buffer for REST TCP server.
setDirectMode(boolean) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets direct mode flag.
setDirectoryPaths(Collection<String>) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Sets path to a shared directory where checkpoints will be stored.
setDiscoveryPort(int) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Specifies the port which is returned to the caller to use for service discovery.
setDiscoveryPort(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets discovery port for warmup.
setDiscoverySpi(DiscoverySpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of DiscoverySpi.
setDiscoveryStartupDelay(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Not used any more.
setDiskPageCompression(DiskPageCompression) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets disk page compression algorithm.
setDiskPageCompressionLevel(Integer) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets algorithm specific disk page compression level.
setDistributedJoins(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Specify if distributed joins are enabled for this query.
setDistributedJoins(boolean) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Specify if distributed joins are enabled for this query.
setDistributedJoins(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setEagerTtl(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setEagerTtl(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets eager ttl flag.
setEmptyPagesPoolSize(int) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Specifies the minimal number of empty pages to be present in reuse lists for this data region.
setEmptyPagesPoolSize(int) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Specifies the minimal number of empty pages to be present in reuse lists for this memory policy.
setEncodeUri(boolean) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Indicates that URI must be encoded before usage.
setEncryptionConfiguration(EncryptionConfiguration) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets encryption configuration.
setEncryptionEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets encrypted flag.
setEncryptionSpi(EncryptionSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instances of EncryptionSpi.
setEndpointAddress(String) - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Set ODBC endpoint address.
setEnforceJoinOrder(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets flag to enforce join order of tables in the query.
setEnforceJoinOrder(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setEnum(boolean) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Sets whether this is enum type.
setEnum(boolean) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Sets whether this is enum type.
setEnumValues(Map<String, Integer>) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Set enum ordinal to names mapping.
setEventListeners(EventListener...) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setEventsDisabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets events disabled flag.
setEventStorageSpi(EventStorageSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of EventStorageSpi.
setEvictionFilter(EvictionFilter<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets eviction filter.
setEvictionPolicy(EvictionPolicy) - Method in class org.apache.ignite.configuration.CacheConfiguration
setEvictionPolicyFactory(Factory<? extends EvictionPolicy<? super K, ? super V>>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache eviction policy factory.
setEvictionThreshold(double) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets memory pages eviction threshold.
setEvictionThreshold(double) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets memory pages eviction threshold.
setExcludeNeighbors(boolean) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Sets flag to exclude same-host-neighbors from being backups of each other (default is false).
setExecutorConfiguration(ExecutorConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets custom executors for user compute tasks.
setExpireAgeMs(long) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Sets events expiration time.
setExpireCount(long) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Sets events queue size.
setExpireDateFieldName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint expiration date field name.
setExpireDateFieldType(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint expiration date field type.
setExpiryPolicy(ExpiryPolicy) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class org.apache.ignite.configuration.CacheConfiguration
setExportFilter(Predicate<ReadOnlyMetricRegistry>) - Method in class org.apache.ignite.spi.metric.jmx.JmxMetricExporterSpi
Sets export filter.
setExportFilter(Predicate<ReadOnlyMetricRegistry>) - Method in interface org.apache.ignite.spi.metric.MetricExporterSpi
Sets export filter.
setExportFilter(Predicate<ReadOnlyMetricRegistry>) - Method in class org.apache.ignite.spi.metric.noop.NoopMetricExporterSpi
Sets export filter.
setExportFilter(Predicate<SystemView<?>>) - Method in interface org.apache.ignite.spi.systemview.SystemViewExporterSpi
Sets export filter.
setExternalCollisionListener(CollisionExternalListener) - Method in interface org.apache.ignite.spi.collision.CollisionSpi
Listener to be set for notification of external collision events (e.g. job stealing).
setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Listener to be set for notification of external collision events (e.g. job stealing).
setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Listener to be set for notification of external collision events (e.g. job stealing).
setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
Listener to be set for notification of external collision events (e.g. job stealing).
setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Listener to be set for notification of external collision events (e.g. job stealing).
setFailoverSpi(FailoverSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of FailoverSpi.
setFailureDetectionTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets failure detection timeout to use in TcpDiscoverySpi and TcpCommunicationSpi.
setFailureHandler(FailureHandler) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets failure handler.
setFetchSize(int) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Sets fetch size.
setField(String, Object) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Sets field value.
setField(String, T, Class<? super T>) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Sets field value with value type specification.
setField(String, BinaryObjectBuilder) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
Sets field value.
setFieldNames(Collection<String>, boolean) - Method in class org.apache.ignite.cache.QueryIndex
Sets a collection of field names altogether with the field sorting direction.
setFields(LinkedHashMap<String, String>) - Method in class org.apache.ignite.cache.QueryEntity
Sets query fields for this query pair.
setFields(LinkedHashMap<String, Boolean>) - Method in class org.apache.ignite.cache.QueryIndex
Sets fields included in the index.
setFieldsPrecision(Map<String, Integer>) - Method in class org.apache.ignite.cache.QueryEntity
Sets fieldsPrecision map for a fields.
setFieldsScale(Map<String, Integer>) - Method in class org.apache.ignite.cache.QueryEntity
Sets fieldsScale map for a fields.
setFileIOFactory(FileIOFactory) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets factory to provide implementation of FileIO interface which is used for data storage files read/write operations
setFileIOFactory(FileIOFactory) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
setFilter(IgniteBiPredicate<K, V>) - Method in class org.apache.ignite.cache.query.IndexQuery
Sets remote cache entries filter.
setFilter(IgniteBiPredicate<K, V>) - Method in class org.apache.ignite.cache.query.ScanQuery
Sets filter.
setFilter(IgnitePredicate<Event>) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Sets filter for events to be recorded.
setForceServerMode(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Deprecated.
Will be removed at 3.0.
setGlobalMemoryQuota(long) - Method in class org.apache.ignite.calcite.CalciteQueryEngineConfiguration
Sets global heap memory quota for SQL engine.
setGridCount(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets number of grids to start and run the warmup.
setGridLogger(IgniteLogger) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets logger to use within grid.
setGridName(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setGroupName(String) - Method in class org.apache.ignite.client.ClientAtomicConfiguration
Gets the cache group name.
setGroupName(String) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setGroupName(String) - Method in class org.apache.ignite.client.ClientCollectionConfiguration
 
setGroupName(String) - Method in class org.apache.ignite.configuration.AtomicConfiguration
 
setGroupName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets the cache group name.
setGroupName(String) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setHandshakeTimeout(long) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets handshake timeout for client connections.
setHasher(JdbcTypeHasher) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Sets hash code calculator.
setHasher(JdbcTypeHasher) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets hash code calculator.
setHeartbeatEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets a value indicating whether heartbeats are enabled.
setHeartbeatInterval(long) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets the heartbeat message interval, in milliseconds.
setHost(String) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Set host.
setHost(String) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets host for TCP binary protocol server.
setHost(String) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Set host.
setIdleQueryCursorCheckFrequency(long) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets idle query cursor check frequency.
setIdleQueryCursorTimeout(long) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets idle query cursors timeout.
setIdleTimeout(long) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets idle timeout for client connections.
setIdleTimeout(long) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets idle timeout for REST server.
setIdMapper(BinaryIdMapper) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Sets ID mapper.
setIdMapper(BinaryIdMapper) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Sets ID mapper.
setIdMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
setIgnite(Ignite) - Method in class org.apache.ignite.stream.StreamAdapter
 
setIgniteHome(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Ignite installation folder.
setIgniteInstanceName(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets of local instance name.
setIgnoredFailureTypes(Set<FailureType>) - Method in class org.apache.ignite.failure.AbstractFailureHandler
Sets failure types that must be ignored by failure handler.
setIncludeEventTypes(int...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets array of event types, which will be recorded by GridEventStorageManager.record(Event).
setIncludeExpired(boolean) - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Sets the flag value defining whether to notify about EventType.EXPIRED events.
setIncludeNotReadyAddresses(boolean) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Determines whether addresses of not-ready pods should be included.
setIncludeProperties(String...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets array of system or environment property names to include into node attributes.
setIndexedTypes(Class<?>...) - Method in class org.apache.ignite.configuration.CacheConfiguration
Array of key and value type pairs to be indexed (thus array length must be always even).
setIndexes(Collection<QueryIndex>) - Method in class org.apache.ignite.cache.QueryEntity
Sets a collection of index entities.
setIndexingSpi(IndexingSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instances of IndexingSpi.
setIndexType(QueryIndexType) - Method in class org.apache.ignite.cache.QueryIndex
Sets index type.
setInitialContextEnvironment(Map<?, ?>) - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Sets initial context environment map that will be used in InitialContext.InitialContext(Hashtable) constructor.
setInitialQuery(Query<Cache.Entry<K, V>>) - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Sets initial query.
setInitialQuery(Query<Cache.Entry<K, V>>) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets initial query.
setInitialQuery(Query<Cache.Entry<K, V>>) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets initial query.
setInitialSize(long) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets initial memory region size defined by this data region.
setInitialSize(long) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets initial memory region size defined by this memory policy.
setInitialSize(long) - Method in class org.apache.ignite.configuration.SystemDataRegionConfiguration
Sets initial size of a data region reserved for system cache.
setInitSchema(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Flag indicating whether DB schema should be initialized by Ignite (default behaviour) or was explicitly created by user.
setInitSchema(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Flag indicating whether DB schema should be initialized by Ignite (default behaviour) or was explicitly created by user.
setInitSchema(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Flag indicating whether DB schema should be initialized by Ignite (default behaviour) or was explicitly created by user.
setInlineSize(int) - Method in class org.apache.ignite.cache.QueryIndex
Sets index inline size in bytes.
setInsertQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets insert entry query.
setInsertQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets insert entry query.
setInterceptor(CacheInterceptor<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache interceptor.
setInterceptors(ServiceCallInterceptor...) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets service call interceptors.
setInternalListener(IgniteDiscoverySpiInternalListener) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
For TESTING only.
setInternalListener(IgniteDiscoverySpiInternalListener) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
For TESTING only.
setInternalListener(IgniteDiscoverySpiInternalListener) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
For TESTING only.
setInvalidate(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets invalidation flag for near cache entries in this transaction.
setIpFinder(TcpDiscoveryIpFinder) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets IP finder for IP addresses sharing and storing.
setIpFinderCleanFrequency(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets IP finder clean frequency in milliseconds.
setIterationCount(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets iteration count for warmup.
setJavaFieldName(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
setJavaFieldType(Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
 
setJdbcEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets whether access through JDBC is enabled.
setJettyPath(String) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets path, either absolute or relative to IGNITE_HOME, to JETTY XML configuration file.
setJndiNames(String...) - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
Sets JNDI names used by this TM factory.
setJndiNames(List<String>) - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
Sets a list of JNDI names used by this TM.
setJobPriorityAttributeKey(String) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets job priority attribute key.
setJoinTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets join timeout.
setJoinTimeout(long) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
setKeepBinary(boolean) - Method in class org.apache.ignite.cdc.CdcConfiguration
 
setKeepBinary(boolean) - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Sets a value indicating whether platform cache should store keys and values in binary form.
setKeepDeserialized(Boolean) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
Sets keep deserialized flag.
setKeyAlgorithm(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets key manager algorithm that will be used to create a key manager.
setKeyConfiguration(CacheKeyConfiguration...) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setKeyConfiguration(CacheKeyConfiguration...) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache key configuration.
setKeyFieldName(String) - Method in class org.apache.ignite.cache.QueryEntity
Sets key field name.
setKeyFieldName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint key field name.
setKeyFields(Set<String>) - Method in class org.apache.ignite.cache.QueryEntity
Gets query fields for this query pair that belongs to the key.
setKeyFields(JdbcTypeField...) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets optional persistent key fields (needed only if CacheJdbcPojoStore is used).
setKeyFieldType(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint key field type.
setKeyRange(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets key range.
setKeySize(int) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Sets encryption key size.
setKeyStoreFilePath(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets path to the key store file.
setKeyStorePassword(char[]) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Sets password to access KeyStore.
setKeyStorePassword(char[]) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets key store password.
setKeyStorePath(String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Sets path to jdk keyStore that stores master key.
setKeyStoreType(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets key store type used in context initialization.
setKeyType(String) - Method in class org.apache.ignite.cache.QueryEntity
Sets key type for this query pair.
setKeyType(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets key type.
setKeyType(Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets key type.
setKeyTypeName(String) - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Sets fully-qualified platform type name of the cache key used for the local map.
setLateAffinityAssignment(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Starting from Ignite 2.1 late affinity assignment is always enabled.
setLazy(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Deprecated.
setLazy(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setLazyMemoryAllocation(boolean) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets lazyMemoryAllocation flag value.
setLifecycleBeans(LifecycleBean...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets a collection of lifecycle beans.
setLimit(int) - Method in class org.apache.ignite.cache.query.IndexQuery
Sets limit to response records count.
setLimit(int) - Method in class org.apache.ignite.cache.query.TextQuery
Sets limit to response records count.
setListener(CommunicationListener<T>) - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
Set communication listener.
setListener(CommunicationListener<Message>) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Deprecated.
setListener(DeploymentListener) - Method in interface org.apache.ignite.spi.deployment.DeploymentSpi
Sets or unsets deployment event listener.
setListener(DeploymentListener) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Sets or unsets deployment event listener.
setListener(DeploymentListener) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Sets or unsets deployment event listener.
setListener(DiscoverySpiListener) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Deprecated.
setListener(DiscoverySpiListener) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sets a listener for discovery events.
setListener(DiscoverySpiListener) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets a listener for discovery events.
setListener(DiscoverySpiListener) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets a listener for discovery events.
setLivenessCheckEnabled(boolean) - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
setLoadBalancingSpi(LoadBalancingSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instance of LoadBalancingSpi.
setLoadPreviousValue(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setLoadProbe(AdaptiveLoadProbe) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Sets implementation of node load probe.
setLoadQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets load query.
setLoadQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets load query.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets whether this query should be executed on a local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.Query
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.ScanQuery
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.SpiQuery
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets whether this query should be executed on local node only.
setLocal(boolean) - Method in class org.apache.ignite.cache.query.TextQuery
Sets whether this query should be executed on local node only.
setLocalAddress(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Sets local host address used by this IP finder.
setLocalAddress(String) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets network addresses for the Discovery SPI.
setLocalEventListeners(Map<IgnitePredicate<? extends Event>, int[]>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets map of pre-configured local event listeners.
setLocalHost(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets system-wide local address or host for all Ignite components to bind to.
setLocalListener(CacheEntryUpdatedListener<K, V>) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets a local callback.
setLocalListener(ContinuousQueryWithTransformer.EventListener<T>) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets local callback.
setLocalPort(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets local port to listen to.
setLocalPortRange(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Range for local ports.
setLockTimeout(long) - Method in class org.apache.ignite.cdc.CdcConfiguration
 
setLockWaitTime(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Timeout in milliseconds to wait when acquiring persistence store lock file before failing the local node.
setLockWaitTime(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Time out in milliseconds to wait when acquiring persistence store lock file before failing the local node.
setLogger(IgniteLogger) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets the logger.
setLogin(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Sets login.
setLoginTimeout(int) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
setLogWriter(PrintWriter) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
setLongOperationsDumpTimeout(long) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Setting a timeout (in millis) for printing long-running transactions as well as transactions that cannot receive locks for all their keys for a long time.
setLongQueryWarningTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
setLongQueryWarningTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setLongQueryWarningTimeout(long) - Method in class org.apache.ignite.configuration.SqlConfiguration
Sets timeout in milliseconds after which long query warning will be printed.
setLongTransactionTimeDumpThreshold(long) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Sets threshold timeout in milliseconds for long transactions, if transaction exceeds it, it will be dumped in log with information about how much time did it spent in system time (time while aquiring locks, preparing, commiting, etc.)
setLowerCase(boolean) - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
Sets whether to use strings in lower case or not.
setManagementEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setManagementThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets management thread pool size to use within grid.
setMarshaller(Marshaller) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Since 2.1. Some Ignite features will not work if non-null marshaller is set (IgniteCache.withKeepBinary(), .NET, CPP, ODBC)
setMarshalLocalJobs(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets marshal local jobs flag.
setMasterKeyName(String) - Method in interface org.apache.ignite.spi.encryption.EncryptionSpi
Sets master key Name that will be used for keys encryption in EncryptionSpi.encryptKey(Serializable) and EncryptionSpi.decryptKey(byte[]) methods and in the EncryptionSpi.masterKeyDigest() method.
setMasterKeyName(String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
Sets master key Name that will be used for keys encryption in EncryptionSpi.encryptKey(Serializable) and EncryptionSpi.decryptKey(byte[]) methods and in the EncryptionSpi.masterKeyDigest() method.
setMasterKeyName(String) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
Sets master key Name that will be used for keys encryption in EncryptionSpi.encryptKey(Serializable) and EncryptionSpi.decryptKey(byte[]) methods and in the EncryptionSpi.masterKeyDigest() method.
setMasterUrl(String) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Sets the host name of the Kubernetes API server.
setMasterUrl(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Deprecated.
set parameters with KubernetesConnectionConfiguration instead.
setMaxAckTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets maximum timeout for receiving acknowledgement for sent message.
setMaxActiveComputeTasksPerConnection(int) - Method in class org.apache.ignite.configuration.ThinClientConfiguration
Sets active compute tasks per connection limit.
setMaxActiveTxPerConnection(int) - Method in class org.apache.ignite.configuration.ThinClientConfiguration
Sets active transactions count per connection limit.
setMaxConcurrentAsyncOperations(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setMaxConcurrentAsyncOperations(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum number of concurrent asynchronous operations.
setMaximumFailoverAttempts(int) - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Sets maximum number of attempts to execute a failed job on another node.
setMaximumFailoverAttempts(int) - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
Sets maximum number of attempts to execute a failed job on another node.
setMaximumPoolSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Set Max workers thread count.
setMaximumPoolSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Set Maximum workers thread count.
setMaximumStealingAttempts(int) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets maximum number of attempts to steal job by another node.
setMaximumStealingAttempts(int) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets maximum number of attempts to steal job by another node.
setMaximumWriteAttempts(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Sets maximum number of write attempts in case of database error.
setMaximumWriteAttempts(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets maximum number of write attempts in case of database error.
setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Sets maximum allowed cache size in bytes.
setMaxMemorySize(long) - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Sets maximum allowed cache size in bytes.
setMaxOpenCursors(int) - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Sets maximum number of opened cursors per connection.
setMaxOpenCursorsPerConnection(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets maximum number of opened cursors per connection.
setMaxOpenCursorsPerConnection(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Sets maximum number of opened cursors per connection.
setMaxParameterCount(int) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Set max query parameters count.
setMaxPerNodeCount(int) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets maximum number of deployed service instances on each node, 0 for unlimited.
setMaxQueryIteratorsCount(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setMaxQueryIteratorsCount(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum number of query iterators that can be stored.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicyFactory
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
Sets maximum allowed cache size.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
Sets maximum allowed cache size.
setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Sets maximum allowed size of cache before entry will start getting evicted.
setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
Sets maximum allowed cache size.
setMaxSize(long) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets maximum memory region size defined by this data region.
setMaxSize(long) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets maximum memory region size defined by this memory policy.
setMaxSize(long) - Method in class org.apache.ignite.configuration.SystemDataRegionConfiguration
Sets maximum data region size in bytes reserved for system cache.
setMaxWalArchiveSize(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a max allowed size(in bytes) of WAL archives.
setMBeanServer(MBeanServer) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets initialized and started MBean server.
setMemoryAllocator(MemoryAllocator) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets memory allocator.
setMemoryAllocator(MemoryAllocator) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets default memory allocator for all memory regions.
setMemoryConfiguration(MemoryConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
setMemoryPolicies(MemoryPolicyConfiguration...) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Sets memory policies configurations.
setMemoryPolicyName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
setMessageExpireTime(long) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Message expire time configuration parameter.
setMessageExpireTime(long) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Message expire time configuration parameter.
setMessageInterceptor(ConnectorMessageInterceptor) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets client message interceptor.
setMethodName(String) - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
Sets method name.
setMetricExporterSpi(MetricExporterSpi...) - Method in class org.apache.ignite.cdc.CdcConfiguration
Sets fully configured instances of MetricExporterSpi.
setMetricExporterSpi(MetricExporterSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instances of MetricExporterSpi.
setMetricRegistry(ReadOnlyMetricManager) - Method in class org.apache.ignite.spi.metric.jmx.JmxMetricExporterSpi
Sets metrics registry that SPI should export.
setMetricRegistry(ReadOnlyMetricManager) - Method in interface org.apache.ignite.spi.metric.MetricExporterSpi
Sets metrics registry that SPI should export.
setMetricRegistry(ReadOnlyMetricManager) - Method in class org.apache.ignite.spi.metric.noop.NoopMetricExporterSpi
Sets metrics registry that SPI should export.
setMetrics(ClusterMetrics) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Sets node metrics.
setMetricsEnabled(boolean) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets memory metrics enabled flag.
setMetricsEnabled(boolean) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Deprecated.
Will be removed in upcoming releases.
setMetricsEnabled(boolean) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets memory metrics enabled flag.
setMetricsEnabled(boolean) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets flag indicating whether persistence metrics collection is enabled.
setMetricsExpireTime(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets time in milliseconds after which a certain metric value is considered expired.
setMetricsHistorySize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets number of metrics kept in history to compute totals and averages.
setMetricsLogFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets frequency of metrics log print out.
setMetricsProvider(DiscoveryMetricsProvider) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Sets discovery metrics provider.
setMetricsProvider(DiscoveryMetricsProvider) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sets discovery metrics provider.
setMetricsProvider(DiscoveryMetricsProvider) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets discovery metrics provider.
setMetricsProvider(DiscoveryMetricsProvider) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets discovery metrics provider.
setMetricsRateTimeInterval(long) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
setMetricsRateTimeInterval(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
setMetricsSubIntervalCount(int) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
setMetricsSubIntervalCount(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
setMetricsUpdateFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Ignite metrics update frequency in milliseconds.
setMinWalArchiveSize(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a min allowed size(in bytes) of WAL archives.
setMulticastGroup(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Sets IP address of multicast group.
setMulticastPort(int) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Sets port number which multicast messages are sent to.
setMultipleTupleExtractor(StreamMultipleTupleExtractor<T, K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
 
setMvccVacuumFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
This is an experimental feature.
setMvccVacuumThreadCount(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
This is an experimental feature.
setName(String) - Method in class org.apache.ignite.cache.QueryIndex
Sets index name.
setName(String) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache name.
setName(String) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets data region name.
setName(String) - Method in class org.apache.ignite.configuration.ExecutorConfiguration
Set thread pool name.
setName(String) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets memory policy name.
setName(String) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets service name.
setName(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
Sets SPI name.
setName(String) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Sets SPI name.
setNameMapper(BinaryNameMapper) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Sets name mapper.
setNameMapper(BinaryNameMapper) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Sets name mapper.
setNameMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
setNamespace(String) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Sets the namespace the Kubernetes service belongs to.
setNamespace(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Deprecated.
set parameters with KubernetesConnectionConfiguration instead.
setNearConfiguration(NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets the near cache configuration to use on all cache nodes.
setNearEvictionPolicy(EvictionPolicy<K, V>) - Method in class org.apache.ignite.configuration.NearCacheConfiguration
setNearEvictionPolicyFactory(Factory<? extends EvictionPolicy<? super K, ? super V>>) - Method in class org.apache.ignite.configuration.NearCacheConfiguration
Sets cache eviction policy factory.
setNearStartSize(int) - Method in class org.apache.ignite.configuration.NearCacheConfiguration
Start size for near cache.
setNetworkCompressionLevel(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets compression level for internal network messages.
setNetworkSendRetryCount(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets message send retries count.
setNetworkSendRetryDelay(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets interval in milliseconds between message send retries.
setNetworkTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Maximum timeout in milliseconds for network requests.
setNetworkTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets maximum network timeout to use for network operations.
setNodeAttributes(Map<String, Object>, IgniteProductVersion) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
Sets node attributes and node version which will be distributed in grid during join process.
setNodeAttributes(Map<String, Object>, IgniteProductVersion) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
Sets node attributes and node version which will be distributed in grid during join process.
setNodeAttributes(Map<String, Object>, IgniteProductVersion) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets node attributes and node version which will be distributed in grid during join process.
setNodeAttributes(Map<String, Object>, IgniteProductVersion) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
Sets node attributes and node version which will be distributed in grid during join process.
setNodeFilter(IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets filter which determines on what nodes the cache should be started.
setNodeFilter(IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.configuration.CollectionConfiguration
 
setNodeFilter(IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets node filter used to filter nodes on which the service will be deployed.
setNodeId(UUID) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setNoDelay(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets whether TCP_NODELAY option should be set for all accepted client connections.
setNodeName(Marshaller, String) - Static method in class org.apache.ignite.marshaller.MarshallerUtils
Set node name to marshaller context if possible.
setNodeWeight(int) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Sets weight of this node.
setNotNullFields(Set<String>) - Method in class org.apache.ignite.cache.QueryEntity
Sets names of fields that must checked for null.
setNumberOfRetries(int) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets number of retries in case of any database errors.
setOdbcConfiguration(OdbcConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setOdbcEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets whether access through ODBC is enabled.
setOffHeapMaxMemory(long) - Method in class org.apache.ignite.configuration.CollectionConfiguration
Deprecated.
No longer used.
setOnheapCacheEnabled(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setOnheapCacheEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Configures on-heap cache for the off-heap based page memory.
setPageEvictionMode(DataPageEvictionMode) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets memory pages eviction mode.
setPageEvictionMode(DataPageEvictionMode) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets memory pages eviction mode.
setPageReplacementMode(PageReplacementMode) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets memory pages replacement mode.
setPageSize(int) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.Query
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.ScanQuery
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.SpiQuery
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.cache.query.TextQuery
Sets optional page size, if 0, then default is used.
setPageSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Changes the page size.
setPageSize(int) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Changes the page size.
setParallelJobsNumber(int) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Sets number of jobs that can be executed in parallel.
setParallelJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Sets number of jobs that can be executed in parallel.
setParallelJobsNumber(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets number of jobs that can be executed in parallel.
setParallelJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Sets number of jobs that can be executed in parallel.
setParallelLoadCacheMinimumThreshold(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Parallel load cache minimum row count threshold.
setParallelLoadCacheMinimumThreshold(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Parallel load cache minimum row count threshold.
setPartition(Integer) - Method in class org.apache.ignite.cache.query.IndexQuery
Sets partition number over which this query should iterate.
setPartition(Integer) - Method in class org.apache.ignite.cache.query.ScanQuery
Sets partition number over which this query should iterate.
setPartitionAwarenessEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets a value indicating whether partition awareness should be enabled.
setPartitionAwarenessMapperFactory(ClientPartitionAwarenessMapperFactory) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setPartitionLossPolicy(PartitionLossPolicy) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setPartitionLossPolicy(PartitionLossPolicy) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets partition loss policy.
setPartitions(int) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
Sets total number of partitions.If the number of partitions is a power of two, the PowerOfTwo hashing method will be used.
setPartitions(int...) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets partitions for a query.
setPartitions(int...) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets partitions for a query.
setPassword(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets password for database access.
setPassword(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets password for database access.
setPassword(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setPassword(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Sets password.
setPath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Sets path.
setPeerClassLoadingEnabled(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Enables/disables peer class loading.
setPeerClassLoadingLocalClassPathExclude(String...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets list of packages in a system class path that should be P2P loaded even if they exist locally.
setPeerClassLoadingMissedResourcesCacheSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets size of missed resources cache.
setPeerClassLoadingThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets thread pool size to use for peer class loading.
setPersistenceEnabled(boolean) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets persistence enabled flag.
setPersistentStoreConfiguration(PersistentStoreConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Part of old API. Use DataStorageConfiguration for configuring persistence instead.
setPersistentStorePath(String) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a path to the root directory where the Persistent Store will persist data and indexes.
setPerTask(boolean) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
Configuration parameter indicating whether a new round robin order should be created for every task.
setPessimisticTxLogLinger(int) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Deprecated.
Pessimistic tx log linger property has no effect.
setPessimisticTxLogSize(int) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Deprecated.
Pessimistic tx log size property has no effect.
setPhase(int) - Method in class org.apache.ignite.IgniteClientSpringBean
Sets SmartLifecycle phase during which the current bean will be initialized.
setPlatformCacheConfiguration(PlatformCacheConfiguration) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets platform cache configuration.
setPlatformConfiguration(PlatformConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets platform configuration.
setPluginConfigurations(CachePluginConfiguration...) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache plugin configurations.
setPluginConfigurations(PluginConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Deprecated.
Since PluginProviders can be set explicitly via IgniteConfiguration.setPluginProviders(PluginProvider[]) it's preferable to store PluginConfiguration as a part of PluginProvider.
setPluginProviders(PluginProvider...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets plugin providers.
setPort(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Set port.
setPort(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets port for TCP binary protocol server.
setPort(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Set port.
setPort(int) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets port number.
setPortRange(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Set port range.
setPortRange(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets number of ports to try if configured one is in use.
setPortRange(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Set port range.
setPriorityAttributeKey(String) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets task priority attribute key.
setProcessorCoefficient(double) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Sets coefficient of every CPU processor.
setProperties(Map<String, Serializable>) - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
Sets a map of properties.
setProperties(Map<String, ?>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Set properties.
setProperties(Map<String, ?>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
Set properties.
setProperties(Map<String, ?>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Set properties.
setProtocol(String) - Method in class org.apache.ignite.ssl.AbstractSslContextFactory
Sets protocol for secure transport.
setProtocols(String...) - Method in class org.apache.ignite.ssl.AbstractSslContextFactory
Sets enabled protocols.
setPublicThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets thread pool size to use within grid.
setPwd(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint database password.
setQueryDetailMetricsSize(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setQueryDetailMetricsSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets size of queries detail metrics that will be stored in memory for monitoring purposes.
setQueryEnginesConfiguration(QueryEngineConfiguration...) - Method in class org.apache.ignite.configuration.SqlConfiguration
Sets query engines configuration.
setQueryEntities(QueryEntity...) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setQueryEntities(Collection<QueryEntity>) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets query entities configuration.
setQueryInitiatorId(String) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
 
setQueryMemoryQuota(long) - Method in class org.apache.ignite.calcite.CalciteQueryEngineConfiguration
Sets per-query heap memory quota.
setQueryParallelism(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setQueryParallelism(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets query parallelism.
setQueryThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets query thread pool size to use within grid.
setRateTimeInterval(long) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
setRateTimeInterval(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
setReadFromBackup(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setReadFromBackup(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets read from backup flag.
setReadThrough(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setRebalanceBatchesPrefetchCount(long) - Method in class org.apache.ignite.client.ClientCacheConfiguration
setRebalanceBatchesPrefetchCount(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
setRebalanceBatchesPrefetchCount(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
The number of batches generated by supply node at rebalancing procedure start.
setRebalanceBatchSize(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
setRebalanceBatchSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
setRebalanceBatchSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
The supply message size in bytes to be loaded within a single rebalance batch.
setRebalanceDelay(long) - Method in class org.apache.ignite.client.ClientCacheConfiguration
Deprecated.
Use baseline topology feature instead. Please, be aware this API will be removed in the next releases.
setRebalanceDelay(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
Use baseline topology feature instead. Please, be aware this API will be removed in the next releases.
setRebalanceMode(CacheRebalanceMode) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setRebalanceMode(CacheRebalanceMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache rebalance mode.
setRebalanceOrder(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setRebalanceOrder(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets cache rebalance order.
setRebalanceThreadPoolSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Deprecated.
setRebalanceThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Max count of threads can be used at rebalancing.
setRebalanceThrottle(long) - Method in class org.apache.ignite.client.ClientCacheConfiguration
setRebalanceThrottle(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
setRebalanceThrottle(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network.
setRebalanceTimeout(long) - Method in class org.apache.ignite.client.ClientCacheConfiguration
setRebalanceTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
setRebalanceTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Rebalance timeout for supply and demand messages in milliseconds.
setReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets REST TCP server receive buffer size in bytes.
setReconnectCount(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Number of times node tries to (re)establish connection to another node.
setReconnectDelay(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets the amount of time in milliseconds that node waits before retrying to (re)connect to the cluster.
setReconnectThrottlingPeriod(long) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets reconnect throttling period.
setReconnectThrottlingRetries(int) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets reconnect throttling retries.
setReencryptionBatchSize(int) - Method in class org.apache.ignite.configuration.EncryptionConfiguration
Sets the number of pages that is scanned during re-encryption under checkpoint lock.
setReencryptionRateLimit(double) - Method in class org.apache.ignite.configuration.EncryptionConfiguration
Sets re-encryption rate limit.
setRemoteFilter(CacheEntryEventSerializableFilter<K, V>) - Method in class org.apache.ignite.cache.query.ContinuousQuery
setRemoteFilterFactory(Factory<? extends CacheEntryEventFilter<K, V>>) - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Sets optional key-value filter factory.
setRemoteFilterFactory(Factory<? extends CacheEntryEventFilter<K, V>>) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets optional key-value filter factory.
setRemoteTransformerFactory(Factory<? extends IgniteClosure<CacheEntryEvent<? extends K, ? extends V>, T>>) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets transformer factory.
setReplicatedOnly(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Deprecated.
No longer used as of Apache Ignite 2.8.
setReplicatedOnly(boolean) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
No longer used as of Apache Ignite 2.8.
setReplicatedOnly(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setResponseWaitTime(int) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Sets time in milliseconds IP finder waits for reply to multicast address request.
setRetryLimit(int) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets the retry limit.
setRetryPolicy(ClientRetryPolicy) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets the retry policy.
setRollbackOnly() - Method in interface org.apache.ignite.transactions.Transaction
Modify the transaction associated with the current thread such that the only possible outcome of the transaction is to roll back the transaction.
setScanners(UriDeploymentScanner...) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Sets scanners.
setSchema(String) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Set schema for the query.
setSchema(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setSecretKey(String) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets secret key to authenticate REST requests.
setSegmentationPolicy(SegmentationPolicy) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets segmentation policy.
setSegmentationResolveAttempts(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets segmentation resolve attempts count.
setSegmentationResolvers(SegmentationResolver...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets segmentation resolvers.
setSegmentCheckFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets network segment check frequency.
setSelectorCount(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets count of selectors to use in TCP server.
setSelectorCount(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets number of selector threads for REST TCP server.
setSendBufferSize(int) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSendBufferSize(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets REST TCP server send buffer size.
setSendConsistentId(boolean) - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
If true then OpenCensusMetricExporterSpi.CONSISTENT_ID_TAG will be added to each exported measure.
setSendInstanceName(boolean) - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
If true then OpenCensusMetricExporterSpi.INSTANCE_NAME_TAG will be added to each exported measure.
setSendNodeId(boolean) - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
If true then OpenCensusMetricExporterSpi.NODE_ID_TAG will be added to each exported measure.
setSendQueueLimit(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets REST TCP server send queue limit.
setSerializer(BinarySerializer) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Sets serializer.
setSerializer(BinarySerializer) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Sets serializer.
setSerializer(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
setServerToClientExceptionStackTraceSending(boolean) - Method in class org.apache.ignite.configuration.ThinClientConfiguration
 
setService(Service) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets service instance.
setServiceConfiguration(ServiceConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets configurations for services to be deployed on the grid.
setServiceName(String) - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Sets the name of Kubernetes service for Ignite pods' IP addresses lookup.
setServiceName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Deprecated.
set parameters with KubernetesConnectionConfiguration instead.
setServicePermissions(Map<String, Collection<SecurityPermission>>) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set service permission map.
setServiceThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets thread pool size to use within grid.
setSessionOutboundMessageQueueLimit(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets Client session outbound message queue limit.
setSessionTimeout(long) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
Sets shared flag.
setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Sets shared flag.
setShutdownPolicy(ShutdownPolicy) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets shutdown policy.
setSimpleName(boolean) - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
Sets whether to use simple name of class or not.
setSingleton(boolean) - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
 
setSingleTupleExtractor(StreamSingleTupleExtractor<T, K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
 
setSize(int) - Method in class org.apache.ignite.configuration.ExecutorConfiguration
Set thread pool size.
setSkipReducerOnUpdate(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setSnapshotPath(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setSnapshotThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setSocketReceiveBuffer(int) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setSocketReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets socket receive buffer size.
setSocketReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Sets socket receive buffer size.
setSocketReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Sets socket receive buffer size.
setSocketSendBuffer(int) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setSocketSendBufferSize(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets socket send buffer size.
setSocketSendBufferSize(int) - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Sets socket send buffer size.
setSocketSendBufferSize(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Sets socket send buffer size.
setSocketTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets socket operations timeout.
setSoLinger(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets SO_LINGER to use for all created sockets.
setSql(String) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets SQL clause.
setSql(String) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets SQL clause.
setSqlConfiguration(SqlConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
 
setSqlConnectorConfiguration(SqlConnectorConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setSqlEscapeAll(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
setSqlEscapeAll(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
setSqlEscapeAll(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setSqlEscapeAll(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
If true all the SQL table and field names will be escaped with double quotes like ({@code "tableName"."
setSqlFunctionClasses(Class<?>...) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets classes with methods annotated by QuerySqlFunction to be used as user-defined functions from SQL queries.
setSqlIndexMaxInlineSize(int) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setSqlIndexMaxInlineSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum inline size for sql indexes.
setSqlOnheapCacheEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets whether SQL on-heap cache is enabled.
setSqlOnheapCacheMaxSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum SQL on-heap cache.
setSqlQueryHistorySize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setSqlQueryHistorySize(int) - Method in class org.apache.ignite.configuration.SqlConfiguration
Sets number of SQL query history elements kept in memory.
setSqlSchema(String) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setSqlSchema(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets sql schema to be used for current cache.
setSqlSchemas(String...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
setSqlSchemas(String...) - Method in class org.apache.ignite.configuration.SqlConfiguration
Sets SQL schemas to be created on node startup.
setSslClientAuth(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets flag indicating whether or not SSL client authentication is required.
setSslClientAuth(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets flag indicating whether or not SSL client authentication is required.
setSslClientCertificateKeyStorePassword(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslClientCertificateKeyStorePassword(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets key store password.
setSslClientCertificateKeyStorePath(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslClientCertificateKeyStoreType(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslClientCertificateKeyStoreType(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets key store type used in context initialization.
setSslClientCertificateKeyStoreUrl(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets path to the key store file.
setSslContextFactory(Factory<SSLContext>) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslContextFactory(Factory<SSLContext>) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets SSL context factory that will be used for creating a secure socket layer.
setSslContextFactory(Factory<SSLContext>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets SSL context factory that will be used for creating a secure socket layer.
setSslEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets whether Secure Socket Layer should be enabled for client connector.
setSslEnabled(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets whether Secure Socket Layer should be enabled for REST TCP binary protocol.
setSslFactory(Factory<SSLContext>) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets instance of Factory that will be used to create an instance of SSLContext for Secure Socket Layer on TCP binary protocol.
setSslFactory(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets the class name of the custom implementation of the Factory<SSLSocketFactory>.
setSslKeyAlgorithm(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslKeyAlgorithm(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets key manager algorithm that will be used to create a key manager.
setSslMode(SslMode) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslMode(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Use SSL connection to Ignite node.
setSslProtocol(SslProtocol) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslProtocol(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets protocol for secure transport.
setSslTrustAll(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslTrustAll(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets to true to trust any server certificate (revoked, expired or self-signed SSL certificates).
setSslTrustCertificateKeyStorePassword(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslTrustCertificateKeyStorePassword(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets trust store password.
setSslTrustCertificateKeyStorePath(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslTrustCertificateKeyStoreType(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setSslTrustCertificateKeyStoreType(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets trust store type.
setSslTrustCertificateKeyStoreUrl(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Sets path to the trust store file.
setStarvationIncrement(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets value to increment job priority by every time a lower priority job gets behind a higher priority job.
setStarvationIncrement(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Sets value to increment job priority by every time a lower priority job gets behind a higher priority job.
setStarvationPreventionEnabled(boolean) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Sets flag indicating whether job starvation prevention is enabled.
setStarvationPreventionEnabled(boolean) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Sets flag indicating whether job starvation prevention is enabled.
setStatisticsEnabled(boolean) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setStatisticsEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setStatisticsEnabled(boolean) - Method in class org.apache.ignite.services.ServiceConfiguration
Enables or disables statistics for the service.
setStatisticsPrintFrequency(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets statistics print frequency.
setStatus(SpanStatus) - Method in class org.apache.ignite.spi.tracing.NoopSpiSpecificSpan
Explicitly set status for span.
setStatus(SpanStatus) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusSpanAdapter
Explicitly set status for span.
setStatus(SpanStatus) - Method in interface org.apache.ignite.spi.tracing.SpiSpecificSpan
Explicitly set status for span.
setStealingAttributes(Map<String, ? extends Serializable>) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Configuration parameter to enable stealing to/from only nodes that have these attributes set (see ClusterNode.attribute(String) and IgniteConfiguration.getUserAttributes() methods).
setStealingEnabled(boolean) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Gets flag indicating whether this node should attempt to steal jobs from other nodes.
setStealingEnabled(boolean) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Gets flag indicating whether this node should attempt to steal jobs from other nodes.
setStoragePath(String) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a path to the root directory where the Persistent Store will persist data and indexes.
setStoreByValue(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setStoreConcurrentLoadAllThreshold(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets the concurrent load-all threshold used for cases when keys' values are being loaded from CacheStore in parallel.
setStoreKeepBinary(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets keep binary in store flag.
setStreamer(IgniteDataStreamer<K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
 
setStripedPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets striped pool size that should be used for cache requests processing.
setSubIntervals(int) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
setSubIntervals(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
setSwapFilePath(String) - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
Sets a path to the memory-mapped file.
setSwapPath(String) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets a path to the memory-mapped files.
setSystemCacheInitialSize(long) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Sets initial size of a memory region reserved for system cache.
setSystemCacheMaxSize(long) - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
Sets maximum memory region size reserved for system cache.
setSystemDataRegionConfiguration(SystemDataRegionConfiguration) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Overrides configuration of system data region which has been created automatically.
setSystemPermissions(Collection<SecurityPermission>) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set collection system permission.
setSystemRegionInitialSize(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
setSystemRegionMaxSize(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
setSystemThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets system thread pool size to use within grid.
setSystemViewExporterSpi(SystemViewExporterSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets fully configured instances of SystemViewExporterSpi.
setSystemViewRegistry(ReadOnlySystemViewRegistry) - Method in interface org.apache.ignite.spi.systemview.SystemViewExporterSpi
Sets system view registry that SPI should export.
setSystemWorkerBlockedTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets maximum inactivity period for system worker.
setSystemWorkerBlockedTimeout(long) - Method in interface org.apache.ignite.mxbean.FailureHandlingMxBean
 
setTableName(String) - Method in class org.apache.ignite.cache.QueryEntity
Sets table name for this query entity.
setTaskPermissions(Map<String, Collection<SecurityPermission>>) - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Setter for set task permission map.
setTcpNoDelay(boolean) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setTcpNoDelay(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Set TCP NO_DELAY flag.
setTcpNoDelay(boolean) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Set TCP NO_DELAY flag.
setTcpNoDelay(boolean) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setTemporaryDirectoryPath(String) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Sets absolute path to temporary directory which will be used by deployment SPI to keep all deployed classes in.
setText(String) - Method in class org.apache.ignite.cache.query.TextQuery
Sets text search string.
setThinClientConfiguration(ThinClientConfiguration) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets thin-client specific configuration.
setThinClientEnabled(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets whether access through thin client is enabled.
setThreadCount(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets thread count for warmup.
setThreadedQueryInitiatorId(String) - Static method in class org.apache.ignite.cache.query.SqlFieldsQuery
Used at the Job worker to setup originator by default for current thread.
setThreadPoolSize(int) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets thread pool that is in charge of processing client requests.
setThreadPoolSize(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
Sets thread pool size to use for processing of client messages (REST requests).
setThreadPoolSize(int) - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
Sets thread pool that is in charge of processing ODBC tasks.
setThreadPoolSize(int) - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Sets thread pool that is in charge of processing SQL requests.
setThreadPriority(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets thread priority.
setThreads(int) - Method in class org.apache.ignite.stream.socket.SocketStreamer
Sets threadds amount.
setThreadsCount(int) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
Sets number of worker threads.
setTimeInterval(long) - Method in class org.apache.ignite.cache.query.AbstractContinuousQuery
Sets time interval.
setTimeInterval(long) - Method in class org.apache.ignite.cache.query.ContinuousQuery
Sets time interval.
setTimeInterval(long) - Method in class org.apache.ignite.cache.query.ContinuousQueryWithTransformer
Sets time interval.
setTimeout(int, TimeUnit) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets the query execution timeout.
setTimeout(int, TimeUnit) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets the query execution timeout.
setTimeout(int) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setTimeServerPortBase(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets time server port base.
setTimeServerPortRange(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets time server port range.
setTimeToLive(int) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Set the default time-to-live for multicast packets sent out on this IP finder in order to control the scope of the multicast.
setTlbSize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
setTopHistorySize(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Sets size of topology snapshots history.
setTopologyValidator(TopologyValidator) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets topology validator.
setTotalCount(int) - Method in class org.apache.ignite.services.ServiceConfiguration
Sets total number of deployed service instances in the cluster, 0 for unlimited.
setTracingSpi(TracingSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Set fully configured instance of TracingSpi.
setTransactionConfiguration(ClientTransactionConfiguration) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets transactions configuration.
setTransactionConfiguration(TransactionConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets transactions configuration.
setTransactionManagerLookupClassName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
setTransactionTimeDumpSamplesCoefficient(double) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Sets the coefficient for samples of completed transactions that will be dumped in log.
setTransactionTimeDumpSamplesPerSecondLimit(int) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Sets the limit of samples of completed transactions that will be dumped in log per second, if TransactionsMXBean.getTransactionTimeDumpSamplesCoefficient() is above 0.0.
setTransformer(JdbcTypesTransformer) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Sets types transformer.
setTransformer(JdbcTypesTransformer) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets types transformer.
setTrustManagers(TrustManager...) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets pre-configured trust managers.
setTrustStoreFilePath(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets path to the trust store file.
setTrustStorePassword(char[]) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets trust store password.
setTrustStoreType(String) - Method in class org.apache.ignite.ssl.SslContextFactory
Sets trust store type used in context initialization.
setTupleExtractor(StreamTupleExtractor<T, K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
Deprecated.
setTxKeyCollisionsInterval(int) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Set timeout interval for tx key contention analysis.
setTxManagerFactory(Factory<T>) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets transaction manager factory for available javax.transaction.TransactionManager implementation, if any.
setTxManagerLookupClassName(String) - Method in class org.apache.ignite.configuration.TransactionConfiguration
setTxOwnerDumpRequestsAllowed(boolean) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Sets if dump requests from local node to near node are allowed, when long running transaction is found.
setTxSerializableEnabled(boolean) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Deprecated.
This method has no effect, TransactionIsolation.SERIALIZABLE isolation is always enabled.
setTxTimeoutOnPartitionMapExchange(long) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets the transaction timeout that will be enforced if the partition map exchange process starts.
setTxTimeoutOnPartitionMapExchange(long) - Method in interface org.apache.ignite.IgniteCluster
Sets transaction timeout on partition map exchange.
setTxTimeoutOnPartitionMapExchange(long) - Method in interface org.apache.ignite.mxbean.TransactionsMXBean
Sets transaction timeout on partition map exchange.
setType(String) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Sets type for query.
setType(Class<?>) - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
 
setType(Class<?>) - Method in class org.apache.ignite.cache.query.TextQuery
Sets type for query.
setType(String) - Method in class org.apache.ignite.cache.query.TextQuery
Sets type for query.
setTypeConfigurations(Collection<BinaryTypeConfiguration>) - Method in class org.apache.ignite.configuration.BinaryConfiguration
Sets type configurations.
setTypeName(String) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
Sets type name.
setTypeName(String) - Method in class org.apache.ignite.cache.CacheKeyConfiguration
 
setTypeName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Sets .NET type name.
setTypeName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
 
setTypeName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
Sets .NET type name.
setTypeName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
Set type name.
setTypes(JdbcType...) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Sets store configurations.
setTypes(JdbcType...) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
Sets store configurations.
setTypes(Class<K>, Class<V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
setTypes(Collection<String>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
setTypesConfiguration(Collection<PlatformDotNetBinaryTypeConfiguration>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
 
setUpdateBatchSize(int) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
Sets update internal bach size.
setUpdateQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets update entry query.
setUpdateQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets update entry query.
setUriList(List<String>) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Sets list of URI which point to a directory with packages and which should be scanned by SPI for the new tasks.
setURL(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
Different application servers us different format (URL & url).
setUrl(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setUseAverage(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Sets flag indicating whether to use average CPU load vs. current.
setUseAverage(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
Sets flag indicating whether to use average job counts vs. current.
setUseAverage(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
Sets flag indicating whether to use average execution time vs. current.
setUseIgniteSslContextFactory(boolean) - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
Sets whether to use Ignite SSL context factory.
setUseJtaSynchronization(boolean) - Method in class org.apache.ignite.configuration.TransactionConfiguration
Sets the flag that defines whether to use lightweight JTA synchronization callback to enlist into JTA transaction instead of creating a separate XA resource.
setUseProcessors(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
Sets flag indicating whether to use average CPU load vs. current (default is true).
setUser(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Sets user name for database access.
setUser(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
Sets user name for database access.
setUser(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint database user name.
setUserAttributes(Map<String, String>) - Method in class org.apache.ignite.configuration.ClientConfiguration
Sets user attributes which can be used to send additional info to the server nodes.
setUserAttributes(Map<String, ?>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets user attributes for this node.
setUserName(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setUsername(String) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
 
setUserObject(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
Sets user-specific object.
setUserPassword(String) - Method in class org.apache.ignite.configuration.ClientConfiguration
 
setUseWeights(boolean) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
Sets a flag to indicate whether node weights should be checked when doing random load balancing.
setUtilityCacheKeepAliveTime(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets keep alive time of thread pool size that will be used to process utility cache messages.
setUtilityCachePoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets default thread pool size that will be used to process utility cache messages.
setValidationEnabled(boolean) - Method in class org.apache.ignite.configuration.SqlConfiguration
Enable/disable key & value validation.
setValue(V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
setValueFieldName(String) - Method in class org.apache.ignite.cache.QueryEntity
Sets value field name.
setValueFieldName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint value field name.
setValueFields(JdbcTypeField...) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets optional persistent value fields (needed only if CacheJdbcPojoStore is used).
setValueFieldType(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
Sets checkpoint value field type.
setValueType(String) - Method in class org.apache.ignite.cache.QueryEntity
Sets value type for this query pair.
setValueType(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets value type.
setValueType(Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
Sets value type.
setValueTypeName(String) - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
Sets fully-qualified platform type name of the cache value used for the local map.
SetView - Class in org.apache.ignite.spi.systemview.view.datastructures
Set representation for a SystemView.
SetView(GridCacheSetProxy<?>) - Constructor for class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
setWaitForSegmentOnStart(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets wait for segment on start flag.
setWaitingJobsNumber(int) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
Sets maximum number of jobs that are allowed to wait in waiting queue.
setWaitingJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
Sets maximum number of jobs that are allowed to wait in waiting queue.
setWaitingJobsNumber(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
Maximum number of jobs that are allowed to wait in waiting queue.
setWaitingJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
Maximum number of jobs that are allowed to wait in waiting queue.
setWaitJobsThreshold(int) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Sets job count threshold at which this node will start stealing jobs from other nodes.
setWaitJobsThreshold(int) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
Sets job count threshold at which this node will start stealing jobs from other nodes.
setWalArchivePath(String) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a path for the WAL archive directory.
setWalArchivePath(String) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a path for the WAL archive directory.
setWalAutoArchiveAfterInactivity(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Note: setting this value with WALMode.FSYNC may generate file size overhead for WAL segments in case grid is used rarely.
setWalAutoArchiveAfterInactivity(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Note: setting this value with WALMode.FSYNC may generate file size overhead for WAL segments in case grid is used rarely.
setWalBufferSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Property defines size(in bytes) of WAL buffer.
setWalBufferSize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
setWalCompactionEnabled(boolean) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets flag indicating whether WAL compaction is enabled.
setWalCompactionLevel(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
setWalCompactionLevel(int) - Method in interface org.apache.ignite.mxbean.DataStorageMXBean
Sets ZIP compression level to WAL compaction.
setWalFlushFrequency(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
This property define how often WAL will be fsync-ed in BACKGROUND mode.
setWalFlushFrequency(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
This property define how often WAL will be fsync-ed in BACKGROUND mode.
setWalForceArchiveTimeout(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
 
setWalFsyncDelayNanos(long) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets property that allows to trade latency for throughput in WALMode.FSYNC mode.
setWalFsyncDelayNanos(long) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
setWalHistorySize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Deprecated.
Instead of walHistorySize use maxWalArchiveSize for manage of archive size.
setWalHistorySize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a total number of checkpoints to keep in the WAL history.
setWalMode(WALMode) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets property that defines behavior of wal fsync.
setWalMode(WALMode) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
setWalPageCompression(DiskPageCompression) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets compression algorithm for WAL page snapshot records.
setWalPageCompressionLevel(Integer) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets algorithm specific page compression level.
setWalPath(String) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a path to the directory where WAL is stored.
setWalRecordIteratorBufferSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets property defining how many bytes iterator read from disk (for one reading), during go ahead wal.
setWalRecordIteratorBufferSize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
 
setWalSegments(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets a number of WAL segments to work with.
setWalSegments(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a number of WAL segments to work with.
setWalSegmentSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets size(in bytes) of a WAL segment.
setWalSegmentSize(int) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets size of a WAL segment.
setWalStorePath(String) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets a path to the directory where WAL is stored .
setWalThreadLocalBufferSize(int) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets size of thread local buffer.
setWarmupClosure(IgniteInClosure<IgniteConfiguration>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets warmup closure to execute before grid startup.
setWarmUpConfiguration(WarmUpConfiguration) - Method in class org.apache.ignite.configuration.DataRegionConfiguration
Sets warm-up configuration.
setWarmupMethods(String...) - Method in class org.apache.ignite.startup.BasicWarmupClosure
Sets warmup methods to use for cache warmup.
setWorkDirectory(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
Sets Ignite work folder.
setWorkDirectory(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Set work directory.
setWriteBehindBatchSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets maximum batch size for write-behind cache.
setWriteBehindCoalescing(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets write coalescing flag for write-behind cache.
setWriteBehindEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets flag indicating whether write-behind is enabled.
setWriteBehindFlushFrequency(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets write-behind flush frequency.
setWriteBehindFlushSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets write-behind flush size.
setWriteBehindFlushThreadCount(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets flush thread count for write-behind cache.
setWriteSynchronizationMode(CacheWriteSynchronizationMode) - Method in class org.apache.ignite.client.ClientCacheConfiguration
 
setWriteSynchronizationMode(CacheWriteSynchronizationMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
Sets write synchronization mode.
setWriteThrottlingEnabled(boolean) - Method in class org.apache.ignite.configuration.DataStorageConfiguration
Sets flag indicating whether write throttling is enabled.
setWriteThrottlingEnabled(boolean) - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
Sets flag indicating whether write throttling is enabled.
setWriteThrough(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
setZkConnectionString(String) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
setZkRootPath(String) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
SharedFsCheckpointSpi - Class in org.apache.ignite.spi.checkpoint.sharedfs
This class defines shared file system CheckpointSpi implementation for checkpoint SPI.
SharedFsCheckpointSpi() - Constructor for class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
Initializes default directory paths.
SharedFsCheckpointSpiMBean - Interface in org.apache.ignite.spi.checkpoint.sharedfs
Management bean that provides general administrative and configuration information about shared file system checkpoints.
shortDisplay() - Method in class org.apache.ignite.events.CacheEvent
Gets a shortened version of toString() result.
shortDisplay() - Method in class org.apache.ignite.events.CacheRebalancingEvent
Gets a shortened version of toString() result.
shortDisplay() - Method in class org.apache.ignite.events.CheckpointEvent
Gets a shortened version of toString() result.
shortDisplay() - Method in class org.apache.ignite.events.DeploymentEvent
Gets a shortened version of toString() result.
shortDisplay() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets a shortened version of toString() result.
shortDisplay() - Method in interface org.apache.ignite.events.Event
Gets a shortened version of toString() result.
shortDisplay() - Method in class org.apache.ignite.events.EventAdapter
Gets a shortened version of toString() result.
shortDisplay() - Method in class org.apache.ignite.events.JobEvent
Gets a shortened version of toString() result.
shortDisplay() - Method in class org.apache.ignite.events.TaskEvent
Gets a shortened version of toString() result.
shortString() - Method in class org.apache.ignite.lang.IgniteUuid
Gets a short string version of this ID.
shouldProceedWithMaintenance() - Method in interface org.apache.ignite.maintenance.MaintenanceWorkflowCallback
Called by MaintenanceRegistry and enables it to check if maintenance is still needed for component that provided this callback.
shouldRetry(ClientRetryPolicyContext) - Method in class org.apache.ignite.client.ClientRetryAllPolicy
Gets a value indicating whether a client operation that has failed due to a connection issue should be retried.
shouldRetry(ClientRetryPolicyContext) - Method in class org.apache.ignite.client.ClientRetryNonePolicy
Gets a value indicating whether a client operation that has failed due to a connection issue should be retried.
shouldRetry(ClientRetryPolicyContext) - Method in interface org.apache.ignite.client.ClientRetryPolicy
Gets a value indicating whether a client operation that has failed due to a connection issue should be retried.
shouldRetry(ClientRetryPolicyContext) - Method in class org.apache.ignite.client.ClientRetryReadPolicy
Gets a value indicating whether a client operation that has failed due to a connection issue should be retried.
showFullStackOnClientSide(boolean) - Method in interface org.apache.ignite.mxbean.ClientProcessorMXBean
Deprecated.
If sets to true shows full stack trace otherwise highlevel short error message.
shrink() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
Shrinks backed container to maximum allowed size.
shrink0() - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
 
shrink0() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
Tries to remove one item from queue.
shrink0() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
Tries to remove one item from queue.
shrink0() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Tries to remove one item from queue.
shutdown - Variable in class org.apache.ignite.configuration.IgniteConfiguration
Shutdown policy for cluster.
shutdown() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
shutdownNow() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
shutdownPolicy() - Method in interface org.apache.ignite.IgniteCluster
Returns a policy of shutdown or default value IgniteConfiguration.DFLT_SHUTDOWN_POLICY if the property is not set.
shutdownPolicy(ShutdownPolicy) - Method in interface org.apache.ignite.IgniteCluster
Sets a shutdown policy on a cluster.
ShutdownPolicy - Enum in org.apache.ignite
This class reperesents a policy of shutdown.
signal() - Method in interface org.apache.ignite.IgniteCondition
Wakes up one waiting thread.
signalAll() - Method in interface org.apache.ignite.IgniteCondition
Wakes up all waiting threads.
simulateNodeFailure() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Deprecated.
you should you DI and get instances of [nioSrvWrapper, commWorker, clientPool] via it.
simulateNodeFailure() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
For TESTING only.
simulateNodeFailure() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST ONLY!!!
simulateNodeFailure() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
For TESTING only.
size() - Method in interface org.apache.ignite.binary.BinaryObject
Get the size of the object
size() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
Returns entry size in bytes.
size(CachePeekMode...) - Method in interface org.apache.ignite.client.ClientCache
Gets the number of all entries cached across all nodes.
size() - Method in interface org.apache.ignite.client.ClientIgniteSet
size(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached across all nodes.
size() - Method in interface org.apache.ignite.IgniteQueue
size() - Method in interface org.apache.ignite.IgniteSet
size() - Method in class org.apache.ignite.lang.IgniteBiTuple
size() - Method in class org.apache.ignite.spi.systemview.view.datastructures.QueueView
 
size() - Method in class org.apache.ignite.spi.systemview.view.datastructures.SetView
 
size() - Method in interface org.apache.ignite.spi.systemview.view.SystemView
 
SIZE_IN_BYTES - Static variable in class org.apache.ignite.lang.IgniteProductVersion
Size in bytes of serialized: 3 bytes (maj, min, maintenance version), 8 bytes - timestamp
sizeAsync(CachePeekMode...) - Method in interface org.apache.ignite.client.ClientCache
Gets the number of all entries cached across all nodes.
sizeAsync(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets the number of all entries cached across all nodes.
sizeLong(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached across all nodes as a long value.
sizeLong(int, CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Gets the number of all entries cached in a partition as a long value.
sizeLongAsync(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets the number of all entries cached across all nodes as a long value.
sizeLongAsync(int, CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
Asynchronously gets the number of all entries cached in a partition as a long value.
skip() - Method in class org.apache.ignite.messaging.MessagingListenActor
Skips current message and continues to listen for new message.
skipCopies() - Method in class org.apache.ignite.dump.DumpReaderConfiguration
 
skipStore() - Method in interface org.apache.ignite.IgniteDataStreamer
Gets flag indicating that write-through behavior should be disabled for data streaming.
skipStore(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets flag indicating that write-through behavior should be disabled for data streaming.
Slf4jLogger - Class in org.apache.ignite.logger.slf4j
SLF4J-based implementation for logging.
Slf4jLogger() - Constructor for class org.apache.ignite.logger.slf4j.Slf4jLogger
Creates new logger.
Slf4jLogger(Logger) - Constructor for class org.apache.ignite.logger.slf4j.Slf4jLogger
Creates new logger with given implementation.
snapshot() - Method in interface org.apache.ignite.Ignite
 
snapshot() - Method in class org.apache.ignite.IgniteSpringBean
snapshot() - Static method in class org.apache.ignite.IgniteSystemProperties
Gets snapshot of system properties.
SNAPSHOT_SYS_VIEW - Static variable in class org.apache.ignite.spi.systemview.view.SnapshotView
Snapshot system view name.
SNAPSHOT_SYS_VIEW_DESC - Static variable in class org.apache.ignite.spi.systemview.view.SnapshotView
Snapshot system view description.
SnapshotEvent - Class in org.apache.ignite.events
Event indicating the cluster snapshot operation result state with the given name.
SnapshotEvent(ClusterNode, String, String, int) - Constructor for class org.apache.ignite.events.SnapshotEvent
 
SnapshotMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use managements API beans, instead.
snapshotName() - Method in class org.apache.ignite.events.SnapshotEvent
 
snapshotRecordSegment() - Method in class org.apache.ignite.spi.systemview.view.SnapshotView
 
SnapshotView - Class in org.apache.ignite.spi.systemview.view
Snapshot representation for a SystemView.
SnapshotView(SnapshotMetadata, Collection<String>) - Constructor for class org.apache.ignite.spi.systemview.view.SnapshotView
 
SnapshotView(IncrementalSnapshotMetadata) - Constructor for class org.apache.ignite.spi.systemview.view.SnapshotView
 
sndMsgLsnrs - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
SocketMessageConverter<T> - Interface in org.apache.ignite.stream.socket
Socket message converter.
SocketStreamer<T,K,V> - Class in org.apache.ignite.stream.socket
Server that receives data from TCP socket, converts it to key-value pairs using StreamTupleExtractor and streams into IgniteDataStreamer instance.
SocketStreamer() - Constructor for class org.apache.ignite.stream.socket.SocketStreamer
 
SortedEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction.sorted
Cache eviction policy which will select the minimum cache entry for eviction.
SortedEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Constructs sorted eviction policy with all defaults.
SortedEvictionPolicy(int) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Constructs sorted eviction policy with maximum size.
SortedEvictionPolicy(int, Comparator<EvictableEntry<K, V>>) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Constructs sorted eviction policy with given maximum size and given entry comparator.
SortedEvictionPolicy(int, int, Comparator<EvictableEntry<K, V>>) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Constructs sorted eviction policy with given maximum size, eviction batch size and entries comparator.
SortedEvictionPolicy(Comparator<EvictableEntry<K, V>>) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
Constructs sorted eviction policy with given maximum size and given entry comparator.
SortedEvictionPolicyFactory<K,V> - Class in org.apache.ignite.cache.eviction.sorted
Factory class for SortedEvictionPolicy.
SortedEvictionPolicyFactory() - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
 
SortedEvictionPolicyFactory(int) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
 
SortedEvictionPolicyFactory(int, int, long) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyFactory
 
SortedEvictionPolicyMBean - Interface in org.apache.ignite.cache.eviction.sorted
MBean for sorted eviction policy.
span() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets span instance.
span(Span) - Method in class org.apache.ignite.events.DiscoveryEvent
Set span.
SpanStatus - Enum in org.apache.ignite.spi.tracing
Various statuses for Spans execution.
spiAdapter - Variable in class org.apache.ignite.spi.IgniteSpiMBeanAdapter
 
spiContext() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
 
spiCtx - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
SpiQuery<K,V> - Class in org.apache.ignite.cache.query
Query to be used by IndexingSpi implementations.
SpiQuery() - Constructor for class org.apache.ignite.cache.query.SpiQuery
 
SpiSpecificSpan - Interface in org.apache.ignite.spi.tracing
Logical piece of a trace that insulates spi specific logic.
spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.eventstorage.NoopEventStorageSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
This method is called to start SPI.
spiStart(String) - Method in interface org.apache.ignite.spi.IgniteSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.metric.jmx.JmxMetricExporterSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.metric.noop.NoopMetricExporterSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.metric.opencensus.OpenCensusMetricExporterSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
This method is called to start SPI.
spiStart(String) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
This method is called to start SPI.
spiStop() - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.encryption.keystore.KeystoreEncryptionSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.eventstorage.NoopEventStorageSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
This method is called to stop SPI.
spiStop() - Method in interface org.apache.ignite.spi.IgniteSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.metric.jmx.JmxMetricExporterSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.metric.noop.NoopMetricExporterSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
This method is called to stop SPI.
spiStop() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
This method is called to stop SPI.
split(int, T) - Method in class org.apache.ignite.compute.ComputeTaskSplitAdapter
This is a simplified version of ComputeTask.map(List, Object) method.
SpringApplicationContextResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of Spring ApplicationContext resource.
SpringResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of resource from Spring ApplicationContext.
SpringResource.DEFAULT - Class in org.apache.ignite.resources
Dummy class to compensate for impossibility of having default null value for annotation method.
sql() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
sql() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
SqlConfiguration - Class in org.apache.ignite.configuration
The configuration of the SQL query subsystem.
SqlConfiguration() - Constructor for class org.apache.ignite.configuration.SqlConfiguration
 
SqlConnectorConfiguration - Class in org.apache.ignite.configuration
Deprecated.
SqlConnectorConfiguration() - Constructor for class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Creates SQL connector configuration with all default values.
SqlConnectorConfiguration(SqlConnectorConfiguration) - Constructor for class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
Creates SQL connector configuration by copying all properties from given configuration.
SqlFieldsQuery - Class in org.apache.ignite.cache.query
SQL Fields query.
SqlFieldsQuery(SqlFieldsQuery) - Constructor for class org.apache.ignite.cache.query.SqlFieldsQuery
Copy constructs SQL fields query.
SqlFieldsQuery(String) - Constructor for class org.apache.ignite.cache.query.SqlFieldsQuery
Constructs SQL fields query.
SqlFieldsQuery(String, boolean) - Constructor for class org.apache.ignite.cache.query.SqlFieldsQuery
Constructs SQL fields query.
sqlIndexMaxInlineSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
SqlIndexView - Class in org.apache.ignite.spi.systemview.view.sql
Sql index representation for a SystemView.
SqlIndexView(TableDescriptor, IndexDescriptor) - Constructor for class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
 
sqlOnheapCacheMaxSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
SqlQuery<K,V> - Class in org.apache.ignite.cache.query
Deprecated.
Since 2.8, please use SqlFieldsQuery instead.
SqlQuery(String, String) - Constructor for class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Constructs query for the given type name and SQL query.
SqlQuery(Class<?>, String) - Constructor for class org.apache.ignite.cache.query.SqlQuery
Deprecated.
Constructs query for the given type and SQL query.
SqlQueryExecutionEvent - Class in org.apache.ignite.events
Query execution event.
SqlQueryExecutionEvent(ClusterNode, String, String, Object[], UUID) - Constructor for class org.apache.ignite.events.SqlQueryExecutionEvent
 
SqlQueryHistoryView - Class in org.apache.ignite.spi.systemview.view
SQL query history representation for a SystemView.
SqlQueryHistoryView(QueryHistory) - Constructor for class org.apache.ignite.spi.systemview.view.SqlQueryHistoryView
 
SqlQueryView - Class in org.apache.ignite.spi.systemview.view
SQL query representation for a SystemView.
SqlQueryView(GridRunningQueryInfo) - Constructor for class org.apache.ignite.spi.systemview.view.SqlQueryView
 
sqlSchema() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
SqlSchemaView - Class in org.apache.ignite.spi.systemview.view.sql
Sql schema system view representation.
SqlSchemaView(SchemaDescriptor) - Constructor for class org.apache.ignite.spi.systemview.view.sql.SqlSchemaView
 
SQLServerDialect - Class in org.apache.ignite.cache.store.jdbc.dialect
A dialect compatible with the Microsoft SQL Server database.
SQLServerDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
 
SqlTableColumnView - Class in org.apache.ignite.spi.systemview.view.sql
Sql table column representation for a SystemView.
SqlTableColumnView(TableDescriptor, GridQueryProperty) - Constructor for class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
SqlTableView - Class in org.apache.ignite.spi.systemview.view.sql
Sql table representation for a SystemView.
SqlTableView(TableDescriptor) - Constructor for class org.apache.ignite.spi.systemview.view.sql.SqlTableView
 
SqlViewColumnView - Class in org.apache.ignite.spi.systemview.view.sql
Sql view column representation for a SystemView.
SqlViewColumnView(SystemView<?>, Map.Entry<String, Class<?>>) - Constructor for class org.apache.ignite.spi.systemview.view.sql.SqlViewColumnView
 
SqlViewView - Class in org.apache.ignite.spi.systemview.view.sql
Sql view representation for a SystemView.
SqlViewView(SystemView<?>) - Constructor for class org.apache.ignite.spi.systemview.view.sql.SqlViewView
 
SslContextFactory - Class in org.apache.ignite.ssl
SSL context factory that provides SSL context configuration with specified key and trust stores.
SslContextFactory() - Constructor for class org.apache.ignite.ssl.SslContextFactory
 
SSLContextWrapper - Class in org.apache.ignite.ssl
Wrapper for SSLContext that extend source context with custom SSL parameters.
SSLContextWrapper(SSLContext, SSLParameters) - Constructor for class org.apache.ignite.ssl.SSLContextWrapper
 
sslCtx - Variable in class org.apache.ignite.ssl.AbstractSslContextFactory
Cached instance of an SSLContext.
sslEnable - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
SSL enable/disable flag.
SslMode - Enum in org.apache.ignite.client
SSL/TLS modes.
SslProtocol - Enum in org.apache.ignite.client
SSL Protocol.
sslSockFactory - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
SSL socket factory.
sslSrvSockFactory - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
SSL server socket factory.
stage() - Method in class org.apache.ignite.lang.IgniteProductVersion
 
stamp() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets current stamp.
stamp() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicStampedView
 
start() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Starts grid component, called on grid start.
start() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
Starts grid component, called on grid start.
start(MetricRegistry) - Method in interface org.apache.ignite.cdc.CdcConsumer
Starts the consumer.
start() - Method in interface org.apache.ignite.dump.DumpConsumer
Starts the consumer.
start() - Method in class org.apache.ignite.IgniteClientSpringBean
start(ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
Starts grid with default configuration.
start(IgniteConfiguration, ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
Starts grid with given configuration.
start(String, ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
Starts all grids specified within given Spring XML configuration file.
start(URL, ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
Starts all grids specified within given Spring XML configuration file URL.
start() - Static method in class org.apache.ignite.Ignition
Starts grid with default configuration.
start(IgniteConfiguration) - Static method in class org.apache.ignite.Ignition
Starts grid with given configuration.
start(String) - Static method in class org.apache.ignite.Ignition
Starts all grids specified within given Spring XML configuration file.
start(URL) - Static method in class org.apache.ignite.Ignition
Starts all grids specified within given Spring XML configuration file URL.
start(InputStream) - Static method in class org.apache.ignite.Ignition
Starts all grids specified within given Spring XML configuration input stream.
start() - Method in interface org.apache.ignite.lifecycle.LifecycleAware
Starts grid component, called on grid start.
start() - Method in interface org.apache.ignite.mxbean.PerformanceStatisticsMBean
Deprecated.
Start collecting performance statistics in the cluster.
start() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Starts grid component, called on grid start.
start() - Method in interface org.apache.ignite.plugin.CachePluginProvider
Starts grid component.
start(PluginContext) - Method in interface org.apache.ignite.plugin.PluginProvider
Starts grid component.
start(String) - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTraceExporter
Starts trace exporter on given node with name igniteInstanceName.
start() - Method in class org.apache.ignite.stream.socket.SocketStreamer
Starts streamer.
START_TIMESTAMP_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
START_TIMESTAMP_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
startClient(ClientConfiguration) - Static method in class org.apache.ignite.Ignition
Initializes new instance of IgniteClient.
started() - Method in interface org.apache.ignite.mxbean.PerformanceStatisticsMBean
Deprecated.
 
started() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Checks if IgniteSpiAdapter.onBeforeStart() has been called on this SPI instance.
startedCaches() - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
startInfo() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets uniformly formatted message for SPI start.
startMessageProcess(TcpDiscoveryAbstractMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
startNodes(File, boolean, int, int) - Method in interface org.apache.ignite.IgniteCluster
Starts one or more nodes on remote host(s).
startNodes(Collection<Map<String, Object>>, Map<String, Object>, boolean, int, int) - Method in interface org.apache.ignite.IgniteCluster
Starts one or more nodes on remote host(s).
startNodesAsync(File, boolean, int, int) - Method in interface org.apache.ignite.IgniteCluster
Starts one or more nodes on remote host(s) asynchronously.
startNodesAsync(Collection<Map<String, Object>>, Map<String, Object>, boolean, int, int) - Method in interface org.apache.ignite.IgniteCluster
Starts one or more nodes on remote host(s) asynchronously.
startStopwatch() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Starts startup stopwatch.
startTime() - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Deprecated.
Get defragmentation's start time.
startTime() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
startTime() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
startTime() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
startTime() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
startTime() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
startTime() - Method in interface org.apache.ignite.transactions.Transaction
Start time of this transaction.
state() - Method in interface org.apache.ignite.client.ClientCluster
Gets current cluster state.
state(ClusterState) - Method in interface org.apache.ignite.client.ClientCluster
Changes current cluster state to given newState cluster state.
state() - Method in class org.apache.ignite.events.ClusterStateChangeEvent
 
state() - Method in class org.apache.ignite.events.ClusterStateChangeStartedEvent
 
state() - Method in interface org.apache.ignite.IgniteCluster
Gets current cluster state.
state(ClusterState) - Method in interface org.apache.ignite.IgniteCluster
Changes current cluster state to given newState cluster state.
state() - Static method in class org.apache.ignite.Ignition
Gets state of grid default grid.
state(String) - Static method in class org.apache.ignite.Ignition
Gets states of named Ignite instance.
state() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
Gets current read state.
state() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Gets current message state.
state() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
state() - Method in class org.apache.ignite.spi.systemview.view.PartitionStateView
 
state() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
state() - Method in interface org.apache.ignite.transactions.Transaction
Gets current transaction state value.
staticallyConfigured() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
stats - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Statistics.
statsPrintFreq - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Statistics print frequency.
status() - Method in interface org.apache.ignite.mxbean.SnapshotMXBean
Deprecated.
Get the status of the current snapshot operation in the cluster.
StatusMatchTable - Class in org.apache.ignite.spi.tracing.opencensus
Table to match OpenCensus span statuses with declared in Tracing SPI.
STEALING_ATTEMPT_COUNT_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Name of job context attribute containing current stealing attempt count.
STEALING_PRIORITY_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Stealing priority attribute name.
stop() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
Stops grid component, called on grid shutdown.
stop() - Method in interface org.apache.ignite.cdc.CdcConsumer
Stops the consumer.
stop() - Method in interface org.apache.ignite.dump.DumpConsumer
Stops the consumer.
stop(Runnable) - Method in class org.apache.ignite.IgniteClientSpringBean
stop() - Method in class org.apache.ignite.IgniteClientSpringBean
stop(boolean) - Static method in class org.apache.ignite.Ignition
Stops default grid.
stop(String, boolean) - Static method in class org.apache.ignite.Ignition
Stops named Ignite instance.
stop() - Method in interface org.apache.ignite.lifecycle.LifecycleAware
Stops grid component, called on grid shutdown.
stop() - Method in class org.apache.ignite.messaging.MessagingListenActor
This method instructs underlying implementation to stop receiving new messages and unregister the message listener.
stop(Object) - Method in class org.apache.ignite.messaging.MessagingListenActor
This method sends the response message to the original sender node and instructs underlying implementation to stop receiving new messages and unregister the message listener.
stop(boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Stops default grid instance.
stop(String, boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Stops named Ignite instance.
stop() - Method in interface org.apache.ignite.mxbean.PerformanceStatisticsMBean
Deprecated.
Stop collecting performance statistics in the cluster.
stop() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
Stops grid component, called on grid shutdown.
stop(boolean) - Method in interface org.apache.ignite.plugin.CachePluginProvider
Stops grid component.
stop(boolean) - Method in interface org.apache.ignite.plugin.PluginProvider
Stops grid component.
stop() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTraceExporter
Stops trace exporter.
stop() - Method in class org.apache.ignite.stream.socket.SocketStreamer
Stops streamer.
stopAll(boolean) - Static method in class org.apache.ignite.Ignition
Stops all started grids in current JVM.
stopAll(boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
Stops all started grids.
stopInfo() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Gets uniformly format message for SPI stop.
stopLocalListen(IgnitePredicate<? extends Event>, int...) - Method in interface org.apache.ignite.IgniteEvents
Removes local event listener.
stopLocalListen(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.IgniteMessaging
Unregisters local listener for given topic on local node only.
StopNodeFailureHandler - Class in org.apache.ignite.failure
Handler will stop node in case of critical error using IgnitionEx.stop(nodeName, true, true) call.
StopNodeFailureHandler() - Constructor for class org.apache.ignite.failure.StopNodeFailureHandler
 
StopNodeOrHaltFailureHandler - Class in org.apache.ignite.failure
Handler will try to stop node if tryStop value is true.
StopNodeOrHaltFailureHandler() - Constructor for class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
Default constructor.
StopNodeOrHaltFailureHandler(boolean, long) - Constructor for class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
 
stopNodes() - Method in interface org.apache.ignite.IgniteCluster
Stops nodes satisfying optional set of predicates.
stopNodes(Collection<UUID>) - Method in interface org.apache.ignite.IgniteCluster
Stops nodes defined by provided IDs.
stopProcess() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiCustomMessage
Called on discovery coordinator node after listener is notified.
stopRemoteListen(UUID) - Method in interface org.apache.ignite.IgniteEvents
Stops listening to remote events.
stopRemoteListen(UUID) - Method in interface org.apache.ignite.IgniteMessaging
Unregisters all listeners identified with provided operation ID on all nodes in the cluster group.
stopRemoteListenAsync(UUID) - Method in interface org.apache.ignite.IgniteEvents
Asynchronously stops listening to remote events.
stopRemoteListenAsync(UUID) - Method in interface org.apache.ignite.IgniteMessaging
Asynchronously unregisters all listeners identified with provided operation ID on all nodes in the cluster group.
stopThreadById(long) - Method in interface org.apache.ignite.mxbean.WorkersControlMXBean
Stops thread by id, if exists.
stopThreadByUniqueName(String) - Method in interface org.apache.ignite.mxbean.WorkersControlMXBean
Stops thread by name, if exists and unique.
stopWarmUp() - Method in interface org.apache.ignite.mxbean.WarmUpMXBean
Deprecated.
Stop warm-up.
store(String, Object, Object, long) - Method in interface org.apache.ignite.spi.indexing.IndexingSpi
Updates index.
store(String, Object, Object, long) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
Updates index.
StreamAdapter<T,K,V> - Class in org.apache.ignite.stream
Convenience adapter for streamers.
StreamAdapter() - Constructor for class org.apache.ignite.stream.StreamAdapter
Empty constructor.
StreamAdapter(IgniteDataStreamer<K, V>, StreamSingleTupleExtractor<T, K, V>) - Constructor for class org.apache.ignite.stream.StreamAdapter
Stream adapter.
StreamAdapter(IgniteDataStreamer<K, V>, StreamMultipleTupleExtractor<T, K, V>) - Constructor for class org.apache.ignite.stream.StreamAdapter
Stream adapter.
StreamMultipleTupleExtractor<T,K,V> - Interface in org.apache.ignite.stream
Stream tuple extractor to convert a single message to zero, one or many tuples.
StreamReceiver<K,V> - Interface in org.apache.ignite.stream
Updates cache with batch of entries.
StreamSingleTupleExtractor<T,K,V> - Interface in org.apache.ignite.stream
Stream tuple extractor to convert a message to a single Ignite key-value tuple.
StreamTransformer<K,V> - Class in org.apache.ignite.stream
Convenience adapter to transform update existing values in streaming cache based on the previously cached value.
StreamTransformer() - Constructor for class org.apache.ignite.stream.StreamTransformer
 
StreamTupleExtractor<T,K,V> - Interface in org.apache.ignite.stream
Deprecated.
Will be removed in 2.0.0.
StreamVisitor<K,V> - Class in org.apache.ignite.stream
Convenience adapter to visit every key-value tuple in the stream.
StreamVisitor() - Constructor for class org.apache.ignite.stream.StreamVisitor
 
stripe() - Method in class org.apache.ignite.thread.IgniteThread
 
StripedExecutorTaskView - Class in org.apache.ignite.spi.systemview.view
StripedExecutor task representation for a SystemView.
StripedExecutorTaskView(StripedExecutor.Stripe, Runnable) - Constructor for class org.apache.ignite.spi.systemview.view.StripedExecutorTaskView
 
stripeIndex() - Method in class org.apache.ignite.spi.systemview.view.StripedExecutorTaskView
 
stripesCount() - Method in class org.apache.ignite.spi.systemview.view.PagesListView
 
subjectId() - Method in class org.apache.ignite.events.CacheEvent
Gets security subject ID initiated this cache event, if security is enabled.
subjectId() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets security subject ID.
subjectId() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets security subject ID.
subjectId() - Method in class org.apache.ignite.events.ClusterStateChangeStartedEvent
Gets security subject ID initiated state change.
subjectId() - Method in class org.apache.ignite.events.SqlQueryExecutionEvent
Gets security subject ID.
subjectId() - Method in class org.apache.ignite.events.TaskEvent
Gets security subject ID initiated this task event, if security is enabled.
subjectId() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets subject ID.
subjectId(UUID) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets subject ID.
subjectId() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
subjectId() - Method in class org.apache.ignite.spi.systemview.view.SqlQueryView
 
subjectId() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
subjectType() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Gets subject type.
subjectType(SecuritySubjectType) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
Sets subject type.
submit(Callable<T>) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
submit(Runnable, T) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
submit(Runnable) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
supportsCommunicationFailureResolve() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedDiscoverySpi
supportsCommunicationFailureResolve() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
supportsCommunicationFailureResolve() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
suspend() - Method in interface org.apache.ignite.transactions.Transaction
Suspends a transaction.
swap() - Method in class org.apache.ignite.lang.IgniteBiTuple
Swaps values.
system() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
SystemDataRegionConfiguration - Class in org.apache.ignite.configuration
This class allows defining system data region configuration with various parameters for Apache Ignite page memory (see DataStorageConfiguration.
SystemDataRegionConfiguration() - Constructor for class org.apache.ignite.configuration.SystemDataRegionConfiguration
 
systemPermissions() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Collection of system-wide permissions (events enable/disable, Visor task execution).
systemPermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Collection of system-wide permissions (events enable/disable, Visor task execution).
systemPermissions(SecurityPermission...) - Static method in class org.apache.ignite.plugin.security.SecurityPermissionSetBuilder
 
SystemProperty - Annotation Type in org.apache.ignite
Ignite system property info.
SystemView<R> - Interface in org.apache.ignite.spi.systemview.view
Implementation provides data for some internal Ignite objects.
SystemViewExporterSpi - Interface in org.apache.ignite.spi.systemview
Exporter of system view to the external recepient.
SystemViewRowAttributeWalker<R> - Interface in org.apache.ignite.spi.systemview.view
Utility class for quick iteration over row properties.
SystemViewRowAttributeWalker.AttributeVisitor - Interface in org.apache.ignite.spi.systemview.view
Attribute visitor.
SystemViewRowAttributeWalker.AttributeWithValueVisitor - Interface in org.apache.ignite.spi.systemview.view
Attribute visitor.

T

tableName() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.BasicJdbcIpFinderDialect
Gets table name in a valid form to use as IP addresses
tableName() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.JdbcIpFinderDialect
Gets table name in a valid form to use as IP addresses
tableName() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.OracleJdbcIpFinderDialect
Gets table name in a valid form to use as IP addresses
tableName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlIndexView
Returns table name.
tableName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
tableName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns table name.
tag() - Method in interface org.apache.ignite.IgniteCluster
User-defined tag describing the cluster.
tag(String) - Method in interface org.apache.ignite.IgniteCluster
Enables user to add a specific label to the cluster e.g. to describe purpose of the cluster or any its characteristics.
tag(String) - Method in interface org.apache.ignite.mxbean.IgniteClusterMXBean
Deprecated.
Changes cluster tag to provided value.
take() - Method in interface org.apache.ignite.IgniteQueue
taskClassName() - Method in class org.apache.ignite.events.JobEvent
Gets name of task class that triggered this event.
taskClassName(String) - Method in class org.apache.ignite.events.JobEvent
Sets name of the task class that triggered this event.
taskClassName() - Method in class org.apache.ignite.events.TaskEvent
Gets name of task class that triggered this event.
taskClassName() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
taskClassName() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
TaskContinuousMapperResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of ComputeTaskContinuousMapper resource.
TaskEvent - Class in org.apache.ignite.events
Grid task event.
TaskEvent(ClusterNode, String, int, IgniteUuid, String, String, boolean, UUID) - Constructor for class org.apache.ignite.events.TaskEvent
Creates task event with given parameters.
taskName() - Method in class org.apache.ignite.events.CacheEvent
Gets task name if cache event was caused by an operation initiated within task execution.
taskName() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
Gets the name of the task that executed the query (if any).
taskName() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets the name of the task that executed the query (if any).
taskName() - Method in class org.apache.ignite.events.JobEvent
Gets name of the task that triggered the event.
taskName(String) - Method in class org.apache.ignite.events.JobEvent
Sets name of the task that triggered this event.
taskName() - Method in class org.apache.ignite.events.TaskEvent
Gets name of the task that triggered the event.
taskName() - Method in class org.apache.ignite.spi.systemview.view.ComputeJobView
 
taskName() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
taskName() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
taskName() - Method in class org.apache.ignite.spi.systemview.view.StripedExecutorTaskView
 
taskNode() - Method in class org.apache.ignite.events.JobEvent
Get node where parent task of the job has originated.
taskNode(ClusterNode) - Method in class org.apache.ignite.events.JobEvent
Sets node where parent task of the job has originated.
taskNodeId() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 
taskPermissions() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
Map of task names to task permissions.
taskPermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
Map of task names to task permissions.
taskSessionId() - Method in class org.apache.ignite.events.JobEvent
Gets task session ID of the task that triggered this event.
taskSessionId(IgniteUuid) - Method in class org.apache.ignite.events.JobEvent
Sets task session ID of the task that triggered this event.
taskSessionId() - Method in class org.apache.ignite.events.TaskEvent
Gets session ID of the task that triggered the event.
TaskSessionResource - Annotation Type in org.apache.ignite.resources
Annotates a field or a setter method for injection of ComputeTaskSession resource.
taskSubjectId() - Method in class org.apache.ignite.events.JobEvent
Gets task subject ID.
taskSubjectId(UUID) - Method in class org.apache.ignite.events.JobEvent
Sets task subject ID.
TcpCommunicationMetricsListener - Class in org.apache.ignite.spi.communication.tcp
Statistics for TcpCommunicationSpi.
TcpCommunicationMetricsListener(Ignite, IgniteSpiContext) - Constructor for class org.apache.ignite.spi.communication.tcp.TcpCommunicationMetricsListener
 
TcpCommunicationSpi - Class in org.apache.ignite.spi.communication.tcp
TcpCommunicationSpi is default communication SPI which uses TCP/IP protocol and Java NIO to communicate with other nodes.
TcpCommunicationSpi() - Constructor for class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 
TcpCommunicationSpiMBean - Interface in org.apache.ignite.spi.communication.tcp
MBean provide access to TCP-based communication SPI.
TcpDiscoveryIpFinder - Interface in org.apache.ignite.spi.discovery.tcp.ipfinder
IP finder interface for TcpDiscoverySpi.
TcpDiscoveryIpFinderAdapter - Class in org.apache.ignite.spi.discovery.tcp.ipfinder
IP finder interface implementation adapter.
TcpDiscoveryIpFinderAdapter() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
 
TcpDiscoveryJdbcIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
JDBC-based IP finder.
TcpDiscoveryJdbcIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Constructor.
TcpDiscoveryJdbcIpFinder(JdbcIpFinderDialect) - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
 
TcpDiscoveryKubernetesIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes
IP finder for automatic lookup of Ignite nodes running in Kubernetes environment.
TcpDiscoveryKubernetesIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Creates an instance of Kubernetes IP finder.
TcpDiscoveryKubernetesIpFinder(KubernetesConnectionConfiguration) - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Creates an instance of Kubernetes IP finder.
TcpDiscoveryMulticastIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.multicast
Multicast-based IP finder.
TcpDiscoveryMulticastIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
Constructs new IP finder.
TcpDiscoverySharedFsIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs
Shared filesystem-based IP finder.
TcpDiscoverySharedFsIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Constructor.
TcpDiscoverySpi - Class in org.apache.ignite.spi.discovery.tcp
Discovery SPI implementation that uses TCP/IP for node discovery.
TcpDiscoverySpi() - Constructor for class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
TcpDiscoverySpiMBean - Interface in org.apache.ignite.spi.discovery.tcp
Management bean for TcpDiscoverySpi.
TcpDiscoveryVmIpFinder - Class in org.apache.ignite.spi.discovery.tcp.ipfinder.vm
IP Finder which works only with pre-configured list of IP addresses specified via TcpDiscoveryVmIpFinder.setAddresses(Collection) method.
TcpDiscoveryVmIpFinder() - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Constructs new IP finder.
TcpDiscoveryVmIpFinder(boolean) - Constructor for class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Constructs new IP finder.
terminateWorker(String) - Method in interface org.apache.ignite.mxbean.WorkersControlMXBean
Terminates worker.
test(ReadOnlyMetricRegistry) - Method in class org.apache.ignite.spi.metric.RegexpMetricFilter
text() - Method in class org.apache.ignite.events.SqlQueryExecutionEvent
Gets query text.
TextQuery<K,V> - Class in org.apache.ignite.cache.query

Full Text Queries Ignite supports full text queries based on Apache Lucene engine.

TextQuery(String, String) - Constructor for class org.apache.ignite.cache.query.TextQuery
Constructs query for the given search string.
TextQuery(String, String, int) - Constructor for class org.apache.ignite.cache.query.TextQuery
Constructs query for the given search string.
TextQuery(Class<?>, String) - Constructor for class org.apache.ignite.cache.query.TextQuery
Constructs query for the given search string.
TextQuery(Class<?>, String, int) - Constructor for class org.apache.ignite.cache.query.TextQuery
Constructs query for the given search string.
THIEF_NODE_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Job context attribute for storing thief node UUID (this attribute is used in job stealing failover SPI).
ThinClientConfiguration - Class in org.apache.ignite.configuration
Server-side thin-client configuration.
ThinClientConfiguration() - Constructor for class org.apache.ignite.configuration.ThinClientConfiguration
Creates thin-client configuration with all default values.
ThinClientConfiguration(ThinClientConfiguration) - Constructor for class org.apache.ignite.configuration.ThinClientConfiguration
Creates thin-client configuration by copying all properties from given configuration.
ThinClientKubernetesAddressFinder - Class in org.apache.ignite.client
Address finder for automatic lookup of Ignite server nodes running in Kubernetes environment.
ThinClientKubernetesAddressFinder(KubernetesConnectionConfiguration) - Constructor for class org.apache.ignite.client.ThinClientKubernetesAddressFinder
 
ThinClientKubernetesAddressFinder(KubernetesConnectionConfiguration, int) - Constructor for class org.apache.ignite.client.ThinClientKubernetesAddressFinder
 
threadCount() - Method in class org.apache.ignite.dump.DumpReaderConfiguration
 
threadedQueryInitiatorId() - Static method in class org.apache.ignite.cache.query.SqlFieldsQuery
 
threadId() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
threadId(int) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
 
threadId() - Method in interface org.apache.ignite.transactions.Transaction
ID of the thread in which this transaction started.
threadName() - Method in class org.apache.ignite.spi.systemview.view.StripedExecutorTaskView
 
threadPri - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Thread priority for all threads started by SPI.
throwable() - Method in class org.apache.ignite.client.events.ConnectionClosedEvent
Get a cause of the failure if any.
throwable() - Method in class org.apache.ignite.client.events.HandshakeFailEvent
Get a cause of the failure.
throwable() - Method in class org.apache.ignite.client.events.RequestFailEvent
Get a cause of the failure.
timeout() - Method in class org.apache.ignite.dump.DumpReaderConfiguration
 
timeout() - Method in class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
Get stop node timeout.
timeout(long) - Method in interface org.apache.ignite.IgniteDataStreamer
Sets the timeout that is used in the following cases: any data addition method can be blocked when all per node parallel operations are exhausted.
timeout() - Method in interface org.apache.ignite.IgniteDataStreamer
timeout() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
timeout() - Method in interface org.apache.ignite.transactions.Transaction
Gets timeout value in milliseconds for this transaction.
timeout(long) - Method in interface org.apache.ignite.transactions.Transaction
Sets transaction timeout value.
TimeoutStrategy - Interface in org.apache.ignite.spi
Strategy to calculate next timeout and check if total timeout reached.
timestamp() - Method in interface org.apache.ignite.events.Event
Gets event timestamp.
timestamp() - Method in class org.apache.ignite.events.EventAdapter
Gets event timestamp.
toArray() - Method in interface org.apache.ignite.client.ClientIgniteSet
toArray(T1[]) - Method in interface org.apache.ignite.client.ClientIgniteSet
toArray() - Method in interface org.apache.ignite.IgniteQueue
toArray(T[]) - Method in interface org.apache.ignite.IgniteQueue
toArray() - Method in interface org.apache.ignite.IgniteSet
toArray(T1[]) - Method in interface org.apache.ignite.IgniteSet
toBinary(Object) - Method in interface org.apache.ignite.IgniteBinary
Converts provided object to instance of BinaryObject.
toBuilder() - Method in interface org.apache.ignite.binary.BinaryObject
Creates a new BinaryObjectBuilder based on this binary object.
toBytes(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
Serialize object to byte array using marshaller.
toCode(CacheMode) - Static method in enum org.apache.ignite.cache.CacheMode
 
topHistSize - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Size of topology snapshots history.
topic() - Method in class org.apache.ignite.spi.systemview.view.ContinuousQueryView
 
topology(long) - Method in interface org.apache.ignite.IgniteCluster
Gets a topology by version.
topology() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
topologyNodes() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets topology nodes from topology snapshot.
topologySnapshot() - Method in interface org.apache.ignite.configuration.CommunicationFailureContext
 
topologySnapshot(long, Collection<ClusterNode>) - Method in class org.apache.ignite.events.DiscoveryEvent
Sets the topology snapshot.
topologySnapshot() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets service deployment topology snapshot.
topologySnapshot() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
TopologyValidator - Interface in org.apache.ignite.configuration
Topology validator is used to verify that cluster topology is valid for further cache operations.
topologyValidator(String) - Method in interface org.apache.ignite.plugin.CacheTopologyValidatorProvider
Provides instance of TopologyValidator for the cache with specified name.
topologyValidator() - Method in class org.apache.ignite.spi.systemview.view.CacheGroupView
 
topologyValidator() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
topologyVersion() - Method in interface org.apache.ignite.cache.CacheEntryVersion
 
topologyVersion() - Method in class org.apache.ignite.events.DiscoveryEvent
Gets topology version if this event is raised on topology change and configured discovery SPI implementation supports topology versioning.
topologyVersion() - Method in interface org.apache.ignite.IgniteCluster
Gets current topology version.
topVer() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
toString() - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
toString() - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
toString() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
toString() - Method in class org.apache.ignite.cache.affinity.AffinityKey
toString() - Method in class org.apache.ignite.cache.affinity.AffinityUuid
toString() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
toString() - Method in class org.apache.ignite.cache.CacheKeyConfiguration
toString() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
toString() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
toString() - Method in class org.apache.ignite.cache.query.Query
toString() - Method in class org.apache.ignite.cache.query.ScanQuery
toString() - Method in class org.apache.ignite.cache.query.SpiQuery
toString() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
toString() - Method in class org.apache.ignite.cache.query.SqlQuery
Deprecated.
toString() - Method in class org.apache.ignite.cache.query.TextQuery
toString() - Method in class org.apache.ignite.cache.QueryEntity
toString() - Method in class org.apache.ignite.cache.QueryEntityPatch
toString() - Method in class org.apache.ignite.cache.QueryIndex
toString() - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
toString() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
toString() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
toString() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
toString() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
toString() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
toString() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
toString() - Method in class org.apache.ignite.cache.websession.WebSessionFilter
toString() - Method in class org.apache.ignite.client.ClientAtomicConfiguration
toString() - Method in class org.apache.ignite.client.ClientCacheConfiguration
toString() - Method in class org.apache.ignite.client.ClientCollectionConfiguration
toString() - Method in class org.apache.ignite.configuration.AtomicConfiguration
toString() - Method in class org.apache.ignite.configuration.BasicAddressResolver
toString() - Method in class org.apache.ignite.configuration.BinaryConfiguration
toString() - Method in class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
toString() - Method in class org.apache.ignite.configuration.CacheConfiguration
toString() - Method in class org.apache.ignite.configuration.ClientConfiguration
toString() - Method in class org.apache.ignite.configuration.ClientConnectorConfiguration
toString() - Method in class org.apache.ignite.configuration.ClientTransactionConfiguration
toString() - Method in class org.apache.ignite.configuration.CollectionConfiguration
toString() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
toString() - Method in class org.apache.ignite.configuration.DataRegionConfiguration
toString() - Method in class org.apache.ignite.configuration.DataStorageConfiguration
toString() - Method in class org.apache.ignite.configuration.DefaultCommunicationFailureResolver
toString() - Method in class org.apache.ignite.configuration.ExecutorConfiguration
toString() - Method in class org.apache.ignite.configuration.IgniteConfiguration
toString() - Method in class org.apache.ignite.configuration.LoadAllWarmUpConfiguration
toString() - Method in class org.apache.ignite.configuration.MemoryConfiguration
Deprecated.
toString() - Method in class org.apache.ignite.configuration.MemoryPolicyConfiguration
Deprecated.
toString() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
toString() - Method in class org.apache.ignite.configuration.NoOpWarmUpConfiguration
toString() - Method in class org.apache.ignite.configuration.OdbcConfiguration
Deprecated.
toString() - Method in class org.apache.ignite.configuration.PersistentStoreConfiguration
Deprecated.
toString() - Method in class org.apache.ignite.configuration.PlatformCacheConfiguration
toString() - Method in class org.apache.ignite.configuration.SqlConfiguration
toString() - Method in class org.apache.ignite.configuration.SqlConnectorConfiguration
Deprecated.
toString() - Method in class org.apache.ignite.configuration.ThinClientConfiguration
toString() - Method in class org.apache.ignite.configuration.TransactionConfiguration
toString() - Method in class org.apache.ignite.development.utils.RecordSizeCountStat
toString() - Method in class org.apache.ignite.development.utils.TxWalStat
toString() - Method in class org.apache.ignite.development.utils.WalStat
toString() - Method in class org.apache.ignite.events.CacheEvent
toString() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
toString() - Method in class org.apache.ignite.events.CacheQueryReadEvent
toString() - Method in class org.apache.ignite.events.CacheRebalancingEvent
toString() - Method in class org.apache.ignite.events.CheckpointEvent
toString() - Method in class org.apache.ignite.events.DeploymentEvent
toString() - Method in class org.apache.ignite.events.DiscoveryEvent
toString() - Method in class org.apache.ignite.events.EventAdapter
toString() - Method in class org.apache.ignite.events.JobEvent
toString() - Method in class org.apache.ignite.events.NodeValidationFailedEvent
toString() - Method in class org.apache.ignite.events.SqlQueryExecutionEvent
toString() - Method in class org.apache.ignite.events.TaskEvent
toString() - Method in class org.apache.ignite.failure.AbstractFailureHandler
toString() - Method in class org.apache.ignite.failure.FailureContext
toString() - Method in class org.apache.ignite.failure.NoOpFailureHandler
toString() - Method in class org.apache.ignite.failure.RestartProcessFailureHandler
toString() - Method in class org.apache.ignite.failure.StopNodeFailureHandler
toString() - Method in class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
toString() - Method in exception org.apache.ignite.IgniteCheckedException
toString() - Method in exception org.apache.ignite.IgniteException
toString() - Method in exception org.apache.ignite.IgniteIllegalStateException
toString() - Method in class org.apache.ignite.IgniteSpringBean
toString() - Method in class org.apache.ignite.lang.IgniteBiTuple
toString() - Method in class org.apache.ignite.lang.IgniteProductVersion
toString() - Method in class org.apache.ignite.lang.IgniteUuid
toString() - Method in class org.apache.ignite.logger.java.JavaLogger
toString() - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
toString() - Method in class org.apache.ignite.logger.java.JavaLoggerFormatter
toString() - Method in class org.apache.ignite.logger.jcl.JclLogger
toString() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
toString() - Method in class org.apache.ignite.logger.NullLogger
toString() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
toString() - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
toString() - Method in class org.apache.ignite.messaging.MessagingListenActor
toString() - Method in class org.apache.ignite.platform.cpp.PlatformCppConfiguration
toString() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
toString() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
toString() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
toString() - Method in class org.apache.ignite.plugin.security.SecurityBasicPermissionSet
toString() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
toString() - Method in class org.apache.ignite.services.ServiceConfiguration
toString() - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
toString() - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
toString() - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
toString() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
toString() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
toString() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
toString() - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
toString() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
toString() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
toString() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
toString() - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
toString() - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
toString() - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
toString() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
toString() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
toString() - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
toString() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
toString() - Method in class org.apache.ignite.spi.discovery.DiscoveryDataBag
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
toString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
toString() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
toString() - Method in class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
toString() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
toString() - Method in class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
toString() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
toString() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
toString() - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
toString() - Method in class org.apache.ignite.spi.IgniteNodeValidationResult
toString() - Method in class org.apache.ignite.spi.IgniteSpiThread
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
toString() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
toString() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
toString() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
toString() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTraceExporter
toString() - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates
toString() - Method in class org.apache.ignite.ssl.SslContextFactory
toString() - Method in class org.apache.ignite.startup.BasicWarmupClosure
toString() - Method in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
toString() - Method in class org.apache.ignite.startup.servlet.ServletStartup
toString() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
toString() - Method in class org.apache.ignite.thread.IgniteThread
toString() - Method in class org.apache.ignite.thread.IgniteThreadFactory
totalBackoffTimeout(long, long, long) - Static method in class org.apache.ignite.spi.ExponentialBackoffTimeoutStrategy
Compute expected max backoff timeout based on initTimeout, maxTimeout and reconCnt and backoff coefficient.
totalBusyTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
totalCanceledJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
totalCnt - Variable in class org.apache.ignite.services.ServiceConfiguration
Total count.
totalCount() - Method in interface org.apache.ignite.client.ClientServiceDescriptor
Gets maximum allowed total number of deployed services in the grid, 0 for unlimited.
totalCount() - Method in interface org.apache.ignite.services.ServiceDescriptor
Gets maximum allowed total number of deployed services in the grid, 0 for unlimited.
totalCount() - Method in class org.apache.ignite.spi.systemview.view.ServiceView
 
totalCpu() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
totalExecutedJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
totalExecutedTasks() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
totalIdleTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
totalJobsExecuteTime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
totalPartitions() - Method in interface org.apache.ignite.mxbean.DefragmentationMXBean
Deprecated.
Get total count of partitions.
totalRejectedJobs() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
totalThreadCount() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
totalTime() - Method in interface org.apache.ignite.cache.query.QueryDetailMetrics
Gets total time of all query executions.
touch(EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
 
touch(EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
 
touch(EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
 
touch(EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
 
trace(String) - Method in interface org.apache.ignite.IgniteLogger
Logs out trace message.
trace(String, String) - Method in interface org.apache.ignite.IgniteLogger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out trace message.
trace(String, String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.NullLogger
Logs out trace message.
trace(String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out trace message.
trace(String, String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out trace message.
tracingConfiguration() - Method in interface org.apache.ignite.Ignite
Returns the TracingConfigurationManager instance that allows to Configure tracing parameters such as sampling rate for the specific tracing coordinates such as scope and label.
tracingConfiguration() - Method in class org.apache.ignite.IgniteSpringBean
Returns the TracingConfigurationManager instance that allows to Configure tracing parameters such as sampling rate for the specific tracing coordinates such as scope and label.
TracingConfigurationCoordinates - Class in org.apache.ignite.spi.tracing
Specifies to which traces, specific configuration will be applied.
TracingConfigurationCoordinates.Builder - Class in org.apache.ignite.spi.tracing
TracingConfigurationCoordinates builder.
TracingConfigurationManager - Interface in org.apache.ignite.spi.tracing
Allows to configure tracing, read the configuration and restore it to the defaults.
TracingConfigurationParameters - Class in org.apache.ignite.spi.tracing
Set of tracing configuration parameters like sampling rate or included scopes.
TracingConfigurationParameters.Builder - Class in org.apache.ignite.spi.tracing
TracingConfigurationParameters builder.
TracingSpi<S extends SpiSpecificSpan> - Interface in org.apache.ignite.spi.tracing
Tracing SPI interface.
transaction() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
Gets transaction spanning multiple store operations, or null if there is no transaction.
Transaction - Interface in org.apache.ignite.transactions
Ignite cache transaction.
TransactionAlreadyCompletedException - Exception in org.apache.ignite.transactions
Exception thrown whenever Mvcc transaction has been finished before operation finished.
TransactionAlreadyCompletedException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionAlreadyCompletedException
Creates new exception with given error message and optional nested exception.
TransactionConcurrency - Enum in org.apache.ignite.transactions
Transaction concurrency control.
TransactionConfiguration - Class in org.apache.ignite.configuration
Transactions configuration.
TransactionConfiguration() - Constructor for class org.apache.ignite.configuration.TransactionConfiguration
Empty constructor.
TransactionConfiguration(TransactionConfiguration) - Constructor for class org.apache.ignite.configuration.TransactionConfiguration
 
TransactionDeadlockException - Exception in org.apache.ignite.transactions
Transaction deadlock exception.
TransactionDeadlockException(String) - Constructor for exception org.apache.ignite.transactions.TransactionDeadlockException
Creates new deadlock exception with given error message.
TransactionDuplicateKeyException - Exception in org.apache.ignite.transactions
Exception thrown whenever transaction tries to inserts entry with same mvcc version more than once.
TransactionDuplicateKeyException(String, Exception) - Constructor for exception org.apache.ignite.transactions.TransactionDuplicateKeyException
Creates new duplicate ket exception with given error message.
TransactionDuplicateKeyException(String) - Constructor for exception org.apache.ignite.transactions.TransactionDuplicateKeyException
Creates new duplicate ket exception with given error message.
TransactionException - Exception in org.apache.ignite.transactions
Base class for all transaction related exceptions.
TransactionException() - Constructor for exception org.apache.ignite.transactions.TransactionException
Creates empty exception.
TransactionException(String) - Constructor for exception org.apache.ignite.transactions.TransactionException
Creates new exception with given error message.
TransactionException(Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionException
Creates new transaction exception with given throwable as a cause and source of error message.
TransactionException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionException
Creates new exception with given error message and optional nested exception.
TransactionHeuristicException - Exception in org.apache.ignite.transactions
Exception thrown whenever grid transaction enters an unknown state.
TransactionHeuristicException(String) - Constructor for exception org.apache.ignite.transactions.TransactionHeuristicException
Creates new heuristic exception with given error message.
TransactionHeuristicException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionHeuristicException
Creates new heuristic exception with given error message and optional nested exception.
TransactionIsolation - Enum in org.apache.ignite.transactions
Defines different cache transaction isolation levels.
TransactionMetrics - Interface in org.apache.ignite.transactions
Transaction metrics, shared across all caches.
TransactionMetricsMxBean - Interface in org.apache.ignite.mxbean
Deprecated.
Check the JmxMetricExporterSpi with "name=\"tx\"" instead.
TransactionMixedModeException - Exception in org.apache.ignite.transactions
Exception thrown whenever transaction spans over MVCC and non-MVCC caches.
TransactionMixedModeException(String) - Constructor for exception org.apache.ignite.transactions.TransactionMixedModeException
Creates new exception with given error message.
TransactionOptimisticException - Exception in org.apache.ignite.transactions
Exception thrown whenever grid transactions fail optimistically.
TransactionOptimisticException(String) - Constructor for exception org.apache.ignite.transactions.TransactionOptimisticException
Creates new optimistic exception with given error message.
TransactionOptimisticException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionOptimisticException
Creates new optimistic exception with given error message and optional nested exception.
TransactionRollbackException - Exception in org.apache.ignite.transactions
Exception thrown whenever grid transactions has been automatically rolled back.
TransactionRollbackException(String) - Constructor for exception org.apache.ignite.transactions.TransactionRollbackException
Creates new rollback exception with given error message.
TransactionRollbackException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionRollbackException
Creates new rollback exception with given error message and optional nested exception.
transactions() - Method in interface org.apache.ignite.client.IgniteClient
Gets client transactions facade.
transactions() - Method in interface org.apache.ignite.Ignite
Gets grid transactions facade.
transactions() - Method in class org.apache.ignite.IgniteClientSpringBean
Gets client transactions facade.
transactions() - Method in class org.apache.ignite.IgniteSpringBean
Gets grid transactions facade.
TransactionSerializationException - Exception in org.apache.ignite.transactions
Exception thrown whenever transaction can't be serialized due to write conflict.
TransactionSerializationException(String, Exception) - Constructor for exception org.apache.ignite.transactions.TransactionSerializationException
Creates new transaction serialization exception with given error message.
TransactionsMXBean - Interface in org.apache.ignite.mxbean
Transactions MXBean interface.
TransactionState - Enum in org.apache.ignite.transactions
Cache transaction state.
TransactionStateChangedEvent - Class in org.apache.ignite.events
Event indicates transaction state change.
TransactionStateChangedEvent(ClusterNode, String, int, Transaction) - Constructor for class org.apache.ignite.events.TransactionStateChangedEvent
 
TransactionTimeoutException - Exception in org.apache.ignite.transactions
Exception thrown whenever transactions time out.
TransactionTimeoutException(String) - Constructor for exception org.apache.ignite.transactions.TransactionTimeoutException
Creates new timeout exception with given error message.
TransactionTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.transactions.TransactionTimeoutException
Creates new timeout exception with given error message and optional nested exception.
TransactionUnsupportedConcurrencyException - Exception in org.apache.ignite.transactions
Exception thrown whenever transaction concurrency level is not supported.
TransactionUnsupportedConcurrencyException(String) - Constructor for exception org.apache.ignite.transactions.TransactionUnsupportedConcurrencyException
Creates new exception with given error message.
TransactionView - Class in org.apache.ignite.spi.systemview.view
Transaction representation for a SystemView.
TransactionView(IgniteInternalTx) - Constructor for class org.apache.ignite.spi.systemview.view.TransactionView
 
transform(String...) - Static method in class org.apache.ignite.startup.cmdline.CommandLineTransformer
 
transformer - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Types transformer.
transformer() - Method in class org.apache.ignite.spi.systemview.view.ScanQueryView
 
trustMgrs - Variable in class org.apache.ignite.ssl.SslContextFactory
Trust managers.
trustStoreFilePath - Variable in class org.apache.ignite.ssl.SslContextFactory
Path to trust store.
trustStorePwd - Variable in class org.apache.ignite.ssl.SslContextFactory
Trust store password
trustStoreType - Variable in class org.apache.ignite.ssl.SslContextFactory
Trust store type.
tryAcquire() - Method in interface org.apache.ignite.IgniteSemaphore
Acquires a permit from this semaphore, only if one is available at the time of invocation.
tryAcquire(long, TimeUnit) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires a permit from this semaphore, if one becomes available within the given waiting time and the current thread has not been interrupted.
tryAcquire(int, long, TimeUnit) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given number of permits from this semaphore, if all become available within the given waiting time and the current thread has not been interrupted.
tryAcquire(int) - Method in interface org.apache.ignite.IgniteSemaphore
Acquires the given number of permits from this semaphore, only if all are available at the time of invocation.
tryFailNode(UUID, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
tryFlush() - Method in interface org.apache.ignite.IgniteDataStreamer
Makes an attempt to stream remaining data.
tryLock() - Method in interface org.apache.ignite.IgniteLock
Acquires the lock only if it is free at the time of invocation.
tryLock(long, TimeUnit) - Method in interface org.apache.ignite.IgniteLock
Acquires the lock if it is not held by another thread within the given waiting time and the current thread has not been interrupted.
tryStop() - Method in class org.apache.ignite.failure.StopNodeOrHaltFailureHandler
Get try stop.
tx() - Method in class org.apache.ignite.events.TransactionStateChangedEvent
 
tx() - Method in interface org.apache.ignite.IgniteTransactions
Gets transaction started by this thread or null if this thread does not have a transaction.
TX_TIMEOUT_ON_PARTITION_MAP_EXCHANGE - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
Transaction timeout on partition map synchronization.
txCommits() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
The total number of commited transactions.
txCommits() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets total number of transaction commits.
txLabel() - Method in class org.apache.ignite.events.CacheEvent
Label of surrounding cache transaction or null if there either is no surrounding transaction or label was not set.
txRollbacks() - Method in interface org.apache.ignite.mxbean.TransactionMetricsMxBean
Deprecated.
Tne total number of rollbacked transactions.
txRollbacks() - Method in interface org.apache.ignite.transactions.TransactionMetrics
Gets total number of transaction rollbacks.
txStart() - Method in interface org.apache.ignite.client.ClientTransactions
Starts a new transaction with the default isolation level, concurrency and timeout.
txStart(TransactionConcurrency, TransactionIsolation) - Method in interface org.apache.ignite.client.ClientTransactions
Starts a new transaction with the specified concurrency and isolation.
txStart(TransactionConcurrency, TransactionIsolation, long) - Method in interface org.apache.ignite.client.ClientTransactions
Starts a new transaction with the specified isolation, concurrency and timeout.
txStart() - Method in interface org.apache.ignite.IgniteTransactions
Starts transaction with default isolation, concurrency, timeout, and invalidation policy.
txStart(TransactionConcurrency, TransactionIsolation) - Method in interface org.apache.ignite.IgniteTransactions
Starts new transaction with the specified concurrency and isolation.
txStart(TransactionConcurrency, TransactionIsolation, long, int) - Method in interface org.apache.ignite.IgniteTransactions
Starts transaction with specified isolation, concurrency, timeout, invalidation flag, and number of participating entries.
TxWalStat - Class in org.apache.ignite.development.utils
Transactions statistics for WAL.
TxWalStat() - Constructor for class org.apache.ignite.development.utils.TxWalStat
 
type() - Method in interface org.apache.ignite.binary.BinaryObject
Gets type information for this binary object.
type() - Method in interface org.apache.ignite.events.Event
Gets type of this event.
type(int) - Method in class org.apache.ignite.events.EventAdapter
Sets event type.
type() - Method in class org.apache.ignite.events.EventAdapter
Gets type of this event.
type() - Method in class org.apache.ignite.failure.FailureContext
 
type(Class<?>) - Method in interface org.apache.ignite.IgniteBinary
Gets metadata for provided class.
type(String) - Method in interface org.apache.ignite.IgniteBinary
Gets metadata for provided class name.
type(int) - Method in interface org.apache.ignite.IgniteBinary
Gets metadata for provided type ID.
type() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
Gets subject type for node.
type() - Method in class org.apache.ignite.spi.discovery.DiscoveryNotification
 
type() - Method in interface org.apache.ignite.spi.metric.ObjectMetric
 
type() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
type() - Method in class org.apache.ignite.spi.systemview.view.SnapshotView
 
type() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableColumnView
 
type() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewColumnView
 
type() - Method in class org.apache.ignite.spi.tracing.NoopTracingSpi
type() - Method in class org.apache.ignite.spi.tracing.opencensus.OpenCensusTracingSpi
type() - Method in interface org.apache.ignite.spi.tracing.TracingSpi
 
typeId(String) - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
Get type ID.
typeId(String) - Method in interface org.apache.ignite.binary.BinaryIdMapper
Gets type ID for provided type name.
typeId() - Method in interface org.apache.ignite.binary.BinaryType
Gets binary type ID.
typeId() - Method in interface org.apache.ignite.cdc.TypeMapping
 
typeId(String) - Method in interface org.apache.ignite.IgniteBinary
Gets type ID for given type name.
typeId() - Method in class org.apache.ignite.spi.systemview.view.BinaryMetadataView
 
typeIdForObject(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Calculate type ID for object.
typeIdForObject(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Calculate type ID for object.
typeIdForTypeName(CacheAbstractJdbcStore.TypeKind, String) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
Calculate type ID for given type name.
typeIdForTypeName(CacheAbstractJdbcStore.TypeKind, String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
Calculate type ID for given type name.
TypeMapping - Interface in org.apache.ignite.cdc
Ignite maps type name to some id.
typeName(String) - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
Gets type clsName.
typeName(String) - Method in interface org.apache.ignite.binary.BinaryNameMapper
Gets type clsName.
typeName() - Method in interface org.apache.ignite.binary.BinaryType
Gets binary type name.
typeName() - Method in interface org.apache.ignite.cdc.TypeMapping
 
typeName() - Method in class org.apache.ignite.spi.systemview.view.BinaryMetadataView
 
types() - Method in interface org.apache.ignite.IgniteBinary
Gets metadata for all known types.

U

uncaughtException(Thread, Throwable) - Method in class org.apache.ignite.thread.OomExceptionHandler
undeployTask(String) - Method in interface org.apache.ignite.IgniteCompute
Makes the best attempt to undeploy a task with given name within the underlying cluster group.
undeployTaskFromGrid(String) - Method in interface org.apache.ignite.mxbean.IgniteMXBean
Makes the best attempt to undeploy a task from the whole grid.
UNKNOWN_NODE - Static variable in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Initiator node is not in current topogy.
UNLIMITED_WAL_ARCHIVE - Static variable in class org.apache.ignite.configuration.DataStorageConfiguration
Value used for making WAL archive size unlimited.
unlock() - Method in interface org.apache.ignite.IgniteLock
Releases the lock.
unmarshal(byte[], ClassLoader) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Unmarshals object from byte array using given class loader.
unmarshal(InputStream, ClassLoader) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Unmarshals object from the input stream using given class loader.
unmarshal(InputStream, ClassLoader) - Method in interface org.apache.ignite.marshaller.Marshaller
Unmarshals object from the input stream using given class loader.
unmarshal(byte[], ClassLoader) - Method in interface org.apache.ignite.marshaller.Marshaller
Unmarshals object from byte array using given class loader.
unmarshal0(InputStream, ClassLoader) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Unmarshals object from the input stream using given class loader.
unmarshal0(byte[], ClassLoader) - Method in class org.apache.ignite.marshaller.AbstractNodeNameAwareMarshaller
Unmarshals object from byte array using given class loader.
unmarshal0(InputStream, ClassLoader) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Unmarshals object from the input stream using given class loader.
unmarshal0(byte[], ClassLoader) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
Unmarshals object from byte array using given class loader.
unregister(String) - Method in interface org.apache.ignite.spi.deployment.DeploymentSpi
Unregisters all class loaders that have a class with given name or have a class with give ComputeTaskName value.
unregister(String) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
Unregisters all class loaders that have a class with given name or have a class with give ComputeTaskName value.
unregister(String) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Unregisters all class loaders that have a class with given name or have a class with give ComputeTaskName value.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.kubernetes.TcpDiscoveryKubernetesIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
Unregisters provided addresses.
unregisterAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
Unregisters provided addresses.
unregisterMaintenanceTask(String) - Method in interface org.apache.ignite.maintenance.MaintenanceRegistry
Deletes MaintenanceTask of given ID from maintenance registry.
unregisterMBean() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
Unregisters MBean.
unwrap(Class<T>) - Method in class org.apache.ignite.cache.CacheManager
unwrap(Class<T>) - Method in class org.apache.ignite.cache.query.CacheEntryEventAdapter
unwrap(Class<T>) - Method in class org.apache.ignite.IgniteJdbcThinDataSource
unwrapCacheEntry(Cache.Entry<K, V>, Class<T>) - Method in interface org.apache.ignite.plugin.CachePluginProvider
Unwrap entry to specified type.
updateAttributes(String, Collection<T2<String, Object>>, int) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
 
updateAttributesV2(String, WebSessionV2) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
 
updateQuery(String, Collection<String>, Iterable<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
Construct update query.
updateQuery(String, Collection<String>, Iterable<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
Construct update query.
uptime() - Method in class org.apache.ignite.spi.systemview.view.NodeMetricsView
 
UPTIME_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
UPTIME_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
UriDeploymentSpi - Class in org.apache.ignite.spi.deployment.uri
Implementation of DeploymentSpi which can deploy tasks from different sources like file system folders, email and HTTP.
UriDeploymentSpi() - Constructor for class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
 
UriDeploymentSpiMBean - Interface in org.apache.ignite.spi.deployment.uri
Management bean for UriDeploymentSpi.
user() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
USER_ATTRS_FORMATTED_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
userVersion() - Method in class org.apache.ignite.spi.systemview.view.ComputeTaskView
 

V

validate(Collection<ClusterNode>) - Method in interface org.apache.ignite.configuration.TopologyValidator
Validates topology.
validate() - Method in interface org.apache.ignite.plugin.CachePluginProvider
Validates cache plugin configuration in process of cache creation.
validateNewNode(ClusterNode) - Method in interface org.apache.ignite.plugin.PluginProvider
validateNewNode(ClusterNode, Serializable) - Method in interface org.apache.ignite.plugin.PluginProvider
Validates that new node can join grid topology, this method is called on coordinator node before new node joins topology.
validateNode(ClusterNode) - Method in interface org.apache.ignite.spi.IgniteSpiContext
Validates that new node can join grid topology, this method is called on coordinator node before new node joins topology.
validateNode(ClusterNode, DiscoveryDataBag) - Method in interface org.apache.ignite.spi.IgniteSpiContext
 
validateRemote(CacheConfiguration, CacheConfiguration, ClusterNode) - Method in interface org.apache.ignite.plugin.CachePluginProvider
Checks that remote caches has configuration compatible with the local.
validationResult() - Method in class org.apache.ignite.events.NodeValidationFailedEvent
 
value(BinaryObject) - Method in interface org.apache.ignite.binary.BinaryField
Get field's value from the given object.
value() - Method in interface org.apache.ignite.cdc.CdcEvent
 
value() - Method in interface org.apache.ignite.dump.DumpEntry
 
value() - Method in class org.apache.ignite.events.CacheQueryReadEvent
Gets read entry value.
value() - Method in interface org.apache.ignite.IgniteAtomicStamped
Gets current value.
value() - Method in interface org.apache.ignite.spi.metric.BooleanMetric
 
value() - Method in interface org.apache.ignite.spi.metric.DoubleMetric
 
value() - Method in interface org.apache.ignite.spi.metric.IntMetric
 
value() - Method in interface org.apache.ignite.spi.metric.LongMetric
 
value() - Method in interface org.apache.ignite.spi.metric.ObjectMetric
 
value() - Method in class org.apache.ignite.spi.systemview.view.BaselineNodeAttributeView
 
value() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionAttributeView
 
value() - Method in class org.apache.ignite.spi.systemview.view.ConfigurationView
 
value() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicLongView
 
value() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicReferenceView
 
value() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicSequenceView
 
value() - Method in class org.apache.ignite.spi.systemview.view.datastructures.AtomicStampedView
 
value() - Method in class org.apache.ignite.spi.systemview.view.MetastorageView
 
value() - Method in class org.apache.ignite.spi.systemview.view.MetricsView
 
value() - Method in class org.apache.ignite.spi.systemview.view.NodeAttributeView
 
valueAlias() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns alias for value column.
valueColumns() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
Gets value columns.
valueKind() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
valueOf(String) - Static method in enum org.apache.ignite.cache.CacheAtomicityMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.CacheMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.CachePeekMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.CacheRebalanceMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.CacheWriteSynchronizationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.PartitionLossPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.QueryIndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.ReadRepairStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.TypeKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.client.ClientOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.client.SslMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.client.SslProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.cluster.ClusterState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.compute.ComputeJobResultPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.compute.ComputeTaskSessionScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.configuration.CheckpointWriteOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.configuration.DataPageEvictionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.configuration.DeploymentMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.configuration.DiskPageCompression
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.configuration.PageReplacementMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.configuration.WALMode
Returns the enum constant of this type with the specified name.
valueOf(DataRegionMetrics) - Static method in class org.apache.ignite.DataRegionMetricsAdapter
Deprecated.
 
valueOf(String) - Static method in enum org.apache.ignite.failure.FailureType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.IgniteState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.lifecycle.LifecycleEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.platform.PlatformType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.plugin.extensions.communication.MessageCollectionItemType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.plugin.security.SecurityPermission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.plugin.security.SecuritySubjectType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.plugin.segmentation.SegmentationPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.ShutdownPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.spi.IgnitePortProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.spi.systemview.view.ComputeJobView.ComputeJobState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.spi.tracing.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.spi.tracing.SpanStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.transactions.TransactionConcurrency
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.transactions.TransactionIsolation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.ignite.transactions.TransactionState
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.ignite.cache.CacheAtomicityMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.CacheMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.CachePeekMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.CacheRebalanceMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.CacheWriteSynchronizationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.PartitionLossPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.QueryIndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.ReadRepairStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.TypeKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.client.ClientOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.client.SslMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.client.SslProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.cluster.ClusterState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.compute.ComputeJobResultPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.compute.ComputeTaskSessionScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.configuration.CheckpointWriteOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.configuration.DataPageEvictionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.configuration.DeploymentMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.configuration.DiskPageCompression
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.configuration.PageReplacementMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.configuration.WALMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.failure.FailureType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.IgniteState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.ignite.lang.IgniteBiTuple
values() - Static method in enum org.apache.ignite.lifecycle.LifecycleEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.platform.PlatformType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.plugin.extensions.communication.MessageCollectionItemType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.plugin.security.SecurityPermission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.plugin.security.SecuritySubjectType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.plugin.segmentation.SegmentationPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.ShutdownPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.spi.IgnitePortProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.spi.systemview.view.ComputeJobView.ComputeJobState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.spi.tracing.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.spi.tracing.SpanStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.transactions.TransactionConcurrency
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.transactions.TransactionIsolation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.ignite.transactions.TransactionState
Returns an array containing the constants of this enum type, in the order they are declared.
valueType() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
 
valueTypeName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlTableView
Returns name of value type.
verify() - Method in class org.apache.ignite.kubernetes.configuration.KubernetesConnectionConfiguration
Verify that configuration is valid.
version() - Method in interface org.apache.ignite.cache.CacheEntry
Returns a comparable object representing the version of this cache entry.
version() - Method in interface org.apache.ignite.cdc.CdcEvent
 
version() - Method in interface org.apache.ignite.cluster.ClusterNode
Gets node version.
version() - Method in interface org.apache.ignite.dump.DumpEntry
 
version() - Method in interface org.apache.ignite.Ignite
Gets Ignite version.
version() - Method in class org.apache.ignite.IgniteSpringBean
Gets Ignite version.
version() - Method in interface org.apache.ignite.plugin.PluginProvider
 
version() - Method in class org.apache.ignite.spi.discovery.isolated.IsolatedNode
Gets node version.
version() - Method in class org.apache.ignite.spi.systemview.view.ClientConnectionView
 
version() - Method in class org.apache.ignite.spi.systemview.view.ClusterNodeView
 
viewName() - Method in class org.apache.ignite.spi.systemview.view.sql.SqlViewColumnView
 
visitAll(SystemViewRowAttributeWalker.AttributeVisitor) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker
Calls visitor for each row attribute.
visitAll(R, SystemViewRowAttributeWalker.AttributeWithValueVisitor) - Method in interface org.apache.ignite.spi.systemview.view.SystemViewRowAttributeWalker
Calls visitor for each row attribute.
VM_ID - Static variable in class org.apache.ignite.lang.IgniteUuid
VM ID.
VM_NAME_DESC - Static variable in interface org.apache.ignite.mxbean.IgniteMXBean
 
vmId() - Static method in class org.apache.ignite.lang.IgniteUuid
Gets UUID associated with local VM.

W

WAIT_JOBS_THRESHOLD_NODE_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
Threshold of maximum jobs on waiting queue.
waitForAttribute(K, long) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Waits for the specified attribute to be set.
waitForAttribute(K, V, long) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Waits for the specified attribute to be set or updated with given value.
waitForAttributes(Collection<?>, long) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Waits for the specified attributes to be set.
waitForAttributes(Map<?, ?>, long) - Method in interface org.apache.ignite.compute.ComputeTaskSession
Waits for the specified attributes to be set or updated with given values.
waitForClientMessagePrecessed() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
FOR TEST PURPOSE ONLY!
waitForLocal(IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Waits for the specified events.
waitForLocalAsync(IgnitePredicate<T>, int...) - Method in interface org.apache.ignite.IgniteEvents
Create future to wait for the specified events.
waitingJobs() - Method in interface org.apache.ignite.spi.collision.CollisionContext
Gets ordered collection of collision contexts for jobs that are currently waiting for execution.
walker() - Method in interface org.apache.ignite.spi.systemview.view.SystemView
 
WALMode - Enum in org.apache.ignite.configuration
WAL Mode.
WalSegmentArchivedEvent - Class in org.apache.ignite.events
Event indicates the completion of WAL segment file transition to archive.
WalSegmentArchivedEvent(ClusterNode, long, File) - Constructor for class org.apache.ignite.events.WalSegmentArchivedEvent
Creates WAL segment event
WalSegmentArchivedEvent(ClusterNode, long, File, int) - Constructor for class org.apache.ignite.events.WalSegmentArchivedEvent
 
WalSegmentCompactedEvent - Class in org.apache.ignite.events
Event indicates the completion of WAL segment compaction.
WalSegmentCompactedEvent(ClusterNode, long, File) - Constructor for class org.apache.ignite.events.WalSegmentCompactedEvent
Creates WAL segment compaction event.
WalStat - Class in org.apache.ignite.development.utils
Statistic for overall WAL file
WalStat() - Constructor for class org.apache.ignite.development.utils.WalStat
 
WarmUpConfiguration - Interface in org.apache.ignite.configuration
Warm-up configuration marker interface.
WarmUpMXBean - Interface in org.apache.ignite.mxbean
Deprecated.
Use managements API beans, instead.
warning(String) - Method in interface org.apache.ignite.IgniteLogger
Logs out warning message.
warning(String, Throwable) - Method in interface org.apache.ignite.IgniteLogger
Logs out warning message with optional exception.
warning(String, String, Throwable) - Method in interface org.apache.ignite.IgniteLogger
Logs out warning message with optional exception.
warning(String) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out warning message.
warning(String, Throwable) - Method in class org.apache.ignite.logger.java.JavaLogger
Logs out warning message with optional exception.
warning(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out warning message.
warning(String, Throwable) - Method in class org.apache.ignite.logger.jcl.JclLogger
Logs out warning message with optional exception.
warning(String, Throwable) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out warning message with optional exception.
warning(String, String, Throwable) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
Logs out warning message with optional exception.
warning(String) - Method in class org.apache.ignite.logger.NullLogger
Logs out warning message.
warning(String, Throwable) - Method in class org.apache.ignite.logger.NullLogger
Logs out warning message with optional exception.
warning(String, Throwable) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out warning message with optional exception.
warning(String, String, Throwable) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
Logs out warning message with optional exception.
WEB_SES_CACHE_NAME_PARAM - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Web sessions caching cache name parameter name.
WEB_SES_KEEP_BINARY_PARAM - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
 
WEB_SES_MAX_RETRIES_ON_FAIL_NAME_PARAM - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Web sessions caching retry on fail parameter name (valid for ATOMIC cache only).
WEB_SES_NAME_PARAM - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Web sessions caching grid name parameter name.
WEB_SES_RETRIES_TIMEOUT_NAME_PARAM - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
Web sessions caching retry on fail timeout parameter name.
WebSessionFilter - Class in org.apache.ignite.cache.websession
Filter for web sessions caching.
WebSessionFilter() - Constructor for class org.apache.ignite.cache.websession.WebSessionFilter
 
WebSphereLibertyTmFactory - Class in org.apache.ignite.cache.jta.websphere
Implementation of Transaction Manager factory that should used within WebSphere Liberty.
WebSphereLibertyTmFactory() - Constructor for class org.apache.ignite.cache.jta.websphere.WebSphereLibertyTmFactory
 
WebSphereTmFactory - Class in org.apache.ignite.cache.jta.websphere
Implementation of Transaction Manager factory that should used within WebSphere Application Server ("full profile" / "traditional" WS AS).
WebSphereTmFactory() - Constructor for class org.apache.ignite.cache.jta.websphere.WebSphereTmFactory
 
WeightedRandomLoadBalancingSpi - Class in org.apache.ignite.spi.loadbalancing.weightedrandom
Load balancing SPI that picks a random node for job execution.
WeightedRandomLoadBalancingSpi() - Constructor for class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
 
WeightedRandomLoadBalancingSpiMBean - Interface in org.apache.ignite.spi.loadbalancing.weightedrandom
Management MBean for WeightedRandomLoadBalancingSpi SPI.
whenNull(IgniteLogger) - Static method in class org.apache.ignite.logger.NullLogger
 
withAsync() - Method in interface org.apache.ignite.IgniteCache
Deprecated.
withAsync() - Method in interface org.apache.ignite.IgniteCluster
Deprecated.
withAsync() - Method in interface org.apache.ignite.IgniteCompute
Deprecated.
withAsync() - Method in interface org.apache.ignite.IgniteEvents
Deprecated.
withAsync() - Method in interface org.apache.ignite.IgniteMessaging
Deprecated.
withAsync() - Method in interface org.apache.ignite.IgniteServices
Deprecated.
withAsync() - Method in interface org.apache.ignite.lang.IgniteAsyncSupport
Deprecated.
since 2.0. Please use new specialized async method e.g.
     IgniteFuture f = cache.getAsync();
 
instead of old-style async API:
     IgniteCache asyncCache = cache.withAsync();
     asyncCache.get(key);
     IgniteFuture fut = asyncCache.future();
 
withExecutor(String) - Method in interface org.apache.ignite.IgniteCompute
Gets instance of the compute API associated with custom executor.
withExpirePolicy(ExpiryPolicy) - Method in interface org.apache.ignite.client.ClientCache
Returns cache with the specified expired policy set.
withExpiryPolicy(ExpiryPolicy) - Method in interface org.apache.ignite.IgniteCache
Returns cache with the specified expired policy set.
withIncludedScopes(Set<Scope>) - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters.Builder
Builder method that allows to set included scopes.
withKeepBinary() - Method in interface org.apache.ignite.client.ClientCache
Returns cache that will operate with binary objects.
withKeepBinary() - Method in interface org.apache.ignite.IgniteCache
Returns cache that will operate with binary objects.
withKeepBinary() - Method in interface org.apache.ignite.IgniteQueue
Returns queue that will operate with binary objects.
withKeepBinary() - Method in interface org.apache.ignite.IgniteSet
Returns Ignite set that operates on binary objects without deserialization.
withLabel(String) - Method in interface org.apache.ignite.client.ClientTransactions
Returns instance of ClientTransactions to mark each new transaction with a specified label.
withLabel(String) - Method in interface org.apache.ignite.IgniteTransactions
Returns instance of Ignite Transactions to mark a transaction with a special label.
withLabel(String) - Method in class org.apache.ignite.spi.tracing.TracingConfigurationCoordinates.Builder
Builder method that allows to set optional label attribute.
withName(String) - Method in interface org.apache.ignite.IgniteCompute
Sets task name for the next executed task in the current thread.
withNoFailover() - Method in interface org.apache.ignite.client.ClientCompute
Sets no-failover flag for tasks executed by returned ClientCompute instance.
withNoFailover() - Method in interface org.apache.ignite.IgniteCompute
Sets no-failover flag for the next task executed in the current thread.
withNoResultCache() - Method in interface org.apache.ignite.client.ClientCompute
Disables result caching for tasks executed by returned ClientCompute instance.
withNoResultCache() - Method in interface org.apache.ignite.IgniteCompute
Disables caching for the next executed task in the current thread.
withNoRetries() - Method in interface org.apache.ignite.IgniteCache
 
withPartitionRecover() - Method in interface org.apache.ignite.IgniteCache
Gets an instance of IgniteCache that will be allowed to execute cache read operations regardless of partition loss policy.
withReadRepair(ReadRepairStrategy) - Method in interface org.apache.ignite.IgniteCache
This is an experimental API.
withSamplingRate(double) - Method in class org.apache.ignite.spi.tracing.TracingConfigurationParameters.Builder
Builder method that allows to set sampling rate.
withSkipStore() - Method in interface org.apache.ignite.IgniteCache
 
withTimeout(long) - Method in interface org.apache.ignite.client.ClientCompute
Sets timeout for tasks executed by returned ClientCompute instance.
withTimeout(long) - Method in interface org.apache.ignite.IgniteCompute
Sets task timeout for the next executed task in the current thread.
withTracing() - Method in interface org.apache.ignite.IgniteTransactions
Returns an instance of IgniteTransactions tran will trace every transaction.
worker() - Method in interface org.apache.ignite.spi.discovery.IgniteDiscoveryThread
 
WorkersControlMXBean - Interface in org.apache.ignite.mxbean
MBean that provides ability to terminate worker that registered in the workers registry.
write(Cache.Entry<? extends K, ? extends V>) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
write(Cache.Entry<? extends K, ? extends V>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
write(Cache.Entry<? extends K, ? extends V>) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
writeAffinityTopologyVersion(String, AffinityTopologyVersion) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes AffinityTopologyVersion.
writeAll(Collection<Cache.Entry<? extends K, ? extends V>>) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
writeAll(Collection<Cache.Entry<? extends K, ? extends V>>) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
writeAll(Collection<Cache.Entry<? extends K, ? extends V>>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
writeBehindBatchSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeBehindCoalescing() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeBehindFlushFrequency() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeBehindFlushSize() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeBehindFlushThreadCount() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeBinary(BinaryWriter) - Method in interface org.apache.ignite.binary.Binarylizable
Writes fields to provided writer.
writeBinary(Object, BinaryWriter) - Method in class org.apache.ignite.binary.BinaryReflectiveSerializer
Writes fields to provided writer.
writeBinary(Object, BinaryWriter) - Method in interface org.apache.ignite.binary.BinarySerializer
Writes fields to provided writer.
writeBinary(BinaryWriter) - Method in class org.apache.ignite.lang.IgniteUuid
Writes fields to provided writer.
writeBitSet(String, BitSet) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes BitSet.
writeBoolean(boolean) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeBoolean(String, boolean) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeBoolean(String, boolean) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes boolean value.
writeBooleanArray(boolean[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeBooleanArray(String, boolean[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeBooleanArray(String, boolean[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes boolean array.
writeByte(byte) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeByte(String, byte) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeByte(String, byte) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes byte value.
writeByteArray(byte[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeByteArray(String, byte[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeByteArray(String, byte[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes byte array.
writeByteArray(String, byte[], long, int) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes byte array.
writeChar(char) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeChar(String, char) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeChar(String, char) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes char value.
writeCharArray(char[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeCharArray(String, char[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeCharArray(String, char[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes char array.
writeCollection(Collection<T>) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeCollection(String, Collection<T>) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeCollection(String, Collection<T>, MessageCollectionItemType) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes collection.
writeDate(Date) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDate(String, Date) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDateArray(Date[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDateArray(String, Date[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDecimal(BigDecimal) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDecimal(String, BigDecimal) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDecimalArray(BigDecimal[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDecimalArray(String, BigDecimal[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDouble(double) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDouble(String, double) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDouble(String, double) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes double value.
writeDoubleArray(double[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeDoubleArray(String, double[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeDoubleArray(String, double[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes double array.
writeEnum(T) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeEnum(String, T) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeEnumArray(T[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeEnumArray(String, T[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeExternal(ObjectOutput) - Method in class org.apache.ignite.cache.affinity.AffinityKey
writeExternal(ObjectOutput) - Method in class org.apache.ignite.cache.eviction.AbstractEvictionPolicy
writeExternal(ObjectOutput) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
writeExternal(ObjectOutput) - Method in class org.apache.ignite.IgniteSpringBean
writeExternal(ObjectOutput) - Method in class org.apache.ignite.lang.IgniteBiTuple
writeExternal(ObjectOutput) - Method in class org.apache.ignite.lang.IgniteProductVersion
writeExternal(ObjectOutput) - Method in class org.apache.ignite.lang.IgniteUuid
writeExternal(ObjectOutput) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetAffinityFunction
writeExternal(ObjectOutput) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
writeFloat(float) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeFloat(String, float) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeFloat(String, float) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes float value.
writeFloatArray(float[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeFloatArray(String, float[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeFloatArray(String, float[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes float array.
writeHeader(short, byte) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes message header.
writeIgniteUuid(String, IgniteUuid) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes IgniteUuid.
writeInt(int) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeInt(String, int) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeInt(String, int) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes int value.
writeIntArray(int[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeIntArray(String, int[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeIntArray(String, int[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes int array.
writeLong(long) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeLong(String, long) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeLong(String, long) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes long value.
writeLongArray(long[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeLongArray(String, long[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeLongArray(String, long[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes long array.
writeLongArray(String, long[], int) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes long array.
writeMap(Map<K, V>) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeMap(String, Map<K, V>) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeMap(String, Map<K, V>, MessageCollectionItemType, MessageCollectionItemType) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes map.
writeMessage(String, Message) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes nested message.
writeMessageType(ByteBuffer, short) - Static method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
Write message type to byte buffer.
writeObject(Object) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeObject(String, Object) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeObjectArray(Object[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeObjectArray(String, Object[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeObjectArray(String, T[], MessageCollectionItemType) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes array of objects.
writer(UUID) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFormatter
Creates new message writer instance.
writeReplace() - Method in class org.apache.ignite.configuration.CacheConfiguration
Creates a copy of current configuration and removes all cache entry listeners.
writeShort(short) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeShort(String, short) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeShort(String, short) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes short value.
writeShortArray(short[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeShortArray(String, short[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeShortArray(String, short[]) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes short array.
writeString(String) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeString(String, String) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeString(String, String) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes String.
writeStringArray(String[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeStringArray(String, String[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeSynchronizationMode() - Method in class org.apache.ignite.spi.systemview.view.CacheView
 
writeTime(Time) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeTime(String, Time) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeTimeArray(Time[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeTimeArray(String, Time[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeTimestamp(Timestamp) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeTimestamp(String, Timestamp) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeTimestampArray(Timestamp[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeTimestampArray(String, Timestamp[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeTo(ByteBuffer, MessageWriter) - Method in interface org.apache.ignite.plugin.extensions.communication.Message
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeMessage2
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.messages.HandshakeWaitMessage
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.messages.NodeIdMessage
Writes this message to provided byte buffer.
writeTo(ByteBuffer, MessageWriter) - Method in class org.apache.ignite.spi.communication.tcp.messages.RecoveryLastReceivedMessage
Writes this message to provided byte buffer.
writeToSocket(Socket, TcpDiscoveryAbstractMessage, byte[], long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Writes message to the socket.
writeToSocket(Socket, TcpDiscoveryAbstractMessage, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Writes message to the socket.
writeToSocket(ClusterNode, Socket, OutputStream, TcpDiscoveryAbstractMessage, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
 
writeToSocket(Socket, OutputStream, TcpDiscoveryAbstractMessage, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Writes message to the socket.
writeToSocket(TcpDiscoveryAbstractMessage, Socket, int, long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
Writes response to the socket.
writeUuid(UUID) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeUuid(String, UUID) - Method in interface org.apache.ignite.binary.BinaryWriter
 
writeUuid(String, UUID) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
Writes UUID.
writeUuidArray(UUID[]) - Method in interface org.apache.ignite.binary.BinaryRawWriter
 
writeUuidArray(String, UUID[]) - Method in interface org.apache.ignite.binary.BinaryWriter
 

X

xid() - Method in class org.apache.ignite.events.CacheEvent
ID of surrounding cache transaction or null if there is no surrounding transaction.
xid() - Method in class org.apache.ignite.spi.systemview.view.TransactionView
 
xid() - Method in interface org.apache.ignite.transactions.Transaction
Gets unique identifier for this transaction.
XML_DESCRIPTOR_PATH - Static variable in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
Default task description file path and name (value is META-INF/ignite.xml).

Z

ZookeeperDiscoverySpi - Class in org.apache.ignite.spi.discovery.zk
Zookeeper Discovery Spi.
ZookeeperDiscoverySpi() - Constructor for class org.apache.ignite.spi.discovery.zk.ZookeeperDiscoverySpi
 
ZookeeperDiscoverySpiMBean - Interface in org.apache.ignite.spi.discovery.zk
Management bean for ZookeeperDiscoverySpi.
A B C D E F G H I J K L M N O P Q R S T U V W X Z 

${current.year} Copyright © Apache Software Foundation
Ignite Database and Caching Platform :   ver. 2.16.0
Release Date :   December 15 2023